@DefaultAnnotation(value=edu.umd.cs.findbugs.annotations.NonNull.class)
PTransforms for transforming data in a pipeline.See: Description
| Interface | Description | 
|---|---|
| Combine.AccumulatingCombineFn.Accumulator<InputT,AccumT,OutputT> | The type of mutable accumulator values used by this  AccumulatingCombineFn. | 
| CombineFnBase.GlobalCombineFn<InputT,AccumT,OutputT> | For internal use only; no backwards-compatibility guarantees. | 
| CombineWithContext.RequiresContextInternal | An internal interface for signaling that a  GloballyCombineFnor aPerKeyCombineFnneeds to accessCombineWithContext.Context. | 
| Contextful.Fn<InputT,OutputT> | A function from an input to an output that may additionally access  Contextful.Fn.Contextwhen
 computing the result. | 
| DoFn.BundleFinalizer | A parameter that is accessible during  @StartBundle,@ProcessElementand@FinishBundlethat allows the caller
 to register a callback that will be invoked after the bundle has been successfully completed
 and the runner has commit the output. | 
| DoFn.BundleFinalizer.Callback | An instance of a function that will be invoked after bundle finalization. | 
| DoFn.MultiOutputReceiver | Receives tagged output for a multi-output function. | 
| DoFn.OutputReceiver<T> | Receives values of the given type. | 
| Materialization<T> | For internal use only; no backwards-compatibility guarantees. | 
| Materializations.MultimapView<K,V> | Represents the  PrimitiveViewTsupplied to theViewFnwhen it declares to use
 themultimap materialization. | 
| Partition.PartitionFn<T> | A function object that chooses an output partition for an element. | 
| ProcessFunction<InputT,OutputT> | A function that computes an output value of type  OutputTfrom an input value of typeInputTand isSerializable. | 
| SerializableComparator<T> | A  Comparatorthat is alsoSerializable. | 
| SerializableFunction<InputT,OutputT> | A function that computes an output value of type  OutputTfrom an input value of typeInputT, isSerializable, and does not allow checked exceptions to be declared. | 
| Watch.Growth.TerminationCondition<InputT,StateT> | A strategy for determining whether it is time to stop polling the current input regardless of
 whether its output is complete or not. | 
