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 typeT
and the main representation for data in Beam.PCollectionView
- an immutable view of aPCollection
that can be accessed as a side input of aParDo
PTransform
.PCollectionTuple
- a heterogeneous tuple ofPCollections
used in cases where aPTransform
takes or returns multiplePCollections
.PCollectionList
- a homogeneous list ofPCollections
used, 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
Throwable
for 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.AComparator
that ordersKVs
by the natural ordering of their keys.KV.OrderByValue<K,V extends Comparable<? super V>> AComparator
that ordersKVs
by the natural ordering of their values.PCollection<T>APCollection<T>
is an immutable collection of values of typeT
.The enumeration of cases for whether aPCollection
is bounded.APCollectionList<T>
is an immutable list of homogeneously typedPCollection<T>s
.APCollectionRowTuple
is an immutable tuple ofPCollection
, "keyed" by a string tag.s
APCollectionTuple
is an immutable tuple of heterogeneously-typedPCollections
, "keyed" byTupleTags
.APCollectionView<T>
is an immutable view of aPCollection
as a value of typeT
that can be accessed as a side input to aParDo
transform.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 forPCollectionView
implementations, 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.Row
is an immutable tuple-like schema to represent one element in aPCollection
.Builder forRow
.Builder forRow
that bases a row on another row.A Concrete subclass ofRow
that delegates to a set of providedFieldValueGetter
s.Concrete subclass ofRow
that explicitly stores all fields of the row.ShardedKey<K>A key and a shard number.For internal use only; no backwards-compatibility guarantees.An immutable pair of a value and a timestamp.ACoder
forTimestampedValue
.TupleTag<V>ATupleTag
is a typed tag to use as the key of a heterogeneously typed tuple, likePCollectionTuple
.ATupleTagList
is an immutable list of heterogeneously typedTupleTags
.A description of a Java type, including actual generic parameters where possible.A utility class for creatingTypeDescriptor
objects for different types, such as Java primitive types, containers andKVs
of otherTypeDescriptor
objects, 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 ofWindowedValue
and static utility methods.Coder forWindowedValue
.A parameterized coder forWindowedValue
.AWindowedValues
which 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 forWindowedValue
coder.WindowingStrategy<T,W extends BoundedWindow> AWindowingStrategy
describes the windowing behavior for a specific collection of values.The accumulation modes that can be used with windowing.
PCollectionViews.IterableViewFn2
.