@DefaultAnnotation(value=org.checkerframework.checker.nullness.qual.NonNull.class)
See: Description
| Interface | Description | 
|---|---|
| FlattenWithHeterogeneousCoders | Category tag for tests that use a  Flattenwhere the inputPCollectionListcontainsPCollectionsheterogeneouscoders. | 
| LargeKeys | Category tags for tests which validate that a Beam runner can handle keys up to a given size. | 
| LargeKeys.Above100KB | Tests if a runner supports 100KB keys. | 
| LargeKeys.Above100MB | Tests if a runner supports 100MB keys. | 
| LargeKeys.Above10KB | Tests if a runner supports 10KB keys. | 
| LargeKeys.Above10MB | Tests if a runner supports 10MB keys. | 
| LargeKeys.Above1MB | Tests if a runner supports 1MB keys. | 
| NeedsRunner | Category tag for validation tests which utilize  TestPipelinefor execution and expect to
 be executed by aPipelineRunner. | 
| PAssert.IterableAssert<T> | Builder interface for assertions applicable to iterables and PCollection contents. | 
| PAssert.SingletonAssert<T> | Builder interface for assertions applicable to a single value. | 
| SerializableMatcher<T> | A  Matcherthat is alsoSerializable. | 
| SerializableMatchers.SerializableSupplier<T> | Supplies values of type  T, and is serializable. | 
| StreamingIT | Deprecated tests which use unbounded PCollections should be in the category  UsesUnboundedPCollections. | 
| TestPipeline.TestValueProviderOptions | Implementation detail of  TestPipeline.newProvider(T), do not use. | 
| TestPipelineOptions | TestPipelineOptionsis a set of options for test pipelines. | 
| TestStream.Event<T> | An event in a  TestStream. | 
| UsesBoundedSplittableParDo | |
| UsesBundleFinalizer | Category tag for validation tests which use  DoFn.BundleFinalizer. | 
| UsesCommittedMetrics | Category tag for validation tests which utilize  Metrics. | 
| UsesCrossLanguageTransforms | Category tag for validation tests which use cross-language transforms. | 
| UsesCustomWindowMerging | Category tag for validation tests which utilize custom window merging. | 
| UsesFailureMessage | Category tag for tests which validate that currect failure message is provided by failed
 pipeline. | 
| UsesKeyInParDo | Category tag for validation tests which use key. | 
| UsesKms | Category tag for validation tests which utilize --tempRoot from  TestPipelineOptionsand
 and expect a default KMS key enable for the bucket specified. | 
| UsesLoopingTimer | Category tag for validation tests which utilize looping timers in  ParDo. | 
| UsesMapState | Category tag for validation tests which utilize  MapState. | 
| UsesMetricsPusher | Category tag for validation tests which utilize the metrics pusher feature. | 
| UsesOnWindowExpiration | Category tag for validation tests which utilize  DoFn.OnWindowExpiration. | 
| UsesParDoLifecycle | Category tag for the ParDoLifecycleTest for exclusion (BEAM-3241). | 
| UsesPerKeyOrderedDelivery | Category tag for validation tests which rely on a runner providing per-key ordering. | 
| UsesPerKeyOrderInBundle | Category tag for validation tests which rely on a runner providing per-key ordering in between
 transforms in the same ProcessBundleRequest. | 
| UsesPythonExpansionService | Category tag for tests which use the expansion service in Python. | 
| UsesRequiresTimeSortedInput | Category tag for validation tests which utilize DoFn.RequiresTimeSortedInputin statefulParDo. | 
| UsesSchema | Category tag for validation tests which utilize schemas. | 
| UsesSdkHarnessEnvironment | Category tag for tests which validate that the SDK harness executes in a well formed environment. | 
| UsesSetState | Category tag for validation tests which utilize  SetState. | 
| UsesSideInputs | Category tag for validation tests which use sideinputs. | 
| UsesSideInputsWithDifferentCoders | Category tag for validation tests which use multiple side inputs with different coders. | 
| UsesStatefulParDo | Category tag for validation tests which utilize stateful  ParDo. | 
| UsesStrictTimerOrdering | Category for tests that enforce strict event-time ordering of fired timers, even in situations
 where multiple tests mutually set one another and watermark hops arbitrarily far to the future. | 
| UsesSystemMetrics | Category tag for tests that use System metrics. | 
| UsesTestStream | Category tag for tests that use  TestStream, which is not a part of the Beam model but a
 special feature currently only implemented by the direct runner and the Flink Runner (streaming). | 
| UsesTestStreamWithMultipleStages | Subcategory for  UsesTestStreamtests which useTestStream# across multiple
 stages. | 
