Skip to content

Commit

Permalink
Update tags
Browse files Browse the repository at this point in the history
  • Loading branch information
pavel-avilov committed Dec 29, 2021
1 parent 1c6c3f6 commit d9f166e
Show file tree
Hide file tree
Showing 19 changed files with 10 additions and 89 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -24,6 +24,7 @@
// pipeline_options:
// categories:
// - Side Input
// - Flatten

import java.net.URI;
import java.util.Arrays;
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -24,6 +24,7 @@
// pipeline_options:
// categories:
// - Testing
// - Filtering

import java.io.Serializable;
import java.util.Arrays;
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -17,14 +17,6 @@
*/
package org.apache.beam.examples.complete.kafkatopubsub;

// beam-playground:
// name: KafkaToPubsubTest
// description: Unit-test for the KafkaToPubsub example.
// multifile: false
// pipeline_options:
// categories:
// - Streaming

import static org.apache.beam.examples.complete.kafkatopubsub.KafkaPubsubConstants.PASSWORD;
import static org.apache.beam.examples.complete.kafkatopubsub.KafkaPubsubConstants.USERNAME;
import static org.apache.beam.examples.complete.kafkatopubsub.kafka.consumer.Utils.getKafkaCredentialsFromVault;
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -23,8 +23,8 @@
// multifile: false
// pipeline_options:
// categories:
// - IO
// - Options
// - Core Transforms
// - Filtering

import java.util.Arrays;
import java.util.List;
Expand Down
8 changes: 0 additions & 8 deletions sdks/go/pkg/beam/core/util/symtab/symtab_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -15,14 +15,6 @@

package symtab

// beam-playground:
// name: SymtabTest
// description: Unit-test for the Symtab example.
// multifile: false
// pipeline_options:
// categories:
// - Side Input

import (
"io/ioutil"
"os"
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/partition_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -21,7 +21,7 @@ package beam_test
// multifile: false
// pipeline_options:
// categories:
// - Testing
// - Core Transforms

import (
"testing"
Expand Down
1 change: 1 addition & 0 deletions sdks/go/pkg/beam/transforms/filter/distinct_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -22,6 +22,7 @@ package filter_test
// pipeline_options:
// categories:
// - Filtering
// - Core Transforms

import (
"testing"
Expand Down
10 changes: 0 additions & 10 deletions sdks/go/test/integration/integration.go
Original file line number Diff line number Diff line change
Expand Up @@ -34,16 +34,6 @@
// environment setup, or by calling gradle commands in :sdks:go:test.
package integration

// beam-playground:
// name: CheckFiltersTest
// description: Unit-test checks if an integration test is filtered to be skipped, either
// because the intended runner does not support it, or the test is sickbayed.
// multifile: false
// pipeline_options:
// categories:
// - Filtering
// - Testing

import (
"fmt"
"regexp"
Expand Down
8 changes: 0 additions & 8 deletions sdks/go/test/integration/synthetic/synthetic_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -15,14 +15,6 @@

package synthetic

// beam-playground:
// name: SyntheticTest
// description: Unit-test for the Synthetic example.
// multifile: false
// pipeline_options:
// categories:
// - Testing

import (
"testing"

Expand Down
9 changes: 0 additions & 9 deletions sdks/go/test/integration/xlang/xlang_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -15,15 +15,6 @@

package xlang

// beam-playground:
// name: XLangTest
// description: Unit-test for the XLang example.
// multifile: false
// pipeline_options:
// categories:
// - Combiners
// - Testing

import (
"fmt"
"reflect"
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -17,14 +17,6 @@
*/
package org.apache.beam.sdk.io;

// beam-playground:
// name: FileBasedSourceTest
// description: Unit-test for the FileBasedSource example.
// multifile: false
// pipeline_options:
// categories:
// - IO

import static org.apache.beam.sdk.testing.SourceTestUtils.assertSplitAtFractionExhaustive;
import static org.apache.beam.sdk.testing.SourceTestUtils.assertSplitAtFractionFails;
import static org.apache.beam.sdk.testing.SourceTestUtils.assertSplitAtFractionSucceedsAndConsistent;
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -17,14 +17,6 @@
*/
package org.apache.beam.sdk.schemas.transforms;

// beam-playground:
// name: ConvertTest
// description: Unit-test for the Convert example.
// multifile: false
// pipeline_options:
// categories:
// - Schemas

import java.util.Arrays;
import java.util.Map;
import java.util.Objects;
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,7 @@
// multifile: false
// pipeline_options:
// categories:
// - Testing
// - Streaming

import static org.apache.beam.sdk.transforms.windowing.Window.into;
import static org.hamcrest.MatcherAssert.assertThat;
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -17,15 +17,6 @@
*/
package org.apache.beam.sdk.transforms.windowing;

// beam-playground:
// name: WindowingTest
// description: Unit-test for the Windowing kata.
// multifile: false
// pipeline_options:
// categories:
// - Windowing
// - Streaming

import java.io.File;
import java.io.FileOutputStream;
import java.io.PrintStream;
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -26,6 +26,7 @@
# pipeline_options:
# categories:
# - Streaming
# - IO

import logging
import unittest
Expand Down
1 change: 1 addition & 0 deletions sdks/python/apache_beam/examples/wordcount_minimal_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -26,6 +26,7 @@
# pipeline_options:
# categories:
# - IO
# - Combiners

import collections
import logging
Expand Down
1 change: 1 addition & 0 deletions sdks/python/apache_beam/examples/wordcount_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -27,6 +27,7 @@
# pipeline_options:
# categories:
# - IO
# - Combiners

import collections
import logging
Expand Down
8 changes: 0 additions & 8 deletions sdks/python/apache_beam/io/filesystemio_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -19,14 +19,6 @@

# pytype: skip-file

# beam-playground:
# name: FileSystemIOTest
# description: Unit-test for the FileSystemIO example.
# multifile: false
# pipeline_options:
# categories:
# - IO

import io
import logging
import multiprocessing
Expand Down
9 changes: 0 additions & 9 deletions sdks/python/apache_beam/transforms/window_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -18,15 +18,6 @@
"""Unit tests for the windowing classes."""
# pytype: skip-file

# beam-playground:
# name: MetricTest
# description: Unit-test for the Window example.
# multifile: false
# pipeline_options:
# categories:
# - Core Transforms
# - Windowing

import unittest

import apache_beam as beam
Expand Down

0 comments on commit d9f166e

Please sign in to comment.