@DefaultAnnotation(value=edu.umd.cs.findbugs.annotations.NonNull.class)
PCollection and other classes for
representing data in a Pipeline.See: Description
| Interface | Description |
|---|---|
| PCollectionView<T> |
A
PCollectionView<T> is an immutable view of a PCollection
as a value of type T that can be accessed
as a side input to a ParDo transform. |
| PInput |
The interface for things that might be input to a
PTransform. |
| POutput |
The interface for things that might be output from a
PTransform. |
| PValue |
For internal use.
|
| TypeDescriptors.TypeVariableExtractor<InputT,OutputT> |
A helper interface for use with
TypeDescriptors.extractFromTypeParameters(Object, Class,
TypeVariableExtractor). |
| Class | Description |
|---|---|
| BeamRecord |
BeamRecord is an immutable tuple-like type to represent one element in a
PCollection. |
| BeamRecordType |
BeamRecordType describes the fields in BeamRecord, extra checking can be added
by overwriting BeamRecordType.validateValueType(int, Object). |
| KV<K,V> |
An immutable key/value pair.
|
| KV.OrderByKey<K extends java.lang.Comparable<? super K>,V> |
A
Comparator that orders KVs by the natural ordering of their keys. |
| KV.OrderByValue<K,V extends java.lang.Comparable<? super V>> |
A
Comparator that orders KVs by the natural ordering of their values. |
| PBegin | |
| PCollection<T> |
A
PCollection<T> is an immutable collection of values of type
T. |
| PCollectionList<T> |
A
PCollectionList<T> is an immutable list of homogeneously
typed PCollection<T>s. |
| PCollectionTuple |
A
PCollectionTuple is an immutable tuple of
heterogeneously-typed PCollections, "keyed" by
TupleTags. |
| PCollectionViews |
For internal use only; no backwards compatibility guarantees.
|
| PCollectionViews.IterableViewFn<T> |
Implementation which is able to adapt a multimap materialization to a
Iterable<T>. |
| PCollectionViews.ListViewFn<T> |
Implementation which is able to adapt a multimap materialization to a
List<T>. |
| PCollectionViews.MapViewFn<K,V> |
Implementation which is able to adapt a multimap materialization to a
Map<K, V>. |
| PCollectionViews.MultimapViewFn<K,V> |
Implementation which is able to adapt a multimap materialization to a
Map<K, Iterable<V>>. |
| PCollectionViews.SimplePCollectionView<ElemT,PrimitiveViewT,ViewT,W extends BoundedWindow> |
A class for
PCollectionView implementations, with additional type parameters
that are not visible at pipeline assembly time when the view is used as a side input. |
| PCollectionViews.SingletonViewFn<T> |
Implementation which is able to adapt a multimap materialization to a
T. |
| PDone | |
| PValueBase |
For internal use.
|
| ShardedKey<K> |
A key and a shard number.
|
| TaggedPValue |
For internal use only; no backwards-compatibility guarantees.
|
| TimestampedValue<V> |
An immutable pair of a value and a timestamp.
|
| TimestampedValue.TimestampedValueCoder<T> |
A
Coder for TimestampedValue. |
| TupleTag<V> |
A
TupleTag is a typed tag to use as the key of a heterogeneously typed tuple, like PCollectionTuple. |
| TupleTagList |
A
TupleTagList is an immutable list of heterogeneously
typed TupleTags. |
| TypeDescriptor<T> |
A description of a Java type, including actual generic parameters where possible.
|
| TypeDescriptors |
A utility class for creating
TypeDescriptor objects for different types, such as Java
primitive types, containers and KVs of other TypeDescriptor objects, and
extracting type variables of parameterized types (e.g. |
| TypeParameter<T> |
Captures a free type variable that can be used in
TypeDescriptor.where(org.apache.beam.sdk.values.TypeParameter<X>, org.apache.beam.sdk.values.TypeDescriptor<X>). |
| ValueInSingleWindow<T> |
An immutable tuple of value, timestamp, window, and pane.
|
| ValueInSingleWindow.Coder<T> |
A coder for
ValueInSingleWindow. |
| ValueWithRecordId<ValueT> |
For internal use only; no backwards compatibility guarantees.
|
| ValueWithRecordId.StripIdsDoFn<T> | |
| ValueWithRecordId.ValueWithRecordIdCoder<ValueT> | |
| WindowingStrategy<T,W extends BoundedWindow> |
A
WindowingStrategy describes the windowing behavior for a specific collection of values. |
| Enum | Description |
|---|---|
| PCollection.IsBounded |
The enumeration of cases for whether a
PCollection is bounded. |
| WindowingStrategy.AccumulationMode |
The accumulation modes that can be used with windowing.
|
PCollection and other classes for
representing data in a Pipeline.
In particular, see these collection abstractions:
PCollection - an immutable collection of
values of type T and the main representation for data in Beam.PCollectionView - an immutable view of a
PCollection that can be accessed as a
side input of a ParDo
PTransform.PCollectionTuple - a heterogeneous tuple of
PCollections
used in cases where a PTransform takes
or returns multiple
PCollections.PCollectionList - a homogeneous list of
PCollections used, for example,
as input to Flatten.And these classes for individual values play particular roles in Beam:
KV - a key/value pair that is used by
keyed transforms, most notably GroupByKey.
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.