| UsesTestStreamWithOutputTimestamp | Category tag for validation tests which use outputTimestamp. | 
| UsesTestStreamWithProcessingTime | Subcategory for  UsesTestStreamtests which use the processing time feature ofTestStream. | 
| UsesTimerMap | Category tag for validation tests which use timerMap. | 
| UsesTimersInParDo | Category tag for validation tests which utilize timers in  ParDo. | 
| UsesUnboundedPCollections | Category tag for validation tests which utilize at least one unbounded  PCollection. | 
| UsesUnboundedSplittableParDo | |
| ValidatesRunner | Category tag for tests which validate that a Beam runner is correctly implemented. | 
| Class | Description | 
|---|---|
| CoderProperties | Properties for use in  Codertests. | 
| CoderProperties.TestElementByteSizeObserver | An  ElementByteSizeObserverthat records the observed element sizes for testing
 purposes. | 
| CombineFnTester | Utilities for testing  CombineFns. | 
| CrashingRunner | A  PipelineRunnerthat applies no overrides and throws an exception on calls toPipeline.run(). | 
| FileChecksumMatcher | Matcher to verify checksum of the contents of an  ShardedFilein E2E test. | 
| JsonMatcher<T> | Matcher to compare a string or byte[] representing a JSON Object, independent of field order. | 
| PAssert | An assertion on the contents of a  PCollectionincorporated into the pipeline. | 
| PAssert.DefaultConcludeTransform | Default transform to check that a PAssert was successful. | 
| PAssert.GroupThenAssert<T> | A transform that applies an assertion-checking function over iterables of  ActualTto
 the entirety of the contents of its input. | 
| PAssert.GroupThenAssertForSingleton<T> | A transform that applies an assertion-checking function to the sole element of a  PCollection. | 
| PAssert.MatcherCheckerFn<T> | Check that the passed-in matchers match the existing data. | 
| PAssert.OneSideInputAssert<ActualT> | An assertion checker that takes a single  PCollectionView<ActualT>and an assertion overActualT, and checks it within a Beam pipeline. | 
| PAssert.PAssertionSite | Track the place where an assertion is defined. | 
| PAssert.PCollectionContentsAssert<T> | An  PAssert.IterableAssertabout the contents of aPCollection. | 
| PAssert.PCollectionListContentsAssert<T> | An assert about the contents of each  PCollectionin the givenPCollectionList. | 
| RegexMatcher | Hamcrest matcher to assert a string matches a pattern. | 
| SerializableMatchers | Static class for building and using  SerializableMatcherinstances. | 
| SourceTestUtils | Helper functions and test harnesses for checking correctness of  Sourceimplementations. | 
| SuccessOrFailure | Output of  PAssert. | 
| TestPipeline | A creator of test pipelines that can be used inside of tests that can be configured to run
 locally or against a remote pipeline runner. | 
| TestPipelineOptions.AlwaysPassMatcher | Matcher which will always pass. | 
| TestPipelineOptions.AlwaysPassMatcherFactory | Factory for  PipelineResultmatchers which always pass. | 
| TestStream<T> | A testing input that generates an unbounded  PCollectionof elements, advancing the
 watermark and processing time as elements are emitted. | 
| TestStream.Builder<T> | An incomplete  TestStream. | 
| TestStream.ElementEvent<T> | A  TestStream.Eventthat produces elements. | 
| TestStream.ProcessingTimeEvent<T> | A  TestStream.Eventthat advances the processing time clock. | 
| TestStream.TestStreamCoder<T> | Coder for  TestStream. | 
| TestStream.WatermarkEvent<T> | A  TestStream.Eventthat advances the watermark. | 
| UsesAttemptedMetrics | Category tag for validation tests which utilize  Metrics. | 
| UsesCounterMetrics | Category tag for validation tests which utilize  Counter. | 
| UsesDistributionMetrics | Category tag for validation tests which utilize  Distribution. | 
| UsesGaugeMetrics | Category tag for validation tests which utilize  Gauge. | 
| UsesImpulse | Category for tests that use  Impulsetransformations. | 
| UsesOrderedListState | Category tag for validation tests which utilize  OrderedListState. | 
| WindowFnTestUtils | A utility class for testing  WindowFns. | 
| Enum | Description | 
|---|---|
| SourceTestUtils.ExpectedSplitOutcome | Expected outcome of  BoundedSource.BoundedReader.splitAtFraction(double). | 
| TestStream.EventType | The types of  TestStream.Eventthat are supported byTestStream. | 
| Exception | Description | 
|---|---|
| TestPipeline.AbandonedNodeException | An exception thrown in case an abandoned  PTransformis
 detected, that is, aPTransformthat has not been run. | 
| TestPipeline.PipelineRunMissingException | An exception thrown in case a test finishes without invoking  Pipeline.run(). | 
PTransforms
 and examples included in the Apache Beam SDK provide examples of using these utilities.