| Class | Description | 
|---|---|
| ApproximateQuantiles | PTransforms for getting an idea of aPCollection's data distribution using
 approximateN-tiles (e.g. | 
| ApproximateQuantiles.ApproximateQuantilesCombineFn<T,ComparatorT extends java.util.Comparator<T> & java.io.Serializable> | The  ApproximateQuantilesCombineFncombiner gives an idea of the distribution of a
 collection of values using approximateN-tiles. | 
| ApproximateUnique | PTransforms for estimating the number of distinct elements in aPCollection, or
 the number of distinct values associated with each key in aPCollectionofKVs. | 
| ApproximateUnique.ApproximateUniqueCombineFn<T> | CombineFnthat computes an estimate of the number of distinct values that were
 combined. | 
| ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique | A heap utility class to efficiently track the largest added elements. | 
| Combine | PTransforms for combiningPCollectionelements globally and per-key. | 
| Combine.AccumulatingCombineFn<InputT,AccumT extends Combine.AccumulatingCombineFn.Accumulator<InputT,AccumT,OutputT>,OutputT> | A  CombineFnthat uses a subclass ofCombine.AccumulatingCombineFn.Accumulatoras its
 accumulator type. | 
| Combine.BinaryCombineDoubleFn | An abstract subclass of  Combine.CombineFnfor implementing combiners that are more easily and
 efficiently expressed as binary operations ondoubles. | 
| Combine.BinaryCombineFn<V> | An abstract subclass of  Combine.CombineFnfor implementing combiners that are more easily
 expressed as binary operations. | 
| Combine.BinaryCombineIntegerFn | An abstract subclass of  Combine.CombineFnfor implementing combiners that are more easily and
 efficiently expressed as binary operations onints | 
| Combine.BinaryCombineLongFn | An abstract subclass of  Combine.CombineFnfor implementing combiners that are more easily and
 efficiently expressed as binary operations onlongs. | 
| Combine.CombineFn<InputT,AccumT,OutputT> | A  CombineFn<InputT, AccumT, OutputT>specifies how to combine a collection of input
 values of typeInputTinto a single output value of typeOutputT. | 
| Combine.Globally<InputT,OutputT> | Combine.Globally<InputT, OutputT>takes aPCollection<InputT>and returns aPCollection<OutputT>whose elements are the result of combining all the elements in
 each window of the inputPCollection, using a specifiedCombineFn<InputT, AccumT, OutputT>. | 
| Combine.GloballyAsSingletonView<InputT,OutputT> | Combine.GloballyAsSingletonView<InputT, OutputT>takes aPCollection<InputT>and returns aPCollectionView<OutputT>whose elements are the result of combining all
 the elements in each window of the inputPCollection, using a specifiedCombineFn<InputT, AccumT, OutputT>. | 
| Combine.GroupedValues<K,InputT,OutputT> | GroupedValues<K, InputT, OutputT>takes aPCollection<KV<K, Iterable<InputT>>>,
 such as the result ofGroupByKey, applies a specifiedCombineFn<InputT, AccumT, OutputT>to each of the inputKV<K, Iterable<InputT>>elements to produce a combined outputKV<K, OutputT>element, and returns aPCollection<KV<K, OutputT>>containing all the combined output elements. | 
| Combine.Holder<V> | Holds a single value value of type  Vwhich may or may not be present. | 
| Combine.IterableCombineFn<V> | |
| Combine.PerKey<K,InputT,OutputT> | PerKey<K, InputT, OutputT>takes aPCollection<KV<K, InputT>>, groups it by
 key, applies a combining function to theInputTvalues associated with each key to
 produce a combinedOutputTvalue, and returns aPCollection<KV<K, OutputT>>representing a map from each distinct key of the inputPCollectionto the corresponding
 combined value. | 
| Combine.PerKeyWithHotKeyFanout<K,InputT,OutputT> | Like  Combine.PerKey, but sharding the combining of hot keys. | 
| Combine.SimpleCombineFn<V> | Deprecated | 
| CombineFnBase | For internal use only; no backwards-compatibility guarantees. | 
| CombineFns | Static utility methods that create combine function instances. | 
| CombineFns.CoCombineResult | A tuple of outputs produced by a composed combine functions. | 
| CombineFns.ComposeCombineFnBuilder | A builder class to construct a composed  CombineFnBase.GlobalCombineFn. | 
| CombineFns.ComposedCombineFn<DataT> | A composed  Combine.CombineFnthat applies multipleCombineFns. | 
| CombineFns.ComposedCombineFnWithContext<DataT> | A composed  CombineWithContext.CombineFnWithContextthat applies multipleCombineFnWithContexts. | 
| CombineWithContext | This class contains combine functions that have access to  PipelineOptionsand side inputs
 throughCombineWithContext.Context. | 
| CombineWithContext.CombineFnWithContext<InputT,AccumT,OutputT> | A combine function that has access to  PipelineOptionsand side inputs throughCombineWithContext.Context. | 
| CombineWithContext.Context | Information accessible to all methods in  CombineFnWithContextandKeyedCombineFnWithContext. | 
| Contextful<ClosureT> | Pair of a bit of user code (a "closure") and the  Requirementsneeded to run it. | 
| Contextful.Fn.Context | An accessor for additional capabilities available in  Contextful.Fn.apply(InputT, org.apache.beam.sdk.transforms.Contextful.Fn.Context). | 
| Count | PTransformsto count the elements in aPCollection. | 
| Create<T> | Create<T>takes a collection of elements of typeTknown when the pipeline is
 constructed and returns aPCollection<T>containing the elements. | 
| Create.OfValueProvider<T> | |
| Create.TimestampedValues<T> | A  PTransformthat creates aPCollectionwhose elements have associated
 timestamps. | 
| Create.Values<T> | A  PTransformthat creates aPCollectionfrom a set of in-memory objects. | 
| Distinct<T> | Distinct<T>takes aPCollection<T>and returns aPCollection<T>that has
 all distinct elements of the input. | 
| Distinct.WithRepresentativeValues<T,IdT> | A  DistinctPTransformthat uses aSerializableFunctionto obtain a
 representative value for each input element. | 
| DoFn<InputT,OutputT> | The argument to  ParDoproviding the code to use to process elements of the inputPCollection. | 
| DoFn.ProcessContinuation | When used as a return value of  DoFn.ProcessElement, indicates whether there is more work to
 be done for the current element. | 
| DoFnOutputReceivers | Common  DoFn.OutputReceiverandDoFn.MultiOutputReceiverclasses. | 
| DoFnTester<InputT,OutputT> | Deprecated Use  TestPipelinewith theDirectRunner. | 
| Filter<T> | PTransforms for filtering from aPCollectionthe elements satisfying a predicate,
 or satisfying an inequality with a given value based on the elements' natural ordering. | 
| FlatMapElements<InputT,OutputT> | PTransforms for mapping a simple function that returns iterables over the elements of aPCollectionand merging the results. | 
| Flatten | Flatten<T>takes multiplePCollection<T>s bundled into aPCollectionList<T>and returns a singlePCollection<T>containing all the elements in
 all the inputPCollections. | 
| Flatten.Iterables<T> | FlattenIterables<T>takes aPCollection<Iterable<T>>and returns aPCollection<T>that contains all the elements from each iterable. | 
| Flatten.PCollections<T> | A  PTransformthat flattens aPCollectionListinto aPCollectioncontaining all the elements of all thePCollections in its input. | 
| GroupByKey<K,V> | GroupByKey<K, V>takes aPCollection<KV<K, V>>, groups the values by key and
 windows, and returns aPCollection<KV<K, Iterable<V>>>representing a map from each
 distinct key and window of the inputPCollectionto anIterableover all the
 values associated with that key in the input per window. | 
| GroupIntoBatches<K,InputT> | A  PTransformthat batches inputs to a desired batch size. | 
| Impulse | For internal use only; no backwards-compatibility guarantees. | 
| InferableFunction<InputT,OutputT> | A  ProcessFunctionwhich is not a functional interface. | 
| JsonToRow | Experimental | 
| Keys<K> | Keys<K>takes aPCollectionofKV<K, V>s and returns aPCollection<K>of the keys. | 
| KvSwap<K,V> | KvSwap<K, V>takes aPCollection<KV<K, V>>and returns aPCollection<KV<V,
 K>>, where all the keys and values have been swapped. | 
| Latest | |
| MapElements<InputT,OutputT> | PTransforms for mapping a simple function over the elements of aPCollection. | 
| Materializations | For internal use only; no backwards-compatibility guarantees. | 
| Max | PTransforms for computing the maximum of the elements in aPCollection, or the
 maximum of the values associated with each key in aPCollectionofKVs. | 
| Mean | PTransforms for computing the arithmetic mean (a.k.a. | 
| Min | PTransforms for computing the minimum of the elements in aPCollection, or the
 minimum of the values associated with each key in aPCollectionofKVs. | 
| ParDo | ParDois the core element-wise transform in Apache Beam, invoking a user-specified
 function on each of the elements of the inputPCollectionto produce zero or more output
 elements, all of which are collected into the outputPCollection. | 
| ParDo.MultiOutput<InputT,OutputT> | A  PTransformthat, when applied to aPCollection<InputT>, invokes a
 user-specifiedDoFn<InputT, OutputT>on all its elements, which can emit elements to
 any of thePTransform's outputPCollections, which are bundled into a resultPCollectionTuple. | 
| ParDo.SingleOutput<InputT,OutputT> | A  PTransformthat, when applied to aPCollection<InputT>, invokes a
 user-specifiedDoFn<InputT, OutputT>on all its elements, with all its outputs
 collected into an outputPCollection<OutputT>. | 
| Partition<T> | Partitiontakes aPCollection<T>and aPartitionFn, uses thePartitionFnto split the elements of the inputPCollectionintoNpartitions,
 and returns aPCollectionList<T>that bundlesNPCollection<T>s
 containing the split elements. | 
| PTransform<InputT extends PInput,OutputT extends POutput> | |
| Regex | PTransorms to use Regular Expressions to process elements in aPCollection. | 
| Regex.AllMatches | Regex.MatchesName<String>takes aPCollection<String>and returns aPCollection<List<String>>representing the value extracted from all the Regex groups of the
 inputPCollectionto the number of times that element occurs in the input. | 
| Regex.Find | Regex.Find<String>takes aPCollection<String>and returns aPCollection<String>representing the value extracted from the Regex groups of the inputPCollectionto the number of times that element occurs in the input. | 
| Regex.FindAll | Regex.Find<String>takes aPCollection<String>and returns aPCollection<List<String>>representing the value extracted from the Regex groups of the inputPCollectionto the number of times that element occurs in the input. | 
| Regex.FindKV | Regex.MatchesKV<KV<String, String>>takes aPCollection<String>and returns aPCollection<KV<String, String>>representing the key and value extracted from the Regex
 groups of the inputPCollectionto the number of times that element occurs in the
 input. | 
| Regex.FindName | Regex.Find<String>takes aPCollection<String>and returns aPCollection<String>representing the value extracted from the Regex groups of the inputPCollectionto the number of times that element occurs in the input. | 
| Regex.FindNameKV | Regex.MatchesKV<KV<String, String>>takes aPCollection<String>and returns aPCollection<KV<String, String>>representing the key and value extracted from the Regex
 groups of the inputPCollectionto the number of times that element occurs in the
 input. | 
| Regex.Matches | Regex.Matches<String>takes aPCollection<String>and returns aPCollection<String>representing the value extracted from the Regex groups of the inputPCollectionto the number of times that element occurs in the input. | 
| Regex.MatchesKV | Regex.MatchesKV<KV<String, String>>takes aPCollection<String>and returns aPCollection<KV<String, String>>representing the key and value extracted from the Regex
 groups of the inputPCollectionto the number of times that element occurs in the
 input. | 
| Regex.MatchesName | Regex.MatchesName<String>takes aPCollection<String>and returns aPCollection<String>representing the value extracted from the Regex groups of the inputPCollectionto the number of times that element occurs in the input. | 
| Regex.MatchesNameKV | Regex.MatchesNameKV<KV<String, String>>takes aPCollection<String>and returns
 aPCollection<KV<String, String>>representing the key and value extracted from the
 Regex groups of the inputPCollectionto the number of times that element occurs in the
 input. | 
| Regex.ReplaceAll | Regex.ReplaceAll<String>takes aPCollection<String>and returns aPCollection<String>with all Strings that matched the Regex being replaced with the
 replacement string. | 
| Regex.ReplaceFirst | Regex.ReplaceFirst<String>takes aPCollection<String>and returns aPCollection<String>with the first Strings that matched the Regex being replaced with the
 replacement string. | 
| Regex.Split | Regex.Split<String>takes aPCollection<String>and returns aPCollection<String>with the input string split into individual items in a list. | 
| Reify | PTransformsfor converting between explicit and implicit form of various Beam
 values. | 
| Requirements | Describes the run-time requirements of a  Contextful, such as access to side inputs. | 
| Reshuffle<K,V> | Deprecated this transform's intended side effects are not portable; it will likely be removed | 
| Reshuffle.ViaRandomKey<T> | Implementation of  Reshuffle.viaRandomKey(). | 
| Sample | PTransforms for taking samples of the elements in aPCollection, or samples of
 the values associated with each key in aPCollectionofKVs. | 
| Sample.FixedSizedSampleFn<T> | CombineFnthat computes a fixed-size sample of a collection of values. | 
| SerializableFunctions | Useful  SerializableFunctionoverrides. | 
| SimpleFunction<InputT,OutputT> | A  SerializableFunctionwhich is not a functional interface. | 
| Sum | PTransforms for computing the sum of the elements in aPCollection, or the sum of
 the values associated with each key in aPCollectionofKVs. | 
| Top | PTransforms for finding the largest (or smallest) set of elements in aPCollection, or the largest (or smallest) set of values associated with each key in aPCollectionofKVs. | 
| Top.Largest<T extends java.lang.Comparable<? super T>> | Deprecated use  Top.Naturalinstead | 
| Top.Natural<T extends java.lang.Comparable<? super T>> | A  SerializableComparatorthat that uses the compared elements' natural
 ordering. | 
| Top.Reversed<T extends java.lang.Comparable<? super T>> | SerializableComparatorthat that uses the reverse of the compared elements'
 natural ordering. | 
| Top.Smallest<T extends java.lang.Comparable<? super T>> | Deprecated use  Top.Reversedinstead | 
| Top.TopCombineFn<T,ComparatorT extends java.util.Comparator<T> & java.io.Serializable> | CombineFnforToptransforms that combines a bunch ofTs into a singlecount-longList<T>, usingcompareFnto choose the largestTs. | 
| ToString | PTransformsfor converting aPCollection<?>,PCollection<KV<?,?>>, orPCollection<Iterable<?>>to aPCollection<String>. | 
| Values<V> | Values<V>takes aPCollectionofKV<K, V>s and returns aPCollection<V>of the values. | 
| View | Transforms for creating  PCollectionViewsfromPCollections(to read them as side inputs). | 
| View.AsIterable<T> | For internal use only; no backwards-compatibility guarantees. | 
| View.AsList<T> | For internal use only; no backwards-compatibility guarantees. | 
| View.AsMap<K,V> | For internal use only; no backwards-compatibility guarantees. | 
| View.AsMultimap<K,V> | For internal use only; no backwards-compatibility guarantees. | 
| View.AsSingleton<T> | For internal use only; no backwards-compatibility guarantees. | 
| View.CreatePCollectionView<ElemT,ViewT> | For internal use only; no backwards-compatibility guarantees. | 
| ViewFn<PrimitiveViewT,ViewT> | For internal use only; no backwards-compatibility guarantees. | 
| Wait | Delays processing of each window in a  PCollectionuntil signaled. | 
| Wait.OnSignal<T> | Implementation of  Wait.on(org.apache.beam.sdk.values.PCollection<?>...). | 
| Watch | Given a "poll function" that produces a potentially growing set of outputs for an input, this
 transform simultaneously continuously watches the growth of output sets of all inputs, until a
 per-input termination condition is reached. | 
| Watch.Growth<InputT,OutputT,KeyT> | |
| Watch.Growth.PollFn<InputT,OutputT> | A function that computes the current set of outputs for the given input, in the form of a
  Watch.Growth.PollResult. | 
| Watch.Growth.PollResult<OutputT> | The result of a single invocation of a  Watch.Growth.PollFn. | 
| WithKeys<K,V> | WithKeys<K, V>takes aPCollection<V>, and either a constant key of typeKor a function fromVtoK, and returns aPCollection<KV<K, V>>, where
 each of the values in the inputPCollectionhas been paired with either the constant key
 or a key computed from the value. | 
| WithTimestamps<T> | A  PTransformfor assigning timestamps to all the elements of aPCollection. | 
| Enum | Description | 
|---|---|
| DoFnTester.CloningBehavior | Deprecated Use  TestPipelinewith theDirectRunner. | 
| Annotation Type | Description | 
|---|---|
| DoFn.BoundedPerElement | Annotation on a splittable  DoFnspecifying that theDoFnperforms a bounded amount of work per input element, so
 applying it to a boundedPCollectionwill produce also a boundedPCollection. | 
| DoFn.Element | Parameter annotation for the input element for a  DoFn.ProcessElementmethod. | 
| DoFn.FieldAccess | Annotation for specifying specific fields that are accessed in a Schema PCollection. | 
| DoFn.FinishBundle | Annotation for the method to use to finish processing a batch of elements. | 
| DoFn.GetInitialRestriction | Annotation for the method that maps an element to an initial restriction for a splittable  DoFn. | 
| DoFn.GetRestrictionCoder | Annotation for the method that returns the coder to use for the restriction of a splittable  DoFn. | 
| DoFn.NewTracker | Annotation for the method that creates a new  RestrictionTrackerfor the restriction of
 a splittableDoFn. | 
| DoFn.OnTimer | Annotation for registering a callback for a timer. | 
| DoFn.OnWindowExpiration | Annotation for the method to use for performing actions on window expiration. | 
| DoFn.ProcessElement | Annotation for the method to use for processing elements. | 
| DoFn.RequiresStableInput | Experimental - no backwards compatibility guarantees. | 
| DoFn.Setup | Annotation for the method to use to prepare an instance for processing bundles of elements. | 
| DoFn.SplitRestriction | Annotation for the method that splits restriction of a splittable  DoFninto multiple parts to
 be processed in parallel. | 
| DoFn.StartBundle | Annotation for the method to use to prepare an instance for processing a batch of elements. | 
| DoFn.StateId | Annotation for declaring and dereferencing state cells. | 
| DoFn.Teardown | Annotation for the method to use to clean up this instance before it is discarded. | 
| DoFn.TimerId | Annotation for declaring and dereferencing timers. | 
| DoFn.Timestamp | Parameter annotation for the input element timestamp for a  DoFn.ProcessElementmethod. | 
| DoFn.UnboundedPerElement | Annotation on a splittable  DoFnspecifying that theDoFnperforms an unbounded amount of work per input element, so
 applying it to a boundedPCollectionwill produce an unboundedPCollection. | 
PTransforms for transforming data in a pipeline.
 A PTransform is an operation that takes an InputT (some subtype of PInput) and produces an OutputT (some subtype of POutput).
 
Common PTransforms include root PTransforms like TextIO.Read
 and Create, processing and conversion operations like
 ParDo, GroupByKey,
 CoGroupByKey, Combine, and Count, and
 outputting PTransforms like TextIO.Write.
 
New PTransforms can be created by composing existing PTransforms. Most PTransforms in this package are composites, and users can also create composite PTransforms for their own application-specific logic.