Package org.apache.beam.sdk.values
@DefaultAnnotation(org.checkerframework.checker.nullness.qual.NonNull.class)
package org.apache.beam.sdk.values
Defines
PCollection and other classes for representing data in
a Pipeline.
In particular, see these collection abstractions:
PCollection- an immutable collection of values of typeTand the main representation for data in Beam.PCollectionView- an immutable view of aPCollectionthat can be accessed as a side input of aParDoPTransform.PCollectionTuple- a heterogeneous tuple ofPCollectionsused in cases where aPTransformtakes or returns multiplePCollections.PCollectionList- a homogeneous list ofPCollectionsused, for example, as input toFlatten.
And these classes for individual values play particular roles in Beam:
KV- a key/value pair that is used by keyed transforms, most notablyGroupByKey.TimestampedValue- a timestamp/value pair that is used for windowing and handling out-of-order data in streaming execution.
For further details, see the documentation for each class in this package.
-
ClassDescriptionA wrapper around a
Throwablefor use with coders.FailsafeValueInSingleWindow<T,ErrorT> An immutable tuple of value, timestamp, window, and pane.FailsafeValueInSingleWindow.Coder<T,ErrorT> A coder forFailsafeValueInSingleWindow.KV<K,V> An immutable key/value pair.AComparatorthat ordersKVsby the natural ordering of their keys.KV.OrderByValue<K,V extends Comparable<? super V>> AComparatorthat ordersKVsby the natural ordering of their values.A builder for an output, to set all the fields and extended metadata of a Beam value.PCollection<T>APCollection<T>is an immutable collection of values of typeT.The enumeration of cases for whether aPCollectionis bounded.APCollectionList<T>is an immutable list of homogeneously typedPCollection<T>s.APCollectionRowTupleis an immutable tuple ofPCollection, "keyed" by a string tag.s
APCollectionTupleis an immutable tuple of heterogeneously-typedPCollections, "keyed" byTupleTags.APCollectionView<T>is an immutable view of aPCollectionas a value of typeTthat can be accessed as a side input to aParDotransform.For internal use only; no backwards compatibility guarantees.Implementation which is able to adapt a multimap materialization to an in-memoryList<T>.Implementation which is able to adapt an iterable materialization to an in-memoryList<T>.Implementation which is able to adapt a multimap materialization to an in-memoryMap<K, V>.Implementation which is able to adapt an iterable materialization to an in-memoryMap<K, V>.Implementation which is able to adapt a multimap materialization to an in-memoryMap<K, Iterable<V>>.Implementation which is able to adapt an iterable materialization to an in-memoryMap<K, Iterable<V>>.Implementation which is able to adapt an iterable materialization to aList<T>.Deprecated.Implementation which is able to adapt an iterable materialization to aIterable<T>.Deprecated.Implementation which is able to adapt a multimap materialization to aList<T>.Deprecated.Implementation which is able to adapt a multimap materialization to aMap<K, V>.Deprecated.Implementation which is able to adapt a multimap materialization to aMap<K, Iterable<V>>.PCollectionViews.SimplePCollectionView<ElemT,PrimitiveViewT, ViewT, W extends BoundedWindow> A class forPCollectionViewimplementations, with additional type parameters that are not visible at pipeline assembly time when the view is used as a side input.Deprecated.Implementation which is able to adapt an iterable materialization to aT.PCollectionViews.ValueOrMetadata<T,MetaT> Stores values or metadata about values.A coder forPCollectionViews.ValueOrMetadata.The interface for things that might be input to aPTransform.The interface for things that might be output from aPTransform.For internal use.For internal use.For internal use.Rowis an immutable tuple-like schema to represent one element in aPCollection.Builder forRow.Builder forRowthat bases a row on another row.A Concrete subclass ofRowthat delegates to a set of providedFieldValueGetters.Concrete subclass ofRowthat explicitly stores all fields of the row.ShardedKey<K>Deprecated.UseShardedKeyinstead.For internal use only; no backwards-compatibility guarantees.An immutable pair of a value and a timestamp.ACoderforTimestampedValue.TupleTag<V>ATupleTagis a typed tag to use as the key of a heterogeneously typed tuple, likePCollectionTuple.ATupleTagListis an immutable list of heterogeneously typedTupleTags.A description of a Java type, including actual generic parameters where possible.A utility class for creatingTypeDescriptorobjects for different types, such as Java primitive types, containers andKVsof otherTypeDescriptorobjects, and extracting type variables of parameterized types (e.g.TypeDescriptors.TypeVariableExtractor<InputT,OutputT> A helper interface for use withTypeDescriptors.extractFromTypeParameters(Object, Class, TypeVariableExtractor).Captures a free type variable that can be used inTypeDescriptor.where(org.apache.beam.sdk.values.TypeParameter<X>, org.apache.beam.sdk.values.TypeDescriptor<X>).An immutable tuple of value, timestamp, window, and pane.A coder forValueInSingleWindow.ValueWithRecordId<ValueT>For internal use only; no backwards compatibility guarantees.A value along with Beam's windowing information and all other metadata.Implementations ofWindowedValueand static utility methods.Coder forWindowedValue.A parameterized coder forWindowedValue.AWindowedValueswhich holds exactly single window per value.Deprecated.Use ParamWindowedValueCoder instead, it is a general purpose implementation of the same concept but makes timestamp, windows and pane info configurable.Abstract class forWindowedValuecoder.WindowingStrategy<T,W extends BoundedWindow> AWindowingStrategydescribes the windowing behavior for a specific collection of values.The accumulation modes that can be used with windowing.
PCollectionViews.IterableViewFn2.