Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W Y Z _ 

A

absolute(String, String...) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
Construct a path from an absolute component path hierarchy.
AbstractGetterTypeSupplier() - Constructor for class org.apache.beam.sdk.schemas.AutoValueSchema.AbstractGetterTypeSupplier
 
accept(T1, T2) - Method in interface org.apache.beam.sdk.function.ThrowingBiConsumer
 
accept(T) - Method in interface org.apache.beam.sdk.function.ThrowingConsumer
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierListContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.FieldSpecifierContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierListContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifyComponentContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.SimpleIdentifierContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.WildcardContext
 
accept(SchemaZipFold.Context, Schema.FieldType, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold
Accepts two components, context.parent() is always ROW, MAP, ARRAY or absent.
accept(SchemaZipFold.Context, Optional<Schema.Field>, Optional<Schema.Field>) - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold
Accepts two fields, context.parent() is always ROW.
accumulate(T, T) - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold
Accumulate two results together.
AccumulatingCombineFn() - Constructor for class org.apache.beam.sdk.transforms.Combine.AccumulatingCombineFn
 
accumulatingFiredPanes() - Method in class org.apache.beam.sdk.transforms.windowing.Window
Returns a new Window PTransform that uses the registered WindowFn and Triggering behavior, and that accumulates elements in a pane after they are triggered.
add(InputT) - Method in interface org.apache.beam.sdk.state.GroupingState
Add a value to the buffer.
add(Iterable<TimestampedValue<T>>) - Static method in class org.apache.beam.sdk.testing.TestStream.ElementEvent
For internal use only: no backwards compatibility guarantees.
add(long) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique
Deprecated.
Adds a value to the heap, returning whether the value is (large enough to be) in the heap.
add(DisplayData.ItemSpec<?>) - Method in interface org.apache.beam.sdk.transforms.display.DisplayData.Builder
Register the given display item.
add(long, long) - Method in class org.apache.beam.sdk.util.BucketingFunction
Add one sample of value (to bucket) at timeMsSinceEpoch.
add(long, long) - Method in class org.apache.beam.sdk.util.MovingFunction
Add value at nowMsSinceEpoch.
addAccum(AccumT) - Method in interface org.apache.beam.sdk.state.CombiningState
Add an accumulator to this state cell.
addArray(Collection<T>) - Method in class org.apache.beam.sdk.values.Row.Builder
 
addArray(Object...) - Method in class org.apache.beam.sdk.values.Row.Builder
 
addArrayField(String, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addAttempted(T, BiFunction<T, T, T>) - Method in class org.apache.beam.sdk.metrics.MetricResult
 
addBooleanField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addByteArrayField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addByteField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addChannel(WritableByteChannel) - Method in class org.apache.beam.sdk.util.ShardingWritableByteChannel
Adds another shard output channel.
addCommitted(T, BiFunction<T, T, T>) - Method in class org.apache.beam.sdk.metrics.MetricResult
 
addComposite(TransformHierarchy.Node) - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
Adds a composite operation to the transform node.
addDateTimeField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addDecimalField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addDoubleField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addElements(T, T...) - Method in class org.apache.beam.sdk.testing.TestStream.Builder
Adds the specified elements to the source with timestamp equal to the current watermark.
addElements(TimestampedValue<T>, TimestampedValue<T>...) - Method in class org.apache.beam.sdk.testing.TestStream.Builder
Adds the specified elements to the source with the provided timestamps.
addExperiment(ExperimentalOptions, String) - Static method in interface org.apache.beam.sdk.options.ExperimentalOptions
Adds experiment to options if not already present.
addField(Schema.Field) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addField(String, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addFields(List<Schema.Field>) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addFields(Schema.Field...) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
AddFields - Class in org.apache.beam.sdk.schemas.transforms
A transform to add new nullable fields to a PCollection's schema.
AddFields() - Constructor for class org.apache.beam.sdk.schemas.transforms.AddFields
 
AddFields.Inner<T> - Class in org.apache.beam.sdk.schemas.transforms
Inner PTransform for AddFields.
addFloatField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addIfAbsent(T) - Method in interface org.apache.beam.sdk.state.SetState
Ensures a value is a member of the set, returning true if it was added and false otherwise.
addIfNotDefault(DisplayData.ItemSpec<T>, T) - Method in interface org.apache.beam.sdk.transforms.display.DisplayData.Builder
Register the given display item if the value is different than the specified default.
addIfNotNull(DisplayData.ItemSpec<?>) - Method in interface org.apache.beam.sdk.transforms.display.DisplayData.Builder
Register the given display item if the value is not null.
addInput(ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique, T) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
Deprecated.
 
addInput(InputT) - Method in interface org.apache.beam.sdk.transforms.Combine.AccumulatingCombineFn.Accumulator
Adds the given input value to this accumulator, modifying this accumulator.
addInput(AccumT, InputT) - Method in class org.apache.beam.sdk.transforms.Combine.AccumulatingCombineFn
 
addInput(double[], Double) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
 
addInput(Combine.Holder<V>, V) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
 
addInput(int[], Integer) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
 
addInput(long[], Long) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
 
addInput(AccumT, InputT) - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
Adds the given input value to the given accumulator, returning the new accumulator value.
addInput(List<V>, V) - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
 
addInput(Object[], DataT) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
 
addInput(Object[], DataT, CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
 
addInput(AccumT, InputT, CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
Adds the given input value to the given accumulator, returning the new accumulator value.
addInput(Top.BoundedHeap<KV<Integer, T>, SerializableComparator<KV<Integer, T>>>, T) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
 
addInt16Field(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addInt32Field(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addInt64Field(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addIterable(Iterable<T>) - Method in class org.apache.beam.sdk.values.Row.Builder
 
addIterableField(String, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addLogicalTypeField(String, Schema.LogicalType<InputT, BaseT>) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addMapField(String, Schema.FieldType, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addNameFilter(MetricNameFilter) - Method in class org.apache.beam.sdk.metrics.MetricsFilter.Builder
addNullableField(String, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addObserver(Observer) - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObservableIterable
Sets the observer, which will observe the iterator returned in the next call to iterator() method.
addOptions(Schema.Options) - Method in class org.apache.beam.sdk.schemas.Schema.Options.Builder
 
addOverrideForClass(Class<?>, SdkHarnessOptions.LogLevel) - Method in class org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides
Overrides the default log level for the passed in class.
addOverrideForName(String, SdkHarnessOptions.LogLevel) - Method in class org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides
Overrides the default log logLevel for the passed in name.
addOverrideForPackage(Package, SdkHarnessOptions.LogLevel) - Method in class org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides
Overrides the default log level for the passed in package.
addRowField(String, Schema) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addStep(String) - Method in class org.apache.beam.sdk.metrics.MetricsFilter.Builder
Add a step filter.
addStringField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
addValue(Object) - Method in class org.apache.beam.sdk.values.Row.Builder
 
addValues(List<Object>) - Method in class org.apache.beam.sdk.values.Row.Builder
 
addValues(Object...) - Method in class org.apache.beam.sdk.values.Row.Builder
 
advance() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
 
advance() - Method in class org.apache.beam.sdk.io.Source.Reader
Advances the reader to the next valid record.
advance() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
Advances the reader to the next valid record.
advance() - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObserver
Advances the observer to the next element.
advanceBy(Duration) - Static method in class org.apache.beam.sdk.testing.TestStream.ProcessingTimeEvent
For internal use only: no backwards compatibility guarantees.
advanceImpl() - Method in class org.apache.beam.sdk.io.FileBasedSource.FileBasedReader
 
advanceImpl() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
Advances to the next record and returns true, or returns false if there is no next record.
advanceProcessingTime(Duration) - Method in class org.apache.beam.sdk.testing.TestStream.Builder
Advance the processing time by the specified amount.
advanceTo(Instant) - Static method in class org.apache.beam.sdk.testing.TestStream.WatermarkEvent
For internal use only: no backwards compatibility guarantees.
advanceWatermarkTo(Instant) - Method in class org.apache.beam.sdk.testing.TestStream.Builder
Advance the watermark of this source to the specified instant.
advanceWatermarkToInfinity() - Method in class org.apache.beam.sdk.testing.TestStream.Builder
Advance the watermark to infinity, completing this TestStream.
AfterAll - Class in org.apache.beam.sdk.transforms.windowing
A composite Trigger that fires when all of its sub-triggers are ready.
afterBundleCommit(Instant, DoFn.BundleFinalizer.Callback) - Method in interface org.apache.beam.sdk.transforms.DoFn.BundleFinalizer
The provided function will be called after the runner successfully commits the output of a successful bundle.
AfterEach - Class in org.apache.beam.sdk.transforms.windowing
A composite Trigger that executes its sub-triggers in order.
AfterFirst - Class in org.apache.beam.sdk.transforms.windowing
A composite Trigger that fires once after at least one of its sub-triggers have fired.
AfterPane - Class in org.apache.beam.sdk.transforms.windowing
A Trigger that fires at some point after a specified number of input elements have arrived.
AfterProcessingTime - Class in org.apache.beam.sdk.transforms.windowing
A Trigger trigger that fires at a specified point in processing time, relative to when input first arrives.
AfterSynchronizedProcessingTime - Class in org.apache.beam.sdk.transforms.windowing
FOR INTERNAL USE ONLY.
afterTimeSinceNewOutput(ReadableDuration) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
Returns a Watch.Growth.TerminationCondition that holds after the given time has elapsed after the last time the Watch.Growth.PollResult for the current input contained a previously unseen output.
afterTimeSinceNewOutput(SerializableFunction<InputT, ReadableDuration>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
Like Watch.Growth.afterTimeSinceNewOutput(ReadableDuration), but the duration is input-dependent.
afterTotalOf(ReadableDuration) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
Returns a Watch.Growth.TerminationCondition that holds after the given time has elapsed after the current input was seen.
afterTotalOf(SerializableFunction<InputT, ReadableDuration>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
Like Watch.Growth.afterTotalOf(ReadableDuration), but the duration is input-dependent.
AfterWatermark - Class in org.apache.beam.sdk.transforms.windowing
AfterWatermark triggers fire based on progress of the system watermark.
AfterWatermark.AfterWatermarkEarlyAndLate - Class in org.apache.beam.sdk.transforms.windowing
 
AfterWatermark.FromEndOfWindow - Class in org.apache.beam.sdk.transforms.windowing
A watermark trigger targeted relative to the end of the window.
aggregate(Combine.CombineFn<InputT, ?, OutputT>) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
Aggregate the grouped data using the specified Combine.CombineFn.
aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
Build up an aggregation function over the input elements.
aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
 
aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
Build up an aggregation function over the input elements.
aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
 
aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
Build up an aggregation function over the input elements.
aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
 
aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
Build up an aggregation function over the input elements.
aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
 
aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
Build up an aggregation function over the input elements.
aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
 
aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
Build up an aggregation function over the input elements.
aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
 
aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
Build up an aggregation function over the input elements.
aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
Build up an aggregation function over the input elements.
aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
 
aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
 
aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
 
aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
 
aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
 
aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
 
aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
 
aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
 
aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
 
aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
 
aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
 
aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
 
aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
 
aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
 
aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
 
aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
 
aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
Build up an aggregation function over the input elements.
aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
Build up an aggregation function over the input elements.
aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
Build up an aggregation function over the input elements.
aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
Build up an aggregation function over the input elements.
aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
Build up an aggregation function over the input elements.
aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
Build up an aggregation function over the input elements.
aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
Build up an aggregation function over the input elements.
aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
Build up an aggregation function over the input elements.
aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
Build up an aggregation function over the input elements.
aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
Build up an aggregation function over the input elements.
aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
Build up an aggregation function over the input elements.
aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
Build up an aggregation function over the input elements.
aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
Build up an aggregation function over the input elements.
aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
Build up an aggregation function over the input elements.
aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
Build up an aggregation function over the input elements.
aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
Build up an aggregation function over the input elements.
aggregateFieldsById(List<Integer>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
 
aggregateFieldsById(List<Integer>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
 
aggregateFieldsById(List<Integer>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
 
aggregateFieldsById(List<Integer>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
 
aggregateFieldsById(List<Integer>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
 
aggregateFieldsById(List<Integer>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
aggregateFieldsById(List<Integer>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
 
align(Duration) - Method in interface org.apache.beam.sdk.state.Timer
Aligns the target timestamp used by Timer.setRelative() to the next boundary of period.
alignedTo(Duration, Instant) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
Aligns timestamps to the smallest multiple of period since the offset greater than the timestamp.
alignedTo(Duration) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
Aligns the time to be the smallest multiple of period greater than the epoch boundary (aka new Instant(0)).
alignTo(Duration, Instant) - Static method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform
For internal use only; no backwards-compatibility guarantees.
alignTo(Duration) - Static method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform
For internal use only; no backwards-compatibility guarantees.
AlignTo() - Constructor for class org.apache.beam.sdk.transforms.windowing.TimestampTransform.AlignTo
 
ALL_CONTEXTS - Static variable in class org.apache.beam.sdk.testing.CoderProperties
All the contexts, for use in test cases.
ALL_KEYS - Static variable in class org.apache.beam.sdk.io.range.ByteKeyRange
The range of all keys, with empty start and end keys.
ALL_SHARDS - Static variable in class org.apache.beam.sdk.util.ShardingWritableByteChannel
Special shard number that causes a write to all shards.
allAsList(Collection<? extends CompletionStage<? extends T>>) - Static method in class org.apache.beam.sdk.util.MoreFutures
Like CompletableFuture.allOf(java.util.concurrent.CompletableFuture<?>...) but returning the result of constituent futures.
allAsListWithExceptions(Collection<? extends CompletionStage<? extends T>>) - Static method in class org.apache.beam.sdk.util.MoreFutures
allLeavesDescriptor(Schema, SerializableFunction<List<String>, String>) - Static method in class org.apache.beam.sdk.schemas.utils.SelectHelpers
 
allMatches(String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.AllMatches PTransform that checks if the entire line matches the Regex.
allMatches(Pattern) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.AllMatches PTransform that checks if the entire line matches the Regex.
AllMatches(Pattern) - Constructor for class org.apache.beam.sdk.transforms.Regex.AllMatches
 
allMetrics() - Method in class org.apache.beam.sdk.metrics.MetricResults
 
allOf(Iterable<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.allOf(Iterable).
allOf(SerializableMatcher<T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.allOf(Matcher[]).
allOf(Watch.Growth.TerminationCondition<InputT, FirstStateT>, Watch.Growth.TerminationCondition<InputT, SecondStateT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
Returns a Watch.Growth.TerminationCondition that holds when both of the given two conditions hold.
allowsDynamicSplitting() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
 
allowsDynamicSplitting() - Method in class org.apache.beam.sdk.io.FileBasedSource.FileBasedReader
 
allowsDynamicSplitting() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
Whether this reader should allow dynamic splitting of the offset ranges.
alwaysFetched() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.StateParameter
 
AlwaysPassMatcher() - Constructor for class org.apache.beam.sdk.testing.TestPipelineOptions.AlwaysPassMatcher
 
AlwaysPassMatcherFactory() - Constructor for class org.apache.beam.sdk.testing.TestPipelineOptions.AlwaysPassMatcherFactory
 
and(PTransformMatcher) - Method in interface org.apache.beam.sdk.runners.PTransformMatcher
 
and(TupleTag<V>, List<V>) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
Returns a new CoGbkResult based on this, with the given tag and given data added to it.
and(TupleTag<V>, PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
Returns a new KeyedPCollectionTuple<K> that is the same as this, appended with the given PCollection.
and(String, PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
A version of KeyedPCollectionTuple.and(String, PCollection) that takes in a string instead of a TupleTag.
and(PCollection.IsBounded) - Method in enum org.apache.beam.sdk.values.PCollection.IsBounded
Returns the composed IsBounded property.
and(PCollection<T>) - Method in class org.apache.beam.sdk.values.PCollectionList
Returns a new PCollectionList that has all the PCollections of this PCollectionList plus the given PCollection appended to the end.
and(Iterable<PCollection<T>>) - Method in class org.apache.beam.sdk.values.PCollectionList
Returns a new PCollectionList that has all the PCollections of this PCollectionList plus the given PCollections appended to the end, in order.
and(TupleTag<T>, PCollection<T>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
Returns a new PCollectionTuple that has each PCollection and TupleTag of this PCollectionTuple plus the given PCollection associated with the given TupleTag.
and(String, PCollection<T>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
A version of PCollectionTuple.and(TupleTag, PCollection) that takes in a String instead of a TupleTag.
and(TupleTag<?>) - Method in class org.apache.beam.sdk.values.TupleTagList
Returns a new TupleTagList that has all the TupleTags of this TupleTagList plus the given TupleTag appended to the end.
and(List<TupleTag<?>>) - Method in class org.apache.beam.sdk.values.TupleTagList
Returns a new TupleTagList that has all the TupleTags of this TupleTagList plus the given TupleTags appended to the end, in order.
any(long) - Static method in class org.apache.beam.sdk.transforms.Sample
Sample#any(long) takes a PCollection<T> and a limit, and produces a new PCollection<T> containing up to limit elements of the input PCollection.
anyCombineFn(int) - Static method in class org.apache.beam.sdk.transforms.Sample
Returns a Combine.CombineFn that computes a fixed-sized potentially non-uniform sample of its inputs.
anyOf(Iterable<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.anyOf(Iterable).
anyOf(SerializableMatcher<T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.anyOf(Matcher[]).
anything() - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.anything().
anyValueCombineFn() - Static method in class org.apache.beam.sdk.transforms.Sample
Returns a Combine.CombineFn that computes a single and potentially non-uniform sample value of its inputs.
ApiSurface - Class in org.apache.beam.sdk.util
Represents the API surface of a package prefix.
applicableTo(PCollection<?>) - Static method in class org.apache.beam.sdk.transforms.GroupByKey
 
ApplicationNameOptions - Interface in org.apache.beam.sdk.options
Options that allow setting the application name.
AppliedCombineFn<K,InputT,AccumT,OutputT> - Class in org.apache.beam.sdk.util
A CombineFnBase.GlobalCombineFn with a fixed accumulator coder.
AppliedPTransform<InputT extends PInput,OutputT extends POutput,TransformT extends PTransform<? super InputT,OutputT>> - Class in org.apache.beam.sdk.runners
For internal use only; no backwards-compatibility guarantees.
apply(InputT) - Method in interface org.apache.beam.sdk.coders.DelegateCoder.CodingFunction
 
apply(T1, T2) - Method in interface org.apache.beam.sdk.function.ThrowingBiFunction
 
apply(T1) - Method in interface org.apache.beam.sdk.function.ThrowingFunction
 
apply(Schema) - Method in interface org.apache.beam.sdk.io.AvroSink.DatumWriterFactory
 
apply(Schema, Schema) - Method in interface org.apache.beam.sdk.io.AvroSource.DatumReaderFactory
 
apply(PTransform<? super PBegin, OutputT>) - Method in class org.apache.beam.sdk.Pipeline
Like Pipeline.apply(String, PTransform) but the transform node in the Pipeline graph will be named according to PTransform.getName().
apply(String, PTransform<? super PBegin, OutputT>) - Method in class org.apache.beam.sdk.Pipeline
Adds a root PTransform, such as Read or Create, to this Pipeline.
apply(Schema, Schema) - Method in class org.apache.beam.sdk.schemas.transforms.Cast.Narrowing
 
apply(Schema, Schema) - Method in interface org.apache.beam.sdk.schemas.transforms.Cast.Validator
 
apply(Schema, Schema) - Method in class org.apache.beam.sdk.schemas.transforms.Cast.Widening
 
apply(Schema, Schema) - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold
 
apply(T) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert.MatcherCheckerFn
 
apply(Statement, Description) - Method in class org.apache.beam.sdk.testing.TestPipeline
 
apply(double, double) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
Applies the binary operation to the two operands, returning the result.
apply(V, V) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
Applies the binary operation to the two operands, returning the result.
apply(int, int) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
Applies the binary operation to the two operands, returning the result.
apply(long, long) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
Applies the binary operation to the two operands, returning the result.
apply(Iterable<? extends InputT>) - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
Applies this CombineFn to a collection of input values to produce a combined output value.
apply(Iterable<? extends InputT>, CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
Applies this CombineFnWithContext to a collection of input values to produce a combined output value.
apply(InputT, Contextful.Fn.Context) - Method in interface org.apache.beam.sdk.transforms.Contextful.Fn
Invokes the function on the given input with the given context.
apply(InputT) - Method in class org.apache.beam.sdk.transforms.InferableFunction
 
apply(PTransform<KeyedPCollectionTuple<K>, OutputT>) - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
Like KeyedPCollectionTuple.apply(String, PTransform) but defaulting to the name provided by the PTransform.
apply(String, PTransform<KeyedPCollectionTuple<K>, OutputT>) - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
Applies the given PTransform to this input KeyedPCollectionTuple and returns its OutputT.
apply(InputT) - Method in interface org.apache.beam.sdk.transforms.ProcessFunction
Returns the result of invoking this function on the given input.
apply(InputT) - Method in interface org.apache.beam.sdk.transforms.SerializableFunction
Returns the result of invoking this function on the given input.
apply(InputT) - Method in class org.apache.beam.sdk.transforms.SimpleFunction
 
apply(PrimitiveViewT) - Method in class org.apache.beam.sdk.transforms.ViewFn
A function to adapt a primitive view type to a desired view type.
apply(WithFailures.ExceptionElement<T>) - Method in class org.apache.beam.sdk.transforms.WithFailures.ExceptionAsMapHandler
 
apply(PTransform<? super PBegin, OutputT>) - Method in class org.apache.beam.sdk.values.PBegin
Like PBegin.apply(String, PTransform) but defaulting to the name of the PTransform.
apply(String, PTransform<? super PBegin, OutputT>) - Method in class org.apache.beam.sdk.values.PBegin
Applies the given PTransform to this PBegin, using name to identify this specific application of the transform.
apply(PTransform<? super PCollection<T>, OutputT>) - Method in class org.apache.beam.sdk.values.PCollection
of the PTransform.
apply(String, PTransform<? super PCollection<T>, OutputT>) - Method in class org.apache.beam.sdk.values.PCollection
Applies the given PTransform to this input PCollection, using name to identify this specific application of the transform.
apply(PTransform<PCollectionList<T>, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionList
Like PCollectionList.apply(String, PTransform) but defaulting to the name of the PTransform.
apply(String, PTransform<PCollectionList<T>, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionList
Applies the given PTransform to this input PCollectionList, using name to identify this specific application of the transform.
apply(PTransform<? super PCollectionTuple, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
Like PCollectionTuple.apply(String, PTransform) but defaulting to the name of the PTransform.
apply(String, PTransform<? super PCollectionTuple, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
Applies the given PTransform to this input PCollectionTuple, using name to identify this specific application of the transform.
apply(Materializations.MultimapView<Void, T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn
Deprecated.
 
apply(Materializations.MultimapView<Void, T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.ListViewFn
Deprecated.
 
apply(Materializations.MultimapView<Void, KV<K, V>>) - Method in class org.apache.beam.sdk.values.PCollectionViews.MapViewFn
Deprecated.
 
apply(Materializations.MultimapView<Void, KV<K, V>>) - Method in class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn
Deprecated.
 
apply(Materializations.MultimapView<Void, T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
Deprecated.
 
applyTransform(InputT, PTransform<? super InputT, OutputT>) - Static method in class org.apache.beam.sdk.Pipeline
For internal use only; no backwards-compatibility guarantees.
applyTransform(String, InputT, PTransform<? super InputT, OutputT>) - Static method in class org.apache.beam.sdk.Pipeline
For internal use only; no backwards-compatibility guarantees.
applyWindowing() - Method in class org.apache.beam.sdk.transforms.PeriodicImpulse
 
approximatePTransformName(Class<?>) - Static method in class org.apache.beam.sdk.util.NameUtils
Returns a name for a PTransform class.
ApproximateQuantiles - Class in org.apache.beam.sdk.transforms
PTransforms for getting an idea of a PCollection's data distribution using approximate N-tiles (e.g.
ApproximateQuantiles.ApproximateQuantilesCombineFn<T,ComparatorT extends java.util.Comparator<T> & java.io.Serializable> - Class in org.apache.beam.sdk.transforms
The ApproximateQuantilesCombineFn combiner gives an idea of the distribution of a collection of values using approximate N-tiles.
approximateSimpleName(Object) - Static method in class org.apache.beam.sdk.util.NameUtils
As NameUtils.approximateSimpleName(Object, String) but returning "Anonymous" when object is an instance of anonymous class.
approximateSimpleName(Object, String) - Static method in class org.apache.beam.sdk.util.NameUtils
Returns a simple name describing a class that is being used as a function (eg., a DoFn or Combine.CombineFn, etc.).
ApproximateUnique - Class in org.apache.beam.sdk.transforms
Deprecated.

Consider using ApproximateCountDistinct in the zetasketch extension module, which makes use of the HllCount implementation.

If ApproximateCountDistinct does not meet your needs then you can directly use HllCount. Direct usage will also give you access to save intermediate aggregation result into a sketch for later processing.

For example, to estimate the number of distinct elements in a PCollection<String>:


 PCollection<String> input = ...;
 PCollection<Long> countDistinct =
     input.apply(HllCount.Init.forStrings().globally()).apply(HllCount.Extract.globally());
 
For more details about using HllCount and the zetasketch extension module, see https://s.apache.org/hll-in-beam#bookmark=id.v6chsij1ixo7.
ApproximateUnique() - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique
Deprecated.
 
ApproximateUnique.ApproximateUniqueCombineFn<T> - Class in org.apache.beam.sdk.transforms
Deprecated.
CombineFn that computes an estimate of the number of distinct values that were combined.
ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique - Class in org.apache.beam.sdk.transforms
Deprecated.
A heap utility class to efficiently track the largest added elements.
ApproximateUnique.Globally<T> - Class in org.apache.beam.sdk.transforms
Deprecated.
PTransform for estimating the number of distinct elements in a PCollection.
ApproximateUnique.PerKey<K,V> - Class in org.apache.beam.sdk.transforms
Deprecated.
PTransform for estimating the number of distinct values associated with each key in a PCollection of KVs.
ApproximateUniqueCombineFn(long, Coder<T>) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
Deprecated.
 
array(Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
Create an array type for the given field type.
array(Schema.FieldType, boolean) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
Deprecated.
Set the nullability on the elementType instead
arrayContaining(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.arrayContaining(Object[]).
arrayContaining(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.arrayContaining(Object[]).
arrayContaining(SerializableMatcher<? super T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.arrayContaining(Matcher[]).
arrayContaining(List<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.arrayContaining(List).
arrayContainingInAnyOrder(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.arrayContainingInAnyOrder(Object[]).
arrayContainingInAnyOrder(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.arrayContainingInAnyOrder(Object[]).
arrayContainingInAnyOrder(SerializableMatcher<? super T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.arrayContainingInAnyOrder(Matcher[]).
arrayContainingInAnyOrder(Collection<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.arrayContainingInAnyOrder(Collection).
arrayQualifier() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
arrayQualifier() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierListContext
 
ArrayQualifierContext(ParserRuleContext, int) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierContext
 
ArrayQualifierListContext(FieldSpecifierNotationParser.QualifierListContext) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierListContext
 
arrayWithSize(int) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.arrayWithSize(int).
arrayWithSize(SerializableMatcher<? super Integer>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.arrayWithSize(Matcher).
as(Class<T>) - Method in interface org.apache.beam.sdk.options.PipelineOptions
Transforms this object into an object of type <T> saving each property that has been manipulated.
as(Class<T>) - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
Creates and returns an object that implements <T>.
as(Class<T>) - Method in class org.apache.beam.sdk.options.PipelineOptionsFactory.Builder
Creates and returns an object that implements <T> using the values configured on this builder during construction.
asIterable() - Static method in class org.apache.beam.sdk.transforms.View
Returns a View.AsIterable transform that takes a PCollection as input and produces a PCollectionView mapping each window to an Iterable of the values in that window.
asList() - Static method in class org.apache.beam.sdk.transforms.View
Returns a View.AsList transform that takes a PCollection and returns a PCollectionView mapping each window to a List containing all of the elements in the window.
asMap() - Method in class org.apache.beam.sdk.transforms.display.DisplayData
 
asMap() - Static method in class org.apache.beam.sdk.transforms.View
Returns a View.AsMap transform that takes a PCollection<KV<K, V>> as input and produces a PCollectionView mapping each window to a Map<K, V>.
asMultimap() - Static method in class org.apache.beam.sdk.transforms.View
Returns a View.AsMultimap transform that takes a PCollection<KV<K, V>> as input and produces a PCollectionView mapping each window to its contents as a Map<K, Iterable<V>> for use as a side input.
assertionError() - Method in class org.apache.beam.sdk.testing.SuccessOrFailure
 
assertSourcesEqualReferenceSource(BoundedSource<T>, List<? extends BoundedSource<T>>, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
Given a reference Source and a list of Sources, assert that the union of the records read from the list of sources is equal to the records read from the reference source.
assertSplitAtFractionBehavior(BoundedSource<T>, int, double, SourceTestUtils.ExpectedSplitOutcome, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
Asserts that the source's reader either fails to splitAtFraction(fraction) after reading numItemsToReadBeforeSplit items, or succeeds in a way that is consistent according to SourceTestUtils.assertSplitAtFractionSucceedsAndConsistent(org.apache.beam.sdk.io.BoundedSource<T>, int, double, org.apache.beam.sdk.options.PipelineOptions).
assertSplitAtFractionExhaustive(BoundedSource<T>, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
Asserts that for each possible start position, BoundedSource.BoundedReader#splitAtFraction at every interesting fraction (halfway between two fractions that differ by at least one item) can be called successfully and the results are consistent if a split succeeds.
assertSplitAtFractionFails(BoundedSource<T>, int, double, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
Asserts that the source's reader fails to splitAtFraction(fraction) after reading numItemsToReadBeforeSplit items.
assertSplitAtFractionSucceedsAndConsistent(BoundedSource<T>, int, double, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
Verifies some consistency properties of BoundedSource.BoundedReader#splitAtFraction on the given source.
assertUnstartedReaderReadsSameAsItsSource(BoundedSource.BoundedReader<T>, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
Assert that a Reader returns a Source that, when read from, produces the same records as the reader.
assign(BoundedWindow, Instant) - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
assignableTo(Schema) - Method in class org.apache.beam.sdk.schemas.Schema
Returns true if this Schema can be assigned to another Schema.
assignableToIgnoreNullable(Schema) - Method in class org.apache.beam.sdk.schemas.Schema
Returns true if this Schema can be assigned to another Schema, ignoring nullable.
AssignContext() - Constructor for class org.apache.beam.sdk.transforms.windowing.WindowFn.AssignContext
 
assignedWindows(WindowFn<T, W>, long) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
assignedWindowsWithValue(WindowFn<T, W>, TimestampedValue<T>) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
assignShardKey(DestinationT, UserT, int) - Method in interface org.apache.beam.sdk.io.ShardingFunction
 
assignsToOneWindow() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
 
assignsToOneWindow() - Method in class org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn
 
assignsToOneWindow() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
 
assignsToOneWindow() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
Returns true if this WindowFn always assigns an element to exactly one window.
assignsToOneWindow() - Method in class org.apache.beam.sdk.util.IdentityWindowFn
 
assignWindow(Instant) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
 
assignWindow(Instant) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
 
assignWindow(Instant) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
 
assignWindow(Instant) - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
 
assignWindow(Instant) - Method in class org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn
Returns the single window to which elements with this timestamp belong.
assignWindows(WindowFn<Object, GlobalWindow>.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
 
assignWindows(WindowFn<T, W>.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn
 
assignWindows(WindowFn<Object, IntervalWindow>.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
 
assignWindows(WindowFn<Object, IntervalWindow>.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
 
assignWindows(Instant) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
 
assignWindows(WindowFn<T, W>.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
Given a timestamp and element, returns the set of windows into which it should be placed.
assignWindows(WindowFn<T, BoundedWindow>.AssignContext) - Method in class org.apache.beam.sdk.util.IdentityWindowFn
 
asSingleton() - Static method in class org.apache.beam.sdk.transforms.View
Returns a View.AsSingleton transform that takes a PCollection with a single value per window as input and produces a PCollectionView that returns the value in the main input window when read as a side input.
asSingletonView() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
Returns a PTransform that produces a PCollectionView whose elements are the result of combining elements per-window in the input PCollection.
atMinimumTimestamp(V) - Static method in class org.apache.beam.sdk.values.TimestampedValue
Returns a new TimestampedValue with the minimum timestamp.
AtomicCoder<T> - Class in org.apache.beam.sdk.coders
A Coder that has no component Coders or other configuration.
AtomicCoder() - Constructor for class org.apache.beam.sdk.coders.AtomicCoder
 
AtomicLongFactory() - Constructor for class org.apache.beam.sdk.options.PipelineOptions.AtomicLongFactory
 
attachValues(List<Object>) - Method in class org.apache.beam.sdk.values.Row.Builder
 
attachValues(Object...) - Method in class org.apache.beam.sdk.values.Row.Builder
 
attempted(MetricKey, T) - Static method in class org.apache.beam.sdk.metrics.MetricResult
 
AutoValueSchema - Class in org.apache.beam.sdk.schemas
A SchemaProvider for AutoValue classes.
AutoValueSchema() - Constructor for class org.apache.beam.sdk.schemas.AutoValueSchema
 
AutoValueSchema.AbstractGetterTypeSupplier - Class in org.apache.beam.sdk.schemas
FieldValueTypeSupplier that's based on AutoValue getters.
AutoValueUtils - Class in org.apache.beam.sdk.schemas.utils
Utilities for managing AutoValue schemas.
AutoValueUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.AutoValueUtils
 
AvroCoder<T> - Class in org.apache.beam.sdk.coders
A Coder using Avro binary format.
AvroCoder(Class<T>, Schema) - Constructor for class org.apache.beam.sdk.coders.AvroCoder
 
AvroCoder.JodaTimestampConversion - Class in org.apache.beam.sdk.coders
Conversion for DateTime.
AvroConvertType(boolean) - Constructor for class org.apache.beam.sdk.schemas.utils.AvroUtils.AvroConvertType
 
AvroGenericCoder - Class in org.apache.beam.sdk.coders
AvroCoder specialisation for GenericRecord.
AvroIO - Class in org.apache.beam.sdk.io
PTransforms for reading and writing Avro files.
AvroIO.Parse<T> - Class in org.apache.beam.sdk.io
AvroIO.ParseAll<T> - Class in org.apache.beam.sdk.io
AvroIO.ParseFiles<T> - Class in org.apache.beam.sdk.io
AvroIO.Read<T> - Class in org.apache.beam.sdk.io
AvroIO.ReadAll<T> - Class in org.apache.beam.sdk.io
Deprecated.
See AvroIO.readAll(Class) for details.
AvroIO.ReadFiles<T> - Class in org.apache.beam.sdk.io
AvroIO.RecordFormatter<ElementT> - Interface in org.apache.beam.sdk.io
Deprecated.
Users can achieve the same by providing this transform in a ParDo before using write in AvroIO AvroIO.write(Class).
AvroIO.Sink<ElementT> - Class in org.apache.beam.sdk.io
AvroIO.TypedWrite<UserT,DestinationT,OutputT> - Class in org.apache.beam.sdk.io
AvroIO.Write<T> - Class in org.apache.beam.sdk.io
This class is used as the default return value of AvroIO.write(java.lang.Class<T>)
AvroPayloadSerializerProvider - Class in org.apache.beam.sdk.schemas.io.payloads
 
AvroPayloadSerializerProvider() - Constructor for class org.apache.beam.sdk.schemas.io.payloads.AvroPayloadSerializerProvider
 
AvroReader(AvroSource<T>) - Constructor for class org.apache.beam.sdk.io.AvroSource.AvroReader
Reads Avro records of type T from the specified source.
AvroRecordSchema - Class in org.apache.beam.sdk.schemas
A SchemaProvider for AVRO generated SpecificRecords and POJOs.
AvroRecordSchema() - Constructor for class org.apache.beam.sdk.schemas.AvroRecordSchema
 
AvroSchemaIOProvider - Class in org.apache.beam.sdk.io
An implementation of SchemaIOProvider for reading and writing Avro files with AvroIO.
AvroSchemaIOProvider() - Constructor for class org.apache.beam.sdk.io.AvroSchemaIOProvider
 
AvroSink<UserT,DestinationT,OutputT> - Class in org.apache.beam.sdk.io
A FileBasedSink for Avro files.
AvroSink.DatumWriterFactory<T> - Interface in org.apache.beam.sdk.io
 
AvroSource<T> - Class in org.apache.beam.sdk.io
Do not use in pipelines directly: most users should use AvroIO.Read.
AvroSource.AvroReader<T> - Class in org.apache.beam.sdk.io
A BlockBasedSource.BlockBasedReader for reading blocks from Avro files.
AvroSource.DatumReaderFactory<T> - Interface in org.apache.beam.sdk.io
 
AvroUtils - Class in org.apache.beam.sdk.schemas.utils
Utils to convert AVRO records to Beam rows.
AvroUtils.AvroConvertType - Class in org.apache.beam.sdk.schemas.utils
 
AvroUtils.AvroConvertValueForGetter - Class in org.apache.beam.sdk.schemas.utils
 
AvroUtils.AvroConvertValueForSetter - Class in org.apache.beam.sdk.schemas.utils
 
AvroUtils.FixedBytesField - Class in org.apache.beam.sdk.schemas.utils
Wrapper for fixed byte fields.

B

BACKLOG_UNKNOWN - Static variable in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
Constant representing an unknown amount of backlog.
backlogBytes() - Static method in class org.apache.beam.sdk.metrics.SourceMetrics
Gauge for source backlog in bytes.
backlogBytesOfSplit(String) - Static method in class org.apache.beam.sdk.metrics.SourceMetrics
Gauge for source split backlog in bytes.
backlogElements() - Static method in class org.apache.beam.sdk.metrics.SourceMetrics
Gauge for source backlog in elements.
backlogElementsOfSplit(String) - Static method in class org.apache.beam.sdk.metrics.SourceMetrics
Gauge for source split backlog in elements.
BackOff - Interface in org.apache.beam.sdk.util
Back-off policy when retrying an operation.
backoff() - Method in class org.apache.beam.sdk.util.FluentBackoff
Instantiates a BackOff that will obey the current configuration.
BackOffUtils - Class in org.apache.beam.sdk.util
Utilities for BackOff.
bag() - Static method in class org.apache.beam.sdk.state.StateSpecs
Create a StateSpec for a BagState, optimized for adding values frequently and occasionally retrieving all the values that have been added.
bag(Coder<T>) - Static method in class org.apache.beam.sdk.state.StateSpecs
Identical to StateSpecs.bag(), but with an element coder explicitly supplied.
BagState<T> - Interface in org.apache.beam.sdk.state
A ReadableState cell containing a bag of values.
BaseArgumentProvider() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
BatchingParams() - Constructor for class org.apache.beam.sdk.transforms.GroupIntoBatches.BatchingParams
 
beforeProcessing(PipelineOptions) - Method in interface org.apache.beam.sdk.harness.JvmInitializer
Implement beforeProcessing to run some custom initialization after basic services such as logging, but before data processing begins.
begin() - Method in class org.apache.beam.sdk.Pipeline
Returns a PBegin owned by this Pipeline.
beginningOnDay(int) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
 
beginningOnDay(int, int) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
 
BigDecimalCoder - Class in org.apache.beam.sdk.coders
A BigDecimalCoder encodes a BigDecimal as an integer scale encoded with VarIntCoder and a BigInteger encoded using BigIntegerCoder.
bigdecimals() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for BigDecimal.
BigEndianIntegerCoder - Class in org.apache.beam.sdk.coders
A BigEndianIntegerCoder encodes Integers in 4 bytes, big-endian.
BigEndianLongCoder - Class in org.apache.beam.sdk.coders
A BigEndianLongCoder encodes Longs in 8 bytes, big-endian.
BigEndianShortCoder - Class in org.apache.beam.sdk.coders
A BigEndianShortCoder encodes Shorts in 2 bytes, big-endian.
BigIntegerCoder - Class in org.apache.beam.sdk.coders
A BigIntegerCoder encodes a BigInteger as a byte array containing the big endian two's-complement representation, encoded via ByteArrayCoder.
bigintegers() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for BigInteger.
BINARY - Static variable in class org.apache.beam.sdk.util.MimeTypes
 
BinaryCombineDoubleFn() - Constructor for class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
 
BinaryCombineFn() - Constructor for class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
 
BinaryCombineIntegerFn() - Constructor for class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
 
BinaryCombineLongFn() - Constructor for class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
 
bind(String, StateBinder) - Method in interface org.apache.beam.sdk.state.StateSpec
For internal use only; no backwards-compatibility guarantees.
bindBag(String, StateSpec<BagState<T>>, Coder<T>) - Method in interface org.apache.beam.sdk.state.StateBinder
 
bindCombining(String, StateSpec<CombiningState<InputT, AccumT, OutputT>>, Coder<AccumT>, Combine.CombineFn<InputT, AccumT, OutputT>) - Method in interface org.apache.beam.sdk.state.StateBinder
 
bindCombiningWithContext(String, StateSpec<CombiningState<InputT, AccumT, OutputT>>, Coder<AccumT>, CombineWithContext.CombineFnWithContext<InputT, AccumT, OutputT>) - Method in interface org.apache.beam.sdk.state.StateBinder
 
bindContext(CombineWithContext.CombineFnWithContext<InputT, AccumT, OutputT>, StateContext<?>) - Static method in class org.apache.beam.sdk.util.CombineFnUtil
Returns the partial application of the CombineWithContext.CombineFnWithContext to a specific context to produce a Combine.CombineFn.
bindMap(String, StateSpec<MapState<KeyT, ValueT>>, Coder<KeyT>, Coder<ValueT>) - Method in interface org.apache.beam.sdk.state.StateBinder
 
bindOrderedList(String, StateSpec<OrderedListState<T>>, Coder<T>) - Method in interface org.apache.beam.sdk.state.StateBinder
 
bindSet(String, StateSpec<SetState<T>>, Coder<T>) - Method in interface org.apache.beam.sdk.state.StateBinder
 
bindValue(String, StateSpec<ValueState<T>>, Coder<T>) - Method in interface org.apache.beam.sdk.state.StateBinder
 
bindWatermark(String, StateSpec<WatermarkHoldState>, TimestampCombiner) - Method in interface org.apache.beam.sdk.state.StateBinder
Bind to a watermark StateSpec.
BitSetCoder - Class in org.apache.beam.sdk.coders
Coder for BitSet.
BitSetCoder - Class in org.apache.beam.sdk.util
Deprecated.
use BitSetCoder instead
Block() - Constructor for class org.apache.beam.sdk.io.BlockBasedSource.Block
 
BlockBasedReader(BlockBasedSource<T>) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
 
BlockBasedSource<T> - Class in org.apache.beam.sdk.io
A BlockBasedSource is a FileBasedSource where a file consists of blocks of records.
BlockBasedSource(String, EmptyMatchTreatment, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
Creates a BlockBasedSource based on a file name or pattern.
BlockBasedSource(String, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
BlockBasedSource(ValueProvider<String>, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
BlockBasedSource(ValueProvider<String>, EmptyMatchTreatment, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
BlockBasedSource(MatchResult.Metadata, long, long, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
Creates a BlockBasedSource for a single file.
BlockBasedSource.Block<T> - Class in org.apache.beam.sdk.io
A Block represents a block of records that can be read.
BlockBasedSource.BlockBasedReader<T> - Class in org.apache.beam.sdk.io
A Reader that reads records from a BlockBasedSource.
BOOLEAN - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
The type of boolean fields.
BooleanCoder - Class in org.apache.beam.sdk.coders
A Coder for Boolean.
BooleanCoder() - Constructor for class org.apache.beam.sdk.coders.BooleanCoder
 
booleans() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for Boolean.
BoundedReader() - Constructor for class org.apache.beam.sdk.io.BoundedSource.BoundedReader
 
BoundedReadFromUnboundedSource<T> - Class in org.apache.beam.sdk.io
PTransform that reads a bounded amount of data from an UnboundedSource, specified as one or both of a maximum number of elements or a maximum period of time to read.
BoundedSource<T> - Class in org.apache.beam.sdk.io
A Source that reads a finite amount of input and, because of that, supports some additional operations.
BoundedSource() - Constructor for class org.apache.beam.sdk.io.BoundedSource
 
BoundedSource.BoundedReader<T> - Class in org.apache.beam.sdk.io
A Reader that reads a bounded amount of input and supports some additional operations, such as progress estimation and dynamic work rebalancing.
boundedWindow(TypeDescriptor<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
BoundedWindow - Class in org.apache.beam.sdk.transforms.windowing
A BoundedWindow represents window information assigned to data elements.
BoundedWindow() - Constructor for class org.apache.beam.sdk.transforms.windowing.BoundedWindow
 
boxIfPrimitive(TypeDescriptor) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
 
BucketingFunction - Class in org.apache.beam.sdk.util
Keep track of the minimum/maximum/sum of a set of timestamped long values.
BucketingFunction(long, int, int, Combine.BinaryCombineLongFn) - Constructor for class org.apache.beam.sdk.util.BucketingFunction
 
BufferedElementCountingOutputStream - Class in org.apache.beam.sdk.util
Provides an efficient encoding for Iterables containing small values by buffering up to bufferSize bytes of data before prefixing the count.
BufferedElementCountingOutputStream(OutputStream) - Constructor for class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
Creates an output stream which encodes the number of elements output to it in a streaming manner.
BufferedElementCountingOutputStream(OutputStream, long) - Constructor for class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
 
build() - Method in class org.apache.beam.sdk.io.fs.CreateOptions.StandardCreateOptions.Builder
 
build() - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
 
build() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
 
build() - Method in class org.apache.beam.sdk.metrics.MetricsFilter.Builder
 
build() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Builder
 
build() - Method in class org.apache.beam.sdk.schemas.io.Failure.Builder
 
build() - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
build() - Method in class org.apache.beam.sdk.schemas.Schema.Field.Builder
 
build() - Method in class org.apache.beam.sdk.schemas.Schema.Options.Builder
 
build() - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError.Builder
 
build() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter.Builder
 
build() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SideInputParameter.Builder
 
build() - Method in class org.apache.beam.sdk.util.InstanceBuilder
Creates the instance by calling the factory method with the given arguments.
build() - Method in class org.apache.beam.sdk.values.Row.Builder
 
build() - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
 
Builder() - Constructor for class org.apache.beam.sdk.io.fs.CreateOptions.Builder
 
builder() - Static method in class org.apache.beam.sdk.io.fs.CreateOptions.StandardCreateOptions
Builder() - Constructor for class org.apache.beam.sdk.io.fs.CreateOptions.StandardCreateOptions.Builder
 
builder() - Static method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata
 
Builder() - Constructor for class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
 
builder() - Static method in class org.apache.beam.sdk.io.TextRowCountEstimator
 
Builder() - Constructor for class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
 
builder() - Static method in class org.apache.beam.sdk.metrics.MetricsFilter
 
Builder() - Constructor for class org.apache.beam.sdk.metrics.MetricsFilter.Builder
 
builder() - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
 
Builder() - Constructor for class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Builder
 
Builder() - Constructor for class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
 
Builder() - Constructor for class org.apache.beam.sdk.schemas.io.Failure.Builder
 
builder() - Static method in class org.apache.beam.sdk.schemas.Schema
 
Builder() - Constructor for class org.apache.beam.sdk.schemas.Schema.Builder
 
Builder() - Constructor for class org.apache.beam.sdk.schemas.Schema.Field.Builder
 
builder() - Static method in class org.apache.beam.sdk.schemas.Schema.Options
 
Builder() - Constructor for class org.apache.beam.sdk.transforms.DoFnSchemaInformation.Builder
 
Builder() - Constructor for class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.Builder
 
Builder() - Constructor for class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError.Builder
 
Builder() - Constructor for class org.apache.beam.sdk.transforms.JsonToRow.ParseResult.Builder
 
Builder() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter.Builder
 
Builder() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SideInputParameter.Builder
 
buildExternal(ConfigT) - Method in interface org.apache.beam.sdk.transforms.ExternalTransformBuilder
Builds the transform after it has been configured.
buildReader() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIO
Returns a schema aware reader.
buildTemporaryFilename(ResourceId, String) - Static method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
Constructs a temporary file resource given the temporary directory and a filename.
buildWriter() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIO
Returns a schema aware writer.
bundleFinalizer() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provide a DoFn.BundleFinalizer for being able to register a callback after the bundle has been successfully persisted by the runner.
bundleFinalizer() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
bundleFinalizer() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
bundleFinalizer() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
BundleMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.BundleMethod
 
by(SerializableFunction<UserT, DestinationT>) - Method in class org.apache.beam.sdk.io.FileIO.Write
Specifies how to partition elements into groups ("destinations").
by(Contextful<Contextful.Fn<UserT, DestinationT>>) - Method in class org.apache.beam.sdk.io.FileIO.Write
By() - Constructor for class org.apache.beam.sdk.schemas.transforms.CoGroup.By
 
by(PredicateT) - Static method in class org.apache.beam.sdk.transforms.Filter
Returns a PTransform that takes an input PCollection<T> and returns a PCollection<T> with elements that satisfy the given predicate.
by(PredicateT) - Static method in class org.apache.beam.sdk.transforms.Filter
Binary compatibility adapter for Filter.by(ProcessFunction).
byFieldAccessDescriptor(FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
Returns a transform that groups all elements in the input PCollection keyed by the fields specified.
byFieldIds(Integer...) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
Returns a transform that groups all elements in the input PCollection keyed by the list of fields specified.
byFieldIds(Iterable<Integer>) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
byFieldNames(String...) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
Returns a transform that groups all elements in the input PCollection keyed by the list of fields specified.
byFieldNames(Iterable<String>) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
ByFields() - Constructor for class org.apache.beam.sdk.schemas.transforms.Group.ByFields
 
BYTE - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
The type of byte fields.
ByteArrayCoder - Class in org.apache.beam.sdk.coders
A Coder for byte[].
byteArrayToJsonString(byte[]) - Static method in class org.apache.beam.sdk.util.StringUtils
Converts the given array of bytes into a legal JSON string.
ByteBuddyUtils - Class in org.apache.beam.sdk.schemas.utils
 
ByteBuddyUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils
 
ByteBuddyUtils.ConvertType - Class in org.apache.beam.sdk.schemas.utils
Give a Java type, returns the Java type expected for use with Row.
ByteBuddyUtils.ConvertValueForGetter - Class in org.apache.beam.sdk.schemas.utils
Takes a StackManipulation that returns a value.
ByteBuddyUtils.ConvertValueForSetter - Class in org.apache.beam.sdk.schemas.utils
Row is going to call the setter with its internal Java type, however the user object being set might have a different type internally.
ByteBuddyUtils.DefaultTypeConversionsFactory - Class in org.apache.beam.sdk.schemas.utils
 
ByteBuddyUtils.InjectPackageStrategy - Class in org.apache.beam.sdk.schemas.utils
A naming strategy for ByteBuddy classes.
ByteBuddyUtils.TransformingMap<K1,V1,K2,V2> - Class in org.apache.beam.sdk.schemas.utils
 
ByteBuddyUtils.TypeConversion<T> - Class in org.apache.beam.sdk.schemas.utils
 
ByteBuddyUtils.TypeConversionsFactory - Interface in org.apache.beam.sdk.schemas.utils
 
ByteCoder - Class in org.apache.beam.sdk.coders
A ByteCoder encodes Byte values in 1 byte using Java serialization.
ByteKey - Class in org.apache.beam.sdk.io.range
A class representing a key consisting of an array of bytes.
ByteKeyRange - Class in org.apache.beam.sdk.io.range
A class representing a range of ByteKeys.
ByteKeyRangeTracker - Class in org.apache.beam.sdk.io.range
ByteKeyRangeTracker - Class in org.apache.beam.sdk.transforms.splittabledofn
A RestrictionTracker for claiming ByteKeys in a ByteKeyRange in a monotonically increasing fashion.
BYTES - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
The type of bytes fields.
bytes() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for Byte.
bytesRead() - Static method in class org.apache.beam.sdk.metrics.SourceMetrics
Counter of bytes read by a source.
bytesReadBySplit(String) - Static method in class org.apache.beam.sdk.metrics.SourceMetrics
Counter of bytes read by a source split.
bytesToRowFn(SchemaProvider, TypeDescriptor<T>, ProcessFunction<byte[], ? extends T>) - Static method in class org.apache.beam.sdk.schemas.RowMessages
 
bytesToRowFn(SchemaProvider, TypeDescriptor<T>, Coder<? extends T>) - Static method in class org.apache.beam.sdk.schemas.RowMessages
 
bytesWritten() - Static method in class org.apache.beam.sdk.metrics.SinkMetrics
Counter of bytes written to a sink.

C

CACHED_CREATORS - Static variable in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
 
CACHED_CREATORS - Static variable in class org.apache.beam.sdk.schemas.utils.POJOUtils
 
CalendarWindows - Class in org.apache.beam.sdk.transforms.windowing
A collection of WindowFns that windows values into calendar-based windows such as spans of days, months, or years.
CalendarWindows() - Constructor for class org.apache.beam.sdk.transforms.windowing.CalendarWindows
 
CalendarWindows.DaysWindows - Class in org.apache.beam.sdk.transforms.windowing
A WindowFn that windows elements into periods measured by days.
CalendarWindows.MonthsWindows - Class in org.apache.beam.sdk.transforms.windowing
A WindowFn that windows elements into periods measured by months.
CalendarWindows.YearsWindows - Class in org.apache.beam.sdk.transforms.windowing
A WindowFn that windows elements into periods measured by years.
cancel() - Method in interface org.apache.beam.sdk.PipelineResult
Cancels the pipeline execution.
CannotProvideCoderException - Exception in org.apache.beam.sdk.coders
The exception thrown when a CoderRegistry or CoderProvider cannot provide a Coder that has been requested.
CannotProvideCoderException(String) - Constructor for exception org.apache.beam.sdk.coders.CannotProvideCoderException
 
CannotProvideCoderException(String, CannotProvideCoderException.ReasonCode) - Constructor for exception org.apache.beam.sdk.coders.CannotProvideCoderException
 
CannotProvideCoderException(String, Throwable) - Constructor for exception org.apache.beam.sdk.coders.CannotProvideCoderException
 
CannotProvideCoderException(String, Throwable, CannotProvideCoderException.ReasonCode) - Constructor for exception org.apache.beam.sdk.coders.CannotProvideCoderException
 
CannotProvideCoderException(Throwable) - Constructor for exception org.apache.beam.sdk.coders.CannotProvideCoderException
 
CannotProvideCoderException(Throwable, CannotProvideCoderException.ReasonCode) - Constructor for exception org.apache.beam.sdk.coders.CannotProvideCoderException
 
CannotProvideCoderException.ReasonCode - Enum in org.apache.beam.sdk.coders
Indicates the reason that Coder inference failed.
canStopPolling(Instant, StateT) - Method in interface org.apache.beam.sdk.transforms.Watch.Growth.TerminationCondition
Called by the Watch transform to determine whether the given termination state signals that Watch should stop calling Watch.Growth.PollFn for the current input, regardless of whether the last Watch.Growth.PollResult was complete or incomplete.
Cast<T> - Class in org.apache.beam.sdk.schemas.transforms
Set of utilities for casting rows between schemas.
Cast() - Constructor for class org.apache.beam.sdk.schemas.transforms.Cast
 
Cast.CompatibilityError - Class in org.apache.beam.sdk.schemas.transforms
Describes compatibility errors during casting.
Cast.Narrowing - Class in org.apache.beam.sdk.schemas.transforms
Narrowing changes type without guarantee to preserve data.
Cast.Validator - Interface in org.apache.beam.sdk.schemas.transforms
Interface for statically validating casts.
Cast.Widening - Class in org.apache.beam.sdk.schemas.transforms
Widening changes to type that can represent any possible value of the original type.
castNumber(Number, Schema.TypeName, Schema.TypeName) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
 
castRow(Row, Schema, Schema) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
 
castValue(Object, Schema.FieldType, Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
 
channelNames - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
characters() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for Character.
checkArgumentNotNull(T) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, Object) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, Object...) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, char) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, int) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, long) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, Object) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, char, char) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, char, int) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, char, long) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, char, Object) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, int, char) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, int, int) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, int, long) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, int, Object) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, long, char) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, long, int) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, long, long) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, long, Object) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, Object, char) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, Object, int) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, Object, long) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, Object, Object) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, Object, Object, Object) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkArgumentNotNull(T, String, Object, Object, Object, Object) - Static method in class org.apache.beam.sdk.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkDone() - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.OutputRangeTracker
 
checkDone() - Method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
 
checkDone() - Method in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
 
checkDone() - Method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker
Checks whether the restriction has been fully processed.
checksum() - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata
An optional checksum to identify the contents of a file.
classesInPackage(String) - Static method in class org.apache.beam.sdk.util.ApiSurface
A factory method to create a Class matcher for classes residing in a given package.
ClassLoaderFileSystem - Class in org.apache.beam.sdk.io
A read-only FileSystem implementation looking up resources using a ClassLoader.
ClassLoaderFileSystem.ClassLoaderFileSystemRegistrar - Class in org.apache.beam.sdk.io
AutoService registrar for the ClassLoaderFileSystem.
ClassLoaderFileSystem.ClassLoaderResourceId - Class in org.apache.beam.sdk.io
 
ClassLoaderFileSystemRegistrar() - Constructor for class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderFileSystemRegistrar
 
ClassWithSchema() - Constructor for class org.apache.beam.sdk.schemas.utils.ReflectUtils.ClassWithSchema
 
cleanup() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
 
clear() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
clear() - Method in interface org.apache.beam.sdk.state.State
Clear out the state location.
clear() - Method in class org.apache.beam.sdk.util.HistogramData
 
clearOutputElements() - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
clearOutputElements(TupleTag<T>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
clearRange(Instant, Instant) - Method in interface org.apache.beam.sdk.state.OrderedListState
Clear a timestamp-limited subrange of the list.
clone(Coder<T>, T) - Static method in class org.apache.beam.sdk.util.CoderUtils
Clones the given value by encoding and then decoding it with the specified Coder.
clone(T) - Static method in class org.apache.beam.sdk.util.SerializableUtils
 
clonesOf(OutT) - Static method in class org.apache.beam.sdk.transforms.SerializableFunctions
 
close() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
Closes the channel and returns the bundle result.
close() - Method in class org.apache.beam.sdk.io.FileBasedSource.FileBasedReader
Closes any ReadableByteChannel created for the current reader.
close() - Method in class org.apache.beam.sdk.io.Source.Reader
Closes the reader.
close() - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
close() - Method in class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
 
close() - Method in class org.apache.beam.sdk.util.ExposedByteArrayInputStream
 
close() - Method in class org.apache.beam.sdk.util.ShardingWritableByteChannel
 
close() - Method in class org.apache.beam.sdk.util.UnownedInputStream
 
close() - Method in class org.apache.beam.sdk.util.UnownedOutputStream
 
CloseableThrowingConsumer<ExceptionT extends java.lang.Exception,T> - Interface in org.apache.beam.sdk.function
A ThrowingConsumer that can be closed.
closeTo(double, double) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.closeTo(double,double).
Coder<T> - Class in org.apache.beam.sdk.coders
A Coder<T> defines how to encode and decode values of type T into byte streams.
Coder() - Constructor for class org.apache.beam.sdk.coders.Coder
 
Coder() - Constructor for class org.apache.beam.sdk.io.range.OffsetRange.Coder
 
Coder.Context - Class in org.apache.beam.sdk.coders
Deprecated.
To implement a coder, do not use any Coder.Context. Just implement only those abstract methods which do not accept a Coder.Context and leave the default implementations for methods accepting a Coder.Context.
Coder.NonDeterministicException - Exception in org.apache.beam.sdk.coders
Exception thrown by Coder.verifyDeterministic() if the encoding is not deterministic, including details of why the encoding is not deterministic.
coderConsistentWithEquals(Coder<T>, T, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<T> and values of type T, the values are equal if and only if the encoded bytes are equal.
coderConsistentWithEqualsInContext(Coder<T>, Coder.Context, T, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<T>, Coder.Context, and values of type T, the values are equal if and only if the encoded bytes are equal, in any Coder.Context.
coderDecodeEncodeContentsEqual(Coder<CollectionT>, CollectionT) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<Collection<T>>, and value of type Collection<T>, encoding followed by decoding yields an equal value of type Collection<T>, in any Coder.Context.
coderDecodeEncodeContentsEqualInContext(Coder<CollectionT>, Coder.Context, CollectionT) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<Collection<T>>, and value of type Collection<T>, encoding followed by decoding yields an equal value of type Collection<T>, in the given Coder.Context.
coderDecodeEncodeContentsInSameOrder(Coder<IterableT>, IterableT) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<Collection<T>>, and value of type Collection<T>, encoding followed by decoding yields an equal value of type Collection<T>, in any Coder.Context.
coderDecodeEncodeContentsInSameOrderInContext(Coder<IterableT>, Coder.Context, IterableT) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<Iterable<T>>, and value of type Iterable<T>, encoding followed by decoding yields an equal value of type Collection<T>, in the given Coder.Context.
coderDecodeEncodeEqual(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<T>, and value of type T, encoding followed by decoding yields an equal value of type T, in any Coder.Context.
coderDecodeEncodeEqualInContext(Coder<T>, Coder.Context, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<T>, Coder.Context, and value of type T, encoding followed by decoding yields an equal value of type T.
coderDecodeEncodeInContext(Coder<T>, Coder.Context, T, Matcher<T>) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<T>, Coder.Context, and value of type T, encoding followed by decoding yields a value of type T and tests that the matcher succeeds on the values.
coderDecodesBase64(Coder<T>, String, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
 
coderDecodesBase64(Coder<T>, List<String>, List<T>) - Static method in class org.apache.beam.sdk.testing.CoderProperties
 
coderDecodesBase64ContentsEqual(Coder<IterableT>, String, IterableT) - Static method in class org.apache.beam.sdk.testing.CoderProperties
 
coderDecodesBase64ContentsEqual(Coder<IterableT>, List<String>, List<IterableT>) - Static method in class org.apache.beam.sdk.testing.CoderProperties
 
coderDeterministic(Coder<T>, T, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<T>, and values of type T, if the values are equal then the encoded bytes are equal, in any Coder.Context.
coderDeterministicInContext(Coder<T>, Coder.Context, T, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<T>, Coder.Context, and values of type T, if the values are equal then the encoded bytes are equal.
coderEncodesBase64(Coder<T>, T, String) - Static method in class org.apache.beam.sdk.testing.CoderProperties
 
coderEncodesBase64(Coder<T>, List<T>, List<String>) - Static method in class org.apache.beam.sdk.testing.CoderProperties
 
CoderException - Exception in org.apache.beam.sdk.coders
An Exception thrown if there is a problem encoding or decoding a value.
CoderException(String) - Constructor for exception org.apache.beam.sdk.coders.CoderException
 
CoderException(String, Throwable) - Constructor for exception org.apache.beam.sdk.coders.CoderException
 
CoderException(Throwable) - Constructor for exception org.apache.beam.sdk.coders.CoderException
 
coderFor(TypeDescriptor<T>, List<? extends Coder<?>>) - Method in class org.apache.beam.sdk.coders.CoderProvider
Returns a Coder<T> to use for values of a particular type, given the Coders for each of the type's generic parameter types.
coderForFieldType(Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.SchemaCoder
 
CoderProperties - Class in org.apache.beam.sdk.testing
Properties for use in Coder tests.
CoderProperties() - Constructor for class org.apache.beam.sdk.testing.CoderProperties
 
CoderProperties.TestElementByteSizeObserver - Class in org.apache.beam.sdk.testing
An ElementByteSizeObserver that records the observed element sizes for testing purposes.
CoderProvider - Class in org.apache.beam.sdk.coders
A CoderProvider provides Coders.
CoderProvider() - Constructor for class org.apache.beam.sdk.coders.CoderProvider
 
CoderProviderRegistrar - Interface in org.apache.beam.sdk.coders
Coder creators have the ability to automatically have their coders registered with this SDK by creating a ServiceLoader entry and a concrete implementation of this interface.
CoderProviders - Class in org.apache.beam.sdk.coders
Static utility methods for creating and working with CoderProviders.
CoderRegistry - Class in org.apache.beam.sdk.coders
A CoderRegistry allows creating a Coder for a given Java class or type descriptor.
coderSerializable(Coder<T>) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that the given Coder<T> can be correctly serialized and deserialized.
coderT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetRestrictionCoderMethod
Type of the returned Coder.
coderT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetWatermarkEstimatorStateCoderMethod
Type of the returned Coder.
CoderUtils - Class in org.apache.beam.sdk.util
Utilities for working with Coders.
CoGbkResult - Class in org.apache.beam.sdk.transforms.join
A row result of a CoGroupByKey.
CoGbkResult(CoGbkResultSchema, Iterable<RawUnionValue>) - Constructor for class org.apache.beam.sdk.transforms.join.CoGbkResult
A row in the PCollection resulting from a CoGroupByKey transform.
CoGbkResult(CoGbkResultSchema, Iterable<RawUnionValue>, int) - Constructor for class org.apache.beam.sdk.transforms.join.CoGbkResult
 
CoGbkResult.CoGbkResultCoder - Class in org.apache.beam.sdk.transforms.join
CoGbkResultSchema - Class in org.apache.beam.sdk.transforms.join
A schema for the results of a CoGroupByKey.
CoGbkResultSchema(TupleTagList) - Constructor for class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
Builds a schema from a tuple of TupleTag<?>s.
CoGroup - Class in org.apache.beam.sdk.schemas.transforms
A transform that performs equijoins across multiple schema PCollections.
CoGroup() - Constructor for class org.apache.beam.sdk.schemas.transforms.CoGroup
 
CoGroup.By - Class in org.apache.beam.sdk.schemas.transforms
Defines the set of fields to extract for the join key, as well as other per-input join options.
CoGroup.ExpandCrossProduct - Class in org.apache.beam.sdk.schemas.transforms
A PTransform that calculates the cross-product join.
CoGroup.Impl - Class in org.apache.beam.sdk.schemas.transforms
The implementing PTransform.
CoGroup.Result - Class in org.apache.beam.sdk.schemas.transforms
 
CoGroupByKey<K> - Class in org.apache.beam.sdk.transforms.join
A PTransform that performs a CoGroupByKey on a tuple of tables.
COLLECTION_TYPES - Static variable in enum org.apache.beam.sdk.schemas.Schema.TypeName
 
CollectionCoder<T> - Class in org.apache.beam.sdk.coders
A CollectionCoder encodes Collections in the format of IterableLikeCoder.
CollectionCoder(Coder<T>) - Constructor for class org.apache.beam.sdk.coders.CollectionCoder
 
Combine - Class in org.apache.beam.sdk.transforms
PTransforms for combining PCollection elements globally and per-key.
combine(Iterable<? extends Instant>) - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
Combines the given times, which must be from the same window and must have been passed through TimestampCombiner.merge(org.apache.beam.sdk.transforms.windowing.BoundedWindow, java.lang.Iterable<? extends org.joda.time.Instant>).
combine(Instant...) - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
Combine.AccumulatingCombineFn<InputT,AccumT extends Combine.AccumulatingCombineFn.Accumulator<InputT,AccumT,OutputT>,OutputT> - Class in org.apache.beam.sdk.transforms
A CombineFn that uses a subclass of Combine.AccumulatingCombineFn.Accumulator as its accumulator type.
Combine.AccumulatingCombineFn.Accumulator<InputT,AccumT,OutputT> - Interface in org.apache.beam.sdk.transforms
The type of mutable accumulator values used by this AccumulatingCombineFn.
Combine.BinaryCombineDoubleFn - Class in org.apache.beam.sdk.transforms
An abstract subclass of Combine.CombineFn for implementing combiners that are more easily and efficiently expressed as binary operations on doubles.
Combine.BinaryCombineFn<V> - Class in org.apache.beam.sdk.transforms
An abstract subclass of Combine.CombineFn for implementing combiners that are more easily expressed as binary operations.
Combine.BinaryCombineIntegerFn - Class in org.apache.beam.sdk.transforms
An abstract subclass of Combine.CombineFn for implementing combiners that are more easily and efficiently expressed as binary operations on ints
Combine.BinaryCombineLongFn - Class in org.apache.beam.sdk.transforms
An abstract subclass of Combine.CombineFn for implementing combiners that are more easily and efficiently expressed as binary operations on longs.
Combine.CombineFn<InputT,AccumT,OutputT> - Class in org.apache.beam.sdk.transforms
A CombineFn<InputT, AccumT, OutputT> specifies how to combine a collection of input values of type InputT into a single output value of type OutputT.
Combine.Globally<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
Combine.Globally<InputT, OutputT> takes a PCollection<InputT> and returns a PCollection<OutputT> whose elements are the result of combining all the elements in each window of the input PCollection, using a specified CombineFn<InputT, AccumT, OutputT>.
Combine.GloballyAsSingletonView<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
Combine.GloballyAsSingletonView<InputT, OutputT> takes a PCollection<InputT> and returns a PCollectionView<OutputT> whose elements are the result of combining all the elements in each window of the input PCollection, using a specified CombineFn<InputT, AccumT, OutputT>.
Combine.GroupedValues<K,InputT,OutputT> - Class in org.apache.beam.sdk.transforms
GroupedValues<K, InputT, OutputT> takes a PCollection<KV<K, Iterable<InputT>>>, such as the result of GroupByKey, applies a specified CombineFn<InputT, AccumT, OutputT> to each of the input KV<K, Iterable<InputT>> elements to produce a combined output KV<K, OutputT> element, and returns a PCollection<KV<K, OutputT>> containing all the combined output elements.
Combine.Holder<V> - Class in org.apache.beam.sdk.transforms
Holds a single value value of type V which may or may not be present.
Combine.IterableCombineFn<V> - Class in org.apache.beam.sdk.transforms
Converts a SerializableFunction from Iterable<V>s to Vs into a simple Combine.CombineFn over Vs.
Combine.PerKey<K,InputT,OutputT> - Class in org.apache.beam.sdk.transforms
PerKey<K, InputT, OutputT> takes a PCollection<KV<K, InputT>>, groups it by key, applies a combining function to the InputT values associated with each key to produce a combined OutputT value, and returns a PCollection<KV<K, OutputT>> representing a map from each distinct key of the input PCollection to the corresponding combined value.
Combine.PerKeyWithHotKeyFanout<K,InputT,OutputT> - Class in org.apache.beam.sdk.transforms
Like Combine.PerKey, but sharding the combining of hot keys.
Combine.SimpleCombineFn<V> - Class in org.apache.beam.sdk.transforms
Deprecated.
CombineContextFactory - Class in org.apache.beam.sdk.util
Factory that produces Combine.Context based on different inputs.
CombineContextFactory() - Constructor for class org.apache.beam.sdk.util.CombineContextFactory
 
CombineFieldsByFields() - Constructor for class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
 
CombineFn() - Constructor for class org.apache.beam.sdk.transforms.Combine.CombineFn
 
combineFn() - Static method in class org.apache.beam.sdk.transforms.Count
Returns a Combine.CombineFn that counts the number of its inputs.
combineFn() - Static method in class org.apache.beam.sdk.transforms.Latest
Returns a Combine.CombineFn that selects the latest element among its inputs.
combineFn(int) - Static method in class org.apache.beam.sdk.transforms.Sample
Returns a Combine.CombineFn that computes a fixed-sized uniform sample of its inputs.
CombineFnBase - Class in org.apache.beam.sdk.transforms
For internal use only; no backwards-compatibility guarantees.
CombineFnBase() - Constructor for class org.apache.beam.sdk.transforms.CombineFnBase
 
CombineFnBase.GlobalCombineFn<InputT,AccumT,OutputT> - Interface in org.apache.beam.sdk.transforms
For internal use only; no backwards-compatibility guarantees.
CombineFns - Class in org.apache.beam.sdk.transforms
Static utility methods that create combine function instances.
CombineFns() - Constructor for class org.apache.beam.sdk.transforms.CombineFns
 
CombineFns.CoCombineResult - Class in org.apache.beam.sdk.transforms
A tuple of outputs produced by a composed combine functions.
CombineFns.ComposeCombineFnBuilder - Class in org.apache.beam.sdk.transforms
A builder class to construct a composed CombineFnBase.GlobalCombineFn.
CombineFns.ComposedCombineFn<DataT> - Class in org.apache.beam.sdk.transforms
A composed Combine.CombineFn that applies multiple CombineFns.
CombineFns.ComposedCombineFnWithContext<DataT> - Class in org.apache.beam.sdk.transforms
CombineFnTester - Class in org.apache.beam.sdk.testing
Utilities for testing CombineFns.
CombineFnTester() - Constructor for class org.apache.beam.sdk.testing.CombineFnTester
 
CombineFnUtil - Class in org.apache.beam.sdk.util
Static utility methods that create combine function instances.
CombineFnUtil() - Constructor for class org.apache.beam.sdk.util.CombineFnUtil
 
CombineFnWithContext() - Constructor for class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
 
CombineWithContext - Class in org.apache.beam.sdk.transforms
This class contains combine functions that have access to PipelineOptions and side inputs through CombineWithContext.Context.
CombineWithContext() - Constructor for class org.apache.beam.sdk.transforms.CombineWithContext
 
CombineWithContext.CombineFnWithContext<InputT,AccumT,OutputT> - Class in org.apache.beam.sdk.transforms
A combine function that has access to PipelineOptions and side inputs through CombineWithContext.Context.
CombineWithContext.Context - Class in org.apache.beam.sdk.transforms
Information accessible to all methods in CombineFnWithContext and KeyedCombineFnWithContext.
CombineWithContext.RequiresContextInternal - Interface in org.apache.beam.sdk.transforms
An internal interface for signaling that a GloballyCombineFn or a PerKeyCombineFn needs to access CombineWithContext.Context.
combining(Combine.CombineFn<InputT, AccumT, OutputT>) - Static method in class org.apache.beam.sdk.state.StateSpecs
Create a StateSpec for a CombiningState which uses a Combine.CombineFn to automatically merge multiple values of type InputT into a single resulting OutputT.
combining(CombineWithContext.CombineFnWithContext<InputT, AccumT, OutputT>) - Static method in class org.apache.beam.sdk.state.StateSpecs
For internal use only; no backwards compatibility guarantees
combining(Coder<AccumT>, Combine.CombineFn<InputT, AccumT, OutputT>) - Static method in class org.apache.beam.sdk.state.StateSpecs
Identical to #combining(CombineFn), but with an accumulator coder explicitly supplied.
combining(Coder<AccumT>, CombineWithContext.CombineFnWithContext<InputT, AccumT, OutputT>) - Static method in class org.apache.beam.sdk.state.StateSpecs
For internal use only; no backwards compatibility guarantees
combiningFromInputInternal(Coder<InputT>, Combine.CombineFn<InputT, AccumT, OutputT>) - Static method in class org.apache.beam.sdk.state.StateSpecs
For internal use only; no backwards-compatibility guarantees.
CombiningState<InputT,AccumT,OutputT> - Interface in org.apache.beam.sdk.state
A ReadableState cell defined by a Combine.CombineFn, accepting multiple input values, combining them as specified into accumulators, and producing a single output value.
compact(AccumT) - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
Returns an accumulator that represents the same logical value as the input accumulator, but may have a more compact representation.
compact(List<V>) - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
 
compact(Object[]) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
 
compact(Object[], CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
 
compact(AccumT, CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
Returns an accumulator that represents the same logical value as the input accumulator, but may have a more compact representation.
compare(T, T) - Method in class org.apache.beam.sdk.transforms.Top.Largest
Deprecated.
 
compare(T, T) - Method in class org.apache.beam.sdk.transforms.Top.Natural
 
compare(T, T) - Method in class org.apache.beam.sdk.transforms.Top.Reversed
 
compare(T, T) - Method in class org.apache.beam.sdk.transforms.Top.Smallest
Deprecated.
 
compare(Object, Object) - Method in class org.apache.beam.sdk.util.common.ReflectHelpers.ObjectsClassComparator
 
compare(KV<K, V>, KV<K, V>) - Method in class org.apache.beam.sdk.values.KV.OrderByKey
 
compare(KV<K, V>, KV<K, V>) - Method in class org.apache.beam.sdk.values.KV.OrderByValue
 
compareTo(ByteKey) - Method in class org.apache.beam.sdk.io.range.ByteKey
ByteKey implements Comparable<ByteKey> by comparing the arrays in lexicographic order.
compareTo(IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
 
CompatibilityError() - Constructor for class org.apache.beam.sdk.schemas.transforms.Cast.CompatibilityError
 
complete(List<TimestampedValue<OutputT>>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
Constructs a Watch.Growth.PollResult with the given outputs and declares that there will be no new outputs for the current input.
complete(Instant, List<OutputT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
Like Watch.Growth.PollResult.complete(List), but assigns the same timestamp to all new outputs.
compose() - Static method in class org.apache.beam.sdk.transforms.CombineFns
compose(SerializableFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.PTransform
For a SerializableFunction<InputT, OutputT> fn, returns a PTransform given by applying fn.apply(v) to the input PCollection<InputT>.
compose(String, SerializableFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.PTransform
Like PTransform.compose(SerializableFunction), but with a custom name.
ComposeCombineFnBuilder() - Constructor for class org.apache.beam.sdk.transforms.CombineFns.ComposeCombineFnBuilder
 
COMPOSITE_TYPES - Static variable in enum org.apache.beam.sdk.schemas.Schema.TypeName
 
CompressedReader(CompressedSource<T>, FileBasedSource.FileBasedReader<T>) - Constructor for class org.apache.beam.sdk.io.CompressedSource.CompressedReader
Create a CompressedReader from a CompressedSource and delegate reader.
CompressedSource<T> - Class in org.apache.beam.sdk.io
A Source that reads from compressed files.
CompressedSource.CompressedReader<T> - Class in org.apache.beam.sdk.io
Reader for a CompressedSource.
CompressedSource.CompressionMode - Enum in org.apache.beam.sdk.io
Deprecated.
Use Compression instead
CompressedSource.DecompressingChannelFactory - Interface in org.apache.beam.sdk.io
Factory interface for creating channels that decompress the content of an underlying channel.
Compression - Enum in org.apache.beam.sdk.io
Various compression types for reading/writing files.
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in interface org.apache.beam.sdk.state.MapState
A deferred read-followed-by-write.
CONCAT_FIELD_NAMES - Static variable in class org.apache.beam.sdk.schemas.utils.SelectHelpers
This policy keeps all levels of a name.
concatFieldNames() - Method in class org.apache.beam.sdk.schemas.transforms.Select.Flattened
For nested fields, concatenate all the names separated by a _ character in the flattened schema.
CONCRETE_CLASS - Static variable in class org.apache.beam.sdk.io.WriteFiles
For internal use by runners.
configurationSchema() - Method in class org.apache.beam.sdk.io.AvroSchemaIOProvider
Returns the expected schema of the configuration object.
configurationSchema() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIOProvider
Returns the expected schema of the configuration object.
configure() - Static method in class org.apache.beam.sdk.transforms.windowing.Window
Returns a new builder for a Window transform for setting windowing parameters other than the windowing function.
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
Returns true if this Coder is injective with respect to Object.equals(java.lang.Object).
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
Returns true if this Coder is injective with respect to Object.equals(java.lang.Object).
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
Returns true if this Coder is injective with respect to Object.equals(java.lang.Object).
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
Returns true if this Coder is injective with respect to Object.equals(java.lang.Object).
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
Returns true if this Coder is injective with respect to Object.equals(java.lang.Object).
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.BitSetCoder
 
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.BooleanCoder
 
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.ByteCoder
Returns true if this Coder is injective with respect to Object.equals(java.lang.Object).
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.Coder
Returns true if this Coder is injective with respect to Object.equals(java.lang.Object).
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.DequeCoder
 
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.DoubleCoder
Returns true if this Coder is injective with respect to Object.equals(java.lang.Object).
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.DurationCoder
Returns true if this Coder is injective with respect to Object.equals(java.lang.Object).
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.FloatCoder
Returns true if this Coder is injective with respect to Object.equals(java.lang.Object).
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.InstantCoder
Returns true if this Coder is injective with respect to Object.equals(java.lang.Object).
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.KvCoder
 
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
LengthPrefixCoder is consistent with equals if the nested Coder is.
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.ListCoder
 
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.MapCoder
 
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.NullableCoder
NullableCoder is consistent with equals if the nested Coder is.
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.SerializableCoder
 
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
Returns true if this Coder is injective with respect to Object.equals(java.lang.Object).
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.VarIntCoder
Returns true if this Coder is injective with respect to Object.equals(java.lang.Object).
consistentWithEquals() - Method in class org.apache.beam.sdk.coders.VarLongCoder
Returns true if this Coder is injective with respect to Object.equals(java.lang.Object).
consistentWithEquals() - Method in class org.apache.beam.sdk.io.fs.MetadataCoder
 
consistentWithEquals() - Method in class org.apache.beam.sdk.io.fs.MetadataCoderV2
 
consistentWithEquals() - Method in class org.apache.beam.sdk.io.fs.ResourceIdCoder
 
consistentWithEquals() - Method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
 
consistentWithEquals() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
 
consistentWithEquals() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindow.Coder
 
consistentWithEquals() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
 
consistentWithEquals() - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
 
constant(FileBasedSink.FilenamePolicy, SerializableFunction<UserT, OutputT>) - Static method in class org.apache.beam.sdk.io.DynamicFileDestinations
Returns a FileBasedSink.DynamicDestinations that always returns the same FileBasedSink.FilenamePolicy.
constant(FileBasedSink.FilenamePolicy) - Static method in class org.apache.beam.sdk.io.DynamicFileDestinations
A specialization of #constant(FilenamePolicy, SerializableFunction) for the case where UserT and OutputT are the same type and the format function is the identity.
constant(OutT) - Static method in class org.apache.beam.sdk.transforms.SerializableFunctions
 
constantDestinations(FileBasedSink.FilenamePolicy, Schema, Map<String, Object>, CodecFactory, SerializableFunction<UserT, OutputT>) - Static method in class org.apache.beam.sdk.io.AvroIO
Returns a DynamicAvroDestinations that always returns the same FileBasedSink.FilenamePolicy, schema, metadata, and codec.
constantDestinations(FileBasedSink.FilenamePolicy, Schema, Map<String, Object>, CodecFactory, SerializableFunction<UserT, OutputT>, AvroSink.DatumWriterFactory<OutputT>) - Static method in class org.apache.beam.sdk.io.AvroIO
Returns a DynamicAvroDestinations that always returns the same FileBasedSink.FilenamePolicy, schema, metadata, and codec.
contains(T) - Method in interface org.apache.beam.sdk.state.SetState
Returns true if this set contains the specified element.
contains(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.contains(Object[]).
contains(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.contains(Object[]).
contains(SerializableMatcher<? super T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.contains(Matcher[]).
contains(List<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.contains(List).
contains(IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
Returns whether this window contains the given window.
containsInAnyOrder(T...) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
Asserts that the iterable in question contains the provided elements.
containsInAnyOrder(Iterable<T>) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
Asserts that the iterable in question contains the provided elements.
containsInAnyOrder(T...) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
Checks that the Iterable contains the expected elements, in any order.
containsInAnyOrder(Iterable<T>) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
Checks that the Iterable contains the expected elements, in any order.
containsInAnyOrder(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.containsInAnyOrder(Object[]).
containsInAnyOrder(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.containsInAnyOrder(Object[]).
containsInAnyOrder(SerializableMatcher<? super T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.containsInAnyOrder(Matcher[]).
containsInAnyOrder(Collection<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.containsInAnyOrder(Collection).
containsKey(ByteKey) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
Returns true if the specified ByteKey is contained within this range.
containsKey(Object) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
containsOnlyClassesMatching(Set<Matcher<Class<?>>>) - Static method in class org.apache.beam.sdk.util.ApiSurface
A factory method to create an ApiSurface matcher, producing a positive match if the queried api surface contains ONLY classes described by the provided matchers.
containsOnlyClassesMatching(Matcher<Class<?>>...) - Static method in class org.apache.beam.sdk.util.ApiSurface
containsOnlyPackages(String...) - Static method in class org.apache.beam.sdk.util.ApiSurface
containsOnlyPackages(Set<String>) - Static method in class org.apache.beam.sdk.util.ApiSurface
A factory method to create an ApiSurface matcher, producing a positive match if the queried api surface contains classes ONLY from specified package names.
containsString(String) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.containsString(java.lang.String).
containsValue(Object) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
Context(boolean) - Constructor for class org.apache.beam.sdk.coders.Coder.Context
Deprecated.
 
Context() - Constructor for class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
 
Context() - Constructor for class org.apache.beam.sdk.transforms.CombineWithContext.Context
 
Context() - Constructor for class org.apache.beam.sdk.transforms.Contextful.Fn.Context
 
Contextful<ClosureT> - Class in org.apache.beam.sdk.transforms
Pair of a bit of user code (a "closure") and the Requirements needed to run it.
Contextful.Fn<InputT,OutputT> - Interface in org.apache.beam.sdk.transforms
A function from an input to an output that may additionally access Contextful.Fn.Context when computing the result.
Contextful.Fn.Context - Class in org.apache.beam.sdk.transforms
An accessor for additional capabilities available in Contextful.Fn.apply(InputT, org.apache.beam.sdk.transforms.Contextful.Fn.Context).
continuously(Duration, Watch.Growth.TerminationCondition<String, ?>) - Method in class org.apache.beam.sdk.io.FileIO.Match
continuously(Duration, Watch.Growth.TerminationCondition<String, ?>) - Method in class org.apache.beam.sdk.io.FileIO.MatchAll
continuously(Duration, Watch.Growth.TerminationCondition<String, ?>) - Method in class org.apache.beam.sdk.io.FileIO.MatchConfiguration
Continuously watches for new files at the given interval until the given termination condition is reached, where the input to the condition is the filepattern.
Convert - Class in org.apache.beam.sdk.schemas.transforms
A set of utilities for converting between different objects supporting schemas.
Convert() - Constructor for class org.apache.beam.sdk.schemas.transforms.Convert
 
convert(TypeDescriptor) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
 
convertArray(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertType
 
convertArray(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
 
convertArray(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
 
convertArray(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
 
convertAvroFieldStrict(Object, Schema, Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Strict conversion from AVRO to Beam, strict because it doesn't do widening or narrowing during conversion.
convertByteBuffer(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertType
 
convertByteBuffer(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
 
convertByteBuffer(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
 
convertByteBuffer(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
 
convertCharSequence(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertType
 
convertCharSequence(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
 
convertCharSequence(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
 
convertCharSequence(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
 
convertCollection(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertType
 
convertCollection(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
 
convertCollection(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
 
convertCollection(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
 
convertDateTime(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertType
 
convertDateTime(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
 
convertDateTime(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
 
convertDateTime(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
 
convertDefault(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.AvroUtils.AvroConvertType
 
convertDefault(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.AvroUtils.AvroConvertValueForGetter
 
convertDefault(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.AvroUtils.AvroConvertValueForSetter
 
convertDefault(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertType
 
convertDefault(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
 
convertDefault(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
 
convertDefault(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
 
ConvertedSchemaInformation(SchemaCoder<T>, Schema.FieldType) - Constructor for class org.apache.beam.sdk.schemas.utils.ConvertHelpers.ConvertedSchemaInformation
 
convertEnum(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertType
 
convertEnum(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
 
convertEnum(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
 
convertEnum(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
 
ConvertHelpers - Class in org.apache.beam.sdk.schemas.utils
Helper functions for converting between equivalent schema types.
ConvertHelpers() - Constructor for class org.apache.beam.sdk.schemas.utils.ConvertHelpers
 
ConvertHelpers.ConvertedSchemaInformation<T> - Class in org.apache.beam.sdk.schemas.utils
Return value after converting a schema.
convertIterable(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertType
 
convertIterable(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
 
convertIterable(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
 
convertIterable(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
 
convertList(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertType
 
convertList(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
 
convertList(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
 
convertList(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
 
convertMap(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertType
 
convertMap(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
 
convertMap(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
 
convertMap(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
 
convertPrimitive(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertType
 
convertPrimitive(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
 
convertPrimitive(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
 
convertPrimitive(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
 
convertToBagSpecInternal(StateSpec<CombiningState<InputT, AccumT, OutputT>>) - Static method in class org.apache.beam.sdk.state.StateSpecs
For internal use only; no backwards-compatibility guarantees.
convertToFileResourceIfPossible(String) - Static method in class org.apache.beam.sdk.io.FileBasedSink
This is a helper function for turning a user-provided output filename prefix and converting it into a ResourceId for writing output files.
convertToMapSpecInternal(StateSpec<SetState<KeyT>>) - Static method in class org.apache.beam.sdk.state.StateSpecs
For internal use only; no backwards-compatibility guarantees.
ConvertType(boolean) - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertType
 
ConvertValueForGetter(StackManipulation) - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
 
ConvertValueForSetter(StackManipulation) - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
 
copy(List<ClassLoaderFileSystem.ClassLoaderResourceId>, List<ClassLoaderFileSystem.ClassLoaderResourceId>) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
 
copy(List<ResourceIdT>, List<ResourceIdT>) - Method in class org.apache.beam.sdk.io.FileSystem
Copies a List of file-like resources from one location to another.
copy(List<ResourceId>, List<ResourceId>, MoveOptions...) - Static method in class org.apache.beam.sdk.io.FileSystems
Copies a List of file-like resources from one location to another.
copy() - Method in interface org.apache.beam.sdk.util.common.Reiterator
Returns a copy of the current Reiterator.
copyFrom(ByteBuffer) - Static method in class org.apache.beam.sdk.io.range.ByteKey
Creates a new ByteKey backed by a copy of the data remaining in the specified ByteBuffer.
copyFrom(byte[]) - Static method in class org.apache.beam.sdk.io.range.ByteKey
Creates a new ByteKey backed by a copy of the specified byte[].
copyFrom(FieldSpecifierNotationParser.DotExpressionComponentContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionComponentContext
 
copyFrom(FieldSpecifierNotationParser.QualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifierListContext
 
Count - Class in org.apache.beam.sdk.transforms
PTransforms to count the elements in a PCollection.
countAsserts(Pipeline) - Static method in class org.apache.beam.sdk.testing.PAssert
 
Counter - Interface in org.apache.beam.sdk.metrics
A metric that reports a single long value and can be incremented or decremented.
counter(String, String) - Static method in class org.apache.beam.sdk.metrics.Metrics
Create a metric that can be incremented and decremented, and is aggregated by taking the sum.
counter(Class<?>, String) - Static method in class org.apache.beam.sdk.metrics.Metrics
Create a metric that can be incremented and decremented, and is aggregated by taking the sum.
CounterMark(long, Instant) - Constructor for class org.apache.beam.sdk.io.CountingSource.CounterMark
Creates a checkpoint mark reflecting the last emitted value.
CountingSource - Class in org.apache.beam.sdk.io
Most users should use GenerateSequence instead.
CountingSource.CounterMark - Class in org.apache.beam.sdk.io
The checkpoint for an unbounded CountingSource is simply the last value produced.
CrashingRunner - Class in org.apache.beam.sdk.testing
A PipelineRunner that applies no overrides and throws an exception on calls to Pipeline.run().
CrashingRunner() - Constructor for class org.apache.beam.sdk.testing.CrashingRunner
 
create(ClassLoaderFileSystem.ClassLoaderResourceId, CreateOptions) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
 
create(WritableByteChannel) - Method in enum org.apache.beam.sdk.io.FileBasedSink.CompressionType
Deprecated.
 
create(WritableByteChannel) - Method in interface org.apache.beam.sdk.io.FileBasedSink.WritableByteChannelFactory
 
create(EmptyMatchTreatment) - Static method in class org.apache.beam.sdk.io.FileIO.MatchConfiguration
create(ResourceIdT, CreateOptions) - Method in class org.apache.beam.sdk.io.FileSystem
Returns a write channel for the given ResourceIdT.
create(ResourceId, String) - Static method in class org.apache.beam.sdk.io.FileSystems
Returns a write channel for the given ResourceId.
create(ResourceId, CreateOptions) - Static method in class org.apache.beam.sdk.io.FileSystems
Returns a write channel for the given ResourceId with CreateOptions.
create(MatchResult.Status, List<MatchResult.Metadata>) - Static method in class org.apache.beam.sdk.io.fs.MatchResult
create(MatchResult.Status, IOException) - Static method in class org.apache.beam.sdk.io.fs.MatchResult
Returns a MatchResult given the MatchResult.Status and IOException.
create(long, long, long, long) - Static method in class org.apache.beam.sdk.metrics.DistributionResult
 
create(long, Instant) - Static method in class org.apache.beam.sdk.metrics.GaugeResult
 
create(String, MetricName) - Static method in class org.apache.beam.sdk.metrics.MetricKey
 
create(Iterable<MetricResult<Long>>, Iterable<MetricResult<DistributionResult>>, Iterable<MetricResult<GaugeResult>>) - Static method in class org.apache.beam.sdk.metrics.MetricQueryResults
 
create(MetricKey, Boolean, T) - Static method in class org.apache.beam.sdk.metrics.MetricResult
 
create(MetricKey, T, T) - Static method in class org.apache.beam.sdk.metrics.MetricResult
 
create(PipelineOptions) - Method in class org.apache.beam.sdk.metrics.MetricsOptions.NoOpMetricsSink
 
create(PipelineOptions) - Method in interface org.apache.beam.sdk.options.DefaultValueFactory
Creates a default value for a getter marked with Default.InstanceFactory.
create(PipelineOptions) - Method in class org.apache.beam.sdk.options.PipelineOptions.AtomicLongFactory
 
create(PipelineOptions) - Method in class org.apache.beam.sdk.options.PipelineOptions.DirectRunner
 
create(PipelineOptions) - Method in class org.apache.beam.sdk.options.PipelineOptions.JobNameFactory
 
create(PipelineOptions) - Method in class org.apache.beam.sdk.options.PipelineOptions.UserAgentFactory
 
create() - Method in class org.apache.beam.sdk.options.PipelineOptionsFactory.Builder
Creates and returns an object that implements PipelineOptions using the values configured on this builder during construction.
create() - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
Creates and returns an object that implements PipelineOptions.
create() - Static method in class org.apache.beam.sdk.Pipeline
Constructs a pipeline from default PipelineOptions.
create(PipelineOptions) - Static method in class org.apache.beam.sdk.Pipeline
Constructs a pipeline from the provided PipelineOptions.
create() - Static method in class org.apache.beam.sdk.PipelineRunner
Creates a runner from the default app PipelineOptions.
create(Class<?>, Schema) - Method in interface org.apache.beam.sdk.schemas.Factory
 
create() - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return an empty FieldAccessDescriptor.
create(Map<String, Integer>) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
Create an enumeration type over a set of String->Integer values.
create(List<String>) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
Create an enumeration type from a fixed set of String values; integer values will be automatically chosen.
create(String...) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
Create an enumeration type from a fixed set of String values; integer values will be automatically chosen.
create(Schema.Field...) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
Create an OneOfType logical type.
create(List<Schema.Field>) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
Create an OneOfType logical type.
create(List<Schema.Field>, Map<String, Integer>) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
Create an OneOfType logical type.
create(Object...) - Method in interface org.apache.beam.sdk.schemas.SchemaUserTypeCreator
 
create() - Static method in class org.apache.beam.sdk.schemas.transforms.AddFields
 
create(List<String>, String) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast.CompatibilityError
 
create() - Static method in class org.apache.beam.sdk.schemas.transforms.Filter
 
create() - Static method in class org.apache.beam.sdk.schemas.transforms.RenameFields
Create an instance of this transform.
create() - Static method in class org.apache.beam.sdk.schemas.transforms.Select
 
create(Class, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils.ClassWithSchema
 
create(List<String>, Optional<Schema.TypeName>) - Static method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
 
create() - Static method in class org.apache.beam.sdk.testing.TestPipeline
Creates and returns a new test pipeline.
create(PipelineOptions) - Method in class org.apache.beam.sdk.testing.TestPipelineOptions.AlwaysPassMatcherFactory
 
create(Coder<T>) - Static method in class org.apache.beam.sdk.testing.TestStream
Create a new TestStream.Builder with no elements and watermark equal to BoundedWindow.TIMESTAMP_MIN_VALUE.
create(Schema) - Static method in class org.apache.beam.sdk.testing.TestStream
 
create(Schema, TypeDescriptor<T>, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Static method in class org.apache.beam.sdk.testing.TestStream
 
create(int, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
Returns an approximate quantiles combiner with the given compareFn and desired number of quantiles.
create(int) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
Like ApproximateQuantiles.ApproximateQuantilesCombineFn.create(int, Comparator), but sorts values using their natural ordering.
create(int, ComparatorT, long, double) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
Creates an approximate quantiles combiner with the given compareFn and desired number of quantiles.
Create<T> - Class in org.apache.beam.sdk.transforms
Create<T> takes a collection of elements of type T known when the pipeline is constructed and returns a PCollection<T> containing the elements.
Create() - Constructor for class org.apache.beam.sdk.transforms.Create
 
create() - Static method in class org.apache.beam.sdk.transforms.Distinct
Returns a Distinct<T> PTransform.
create() - Static method in class org.apache.beam.sdk.transforms.DoFnSchemaInformation
Create an instance.
create() - Static method in class org.apache.beam.sdk.transforms.GroupByKey
Returns a GroupByKey<K, V> PTransform.
create(long, Duration) - Static method in class org.apache.beam.sdk.transforms.GroupIntoBatches.BatchingParams
 
create() - Static method in class org.apache.beam.sdk.transforms.Impulse
Create a new Impulse PTransform.
create() - Static method in class org.apache.beam.sdk.transforms.join.CoGroupByKey
Returns a CoGroupByKey<K> PTransform.
create(JsonToRow.JsonToRowWithErrFn) - Static method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError
 
create() - Static method in class org.apache.beam.sdk.transforms.Keys
Returns a Keys<K> PTransform.
create() - Static method in class org.apache.beam.sdk.transforms.KvSwap
Returns a KvSwap<K, V> PTransform.
create() - Static method in class org.apache.beam.sdk.transforms.PeriodicImpulse
 
create() - Static method in class org.apache.beam.sdk.transforms.PeriodicSequence
 
create() - Static method in class org.apache.beam.sdk.transforms.Values
Returns a Values<V> PTransform.
create(T) - Static method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadata
 
create(Coder<T>, Coder<MetaT>) - Static method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadataCoder
 
Create.OfValueProvider<T> - Class in org.apache.beam.sdk.transforms
Create.TimestampedValues<T> - Class in org.apache.beam.sdk.transforms
A PTransform that creates a PCollection whose elements have associated timestamps.
Create.Values<T> - Class in org.apache.beam.sdk.transforms
A PTransform that creates a PCollection from a set of in-memory objects.
createAccumulator() - Method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
 
createAccumulator() - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
Deprecated.
 
createAccumulator() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
 
createAccumulator() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
 
createAccumulator() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
 
createAccumulator() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
 
createAccumulator() - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
Returns a new, mutable accumulator value, representing the accumulation of zero input values.
createAccumulator() - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
 
createAccumulator() - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
 
createAccumulator(CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
 
createAccumulator(CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
Returns a new, mutable accumulator value, representing the accumulation of zero input values.
createAccumulator() - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
 
createAccumulator() - Method in class org.apache.beam.sdk.transforms.Top.TopCombineFn
 
createConstructorCreator(Class<T>, Constructor<T>, Schema, List<FieldValueTypeInformation>, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
 
createConstructorCreator(Class<T>, Constructor<T>, Schema, List<FieldValueTypeInformation>, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
 
createContextual(DeserializationContext, BeanProperty) - Method in class org.apache.beam.sdk.options.ValueProvider.Deserializer
 
createDecompressingChannel(ReadableByteChannel) - Method in enum org.apache.beam.sdk.io.CompressedSource.CompressionMode
Deprecated.
 
createDecompressingChannel(ReadableByteChannel) - Method in interface org.apache.beam.sdk.io.CompressedSource.DecompressingChannelFactory
Given a channel, create a channel that decompresses the content read from the channel.
createDefault() - Static method in class org.apache.beam.sdk.coders.CoderRegistry
Creates a CoderRegistry containing registrations for all standard coders part of the core Java Apache Beam SDK and also any registrations provided by coder registrars.
createDefault() - Static method in class org.apache.beam.sdk.schemas.SchemaRegistry
 
createForSubrangeOfFile(String, long, long) - Method in class org.apache.beam.sdk.io.AvroSource
Deprecated.
Used by Dataflow worker
createForSubrangeOfFile(MatchResult.Metadata, long, long) - Method in class org.apache.beam.sdk.io.AvroSource
 
createForSubrangeOfFile(MatchResult.Metadata, long, long) - Method in class org.apache.beam.sdk.io.BlockBasedSource
Creates a BlockBasedSource for the specified range in a single file.
createForSubrangeOfFile(MatchResult.Metadata, long, long) - Method in class org.apache.beam.sdk.io.CompressedSource
Creates a CompressedSource for a subrange of a file.
createForSubrangeOfFile(MatchResult.Metadata, long, long) - Method in class org.apache.beam.sdk.io.FileBasedSource
Creates and returns a new FileBasedSource of the same type as the current FileBasedSource backed by a given file and an offset range.
createFromStateContext(StateContext<?>) - Static method in class org.apache.beam.sdk.util.CombineContextFactory
Returns a Combine.Context that wraps a StateContext.
createGetter(FieldValueTypeInformation, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
 
createGetterConversions(StackManipulation) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.DefaultTypeConversionsFactory
 
createGetterConversions(StackManipulation) - Method in interface org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversionsFactory
 
createIterator() - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObservableIterable
Derived classes override this method to return an iterator for this iterable.
createLzoInputStream(InputStream) - Static method in class org.apache.beam.sdk.util.LzoCompression
Create an InputStream that will read from the given InputStream using LzoCodec.
createLzoOutputStream(OutputStream) - Static method in class org.apache.beam.sdk.util.LzoCompression
Create an OutputStream that will write to the given OutputStream.
createLzopInputStream(InputStream) - Static method in class org.apache.beam.sdk.util.LzoCompression
Create an InputStream that will read from the given InputStream using LzopCodec.
createLzopOutputStream(OutputStream) - Static method in class org.apache.beam.sdk.util.LzoCompression
Create a OutputStream that will write to the given OutputStream.
createMetadata(MetaT) - Static method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadata
 
CreateOptions - Class in org.apache.beam.sdk.io.fs
An abstract class that contains common configuration options for creating resources.
CreateOptions() - Constructor for class org.apache.beam.sdk.io.fs.CreateOptions
 
CreateOptions.Builder<BuilderT extends CreateOptions.Builder<BuilderT>> - Class in org.apache.beam.sdk.io.fs
An abstract builder for CreateOptions.
CreateOptions.StandardCreateOptions - Class in org.apache.beam.sdk.io.fs
A standard configuration options with builder.
CreateOptions.StandardCreateOptions.Builder - Class in org.apache.beam.sdk.io.fs
createPane(boolean, boolean, PaneInfo.Timing) - Static method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
 
createPane(boolean, boolean, PaneInfo.Timing, long, long) - Static method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
Factory method to create a PaneInfo with the specified parameters.
createPrimitiveOutputInternal(Pipeline, WindowingStrategy<?, ?>, PCollection.IsBounded, Coder<T>) - Static method in class org.apache.beam.sdk.values.PCollection
For internal use only; no backwards-compatibility guarantees.
createPrimitiveOutputInternal(Pipeline, WindowingStrategy<?, ?>, PCollection.IsBounded, Coder<T>, TupleTag<?>) - Static method in class org.apache.beam.sdk.values.PCollection
For internal use only; no backwards-compatibility guarantees.
createProcessContext(ValueInSingleWindow<InputT>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
createReader(PipelineOptions) - Method in class org.apache.beam.sdk.io.BoundedSource
Returns a new BoundedSource.BoundedReader that reads from this source.
createReader(PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSource
 
createReader(PipelineOptions, CheckpointMarkT) - Method in class org.apache.beam.sdk.io.UnboundedSource
Create a new UnboundedSource.UnboundedReader to read from this source, resuming from the given checkpoint if present.
createSetter(FieldValueTypeInformation, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
 
createSetterConversions(StackManipulation) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.DefaultTypeConversionsFactory
 
createSetterConversions(StackManipulation) - Method in interface org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversionsFactory
 
createSingleFileReader(PipelineOptions) - Method in class org.apache.beam.sdk.io.AvroSource
 
createSingleFileReader(PipelineOptions) - Method in class org.apache.beam.sdk.io.BlockBasedSource
Creates a BlockBasedReader.
createSingleFileReader(PipelineOptions) - Method in class org.apache.beam.sdk.io.CompressedSource
Creates a FileBasedReader to read a single file.
createSingleFileReader(PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSource
Creates and returns an instance of a FileBasedReader implementation for the current source assuming the source represents a single file.
createSourceForSubrange(long, long) - Method in class org.apache.beam.sdk.io.FileBasedSource
 
createSourceForSubrange(long, long) - Method in class org.apache.beam.sdk.io.OffsetBasedSource
Returns an OffsetBasedSource for a subrange of the current source.
createStaticCreator(Class<T>, Method, Schema, List<FieldValueTypeInformation>, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
 
createStaticCreator(Class<T>, Method, Schema, List<FieldValueTypeInformation>, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
 
createStructuralValues(Coder<T>, List<T>) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
Testing utilities below depend on standard assertions and matchers to compare elements read by sources.
createTypeConversion(boolean) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.DefaultTypeConversionsFactory
 
createTypeConversion(boolean) - Method in interface org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversionsFactory
 
createValue(String, T) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
Create a OneOfType.Value specifying which field to set and the value to set.
createValue(int, T) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
Create a OneOfType.Value specifying which field to set and the value to set.
createValue(EnumerationType.Value, T) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
Create a OneOfType.Value specifying which field to set and the value to set.
createWriteOperation() - Method in class org.apache.beam.sdk.io.AvroSink
 
createWriteOperation() - Method in class org.apache.beam.sdk.io.FileBasedSink
Return a subclass of FileBasedSink.WriteOperation that will manage the write to the sink.
createWriter() - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
Clients must implement to return a subclass of FileBasedSink.Writer.
crossProductJoin() - Method in class org.apache.beam.sdk.schemas.transforms.CoGroup.Impl
Expand the join into individual rows, similar to SQL joins.
currentEventTime() - Method in interface org.apache.beam.sdk.state.Timers
Returns the current event time.
currentProcessingTime() - Method in interface org.apache.beam.sdk.state.Timers
Returns the current processing time.
currentRestriction() - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.OutputRangeTracker
 
currentRestriction() - Method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
 
currentRestriction() - Method in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
 
currentRestriction() - Method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker
Returns a restriction accurately describing the full range of work the current DoFn.ProcessElement call will do, including already completed work.
currentSynchronizedProcessingTime() - Method in interface org.apache.beam.sdk.state.Timers
Returns the current synchronized processing time or null if unknown.
currentWatermark() - Method in interface org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimator
Return estimated output watermark.
currentWatermark() - Method in class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.Manual
 
currentWatermark() - Method in class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.MonotonicallyIncreasing
 
currentWatermark() - Method in class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.WallTime
 
CustomCoder<T> - Class in org.apache.beam.sdk.coders
An abstract base class that implements all methods of Coder except Coder.encode(T, java.io.OutputStream) and Coder.decode(java.io.InputStream).
CustomCoder() - Constructor for class org.apache.beam.sdk.coders.CustomCoder
 

D

Date - Class in org.apache.beam.sdk.schemas.logicaltypes
A date without a time-zone.
Date() - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.Date
 
DATE - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.SqlTypes
Beam LogicalType corresponding to ZetaSQL/CalciteSQL DATE type.
DATE_FIELD_NAME - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
 
DATE_TYPES - Static variable in enum org.apache.beam.sdk.schemas.Schema.TypeName
 
DateTime - Class in org.apache.beam.sdk.schemas.logicaltypes
A datetime without a time-zone.
DateTime() - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.DateTime
 
DATETIME - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.SqlTypes
Beam LogicalType corresponding to ZetaSQL DATETIME type.
DATETIME - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
The type of datetime fields.
DATETIME_SCHEMA - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
 
days(int) - Static method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows
Returns a WindowFn that windows elements into periods measured by days.
DeadLetteredTransform<InputT,OutputT> - Class in org.apache.beam.sdk.schemas.io
 
DeadLetteredTransform(SimpleFunction<InputT, OutputT>, String) - Constructor for class org.apache.beam.sdk.schemas.io.DeadLetteredTransform
 
debug(String, Object...) - Static method in class org.apache.beam.sdk.util.WindowTracing
 
dec() - Method in interface org.apache.beam.sdk.metrics.Counter
 
dec(long) - Method in interface org.apache.beam.sdk.metrics.Counter
 
dec() - Method in class org.apache.beam.sdk.metrics.DelegatingCounter
 
dec(long) - Method in class org.apache.beam.sdk.metrics.DelegatingCounter
 
DECIMAL - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
The type of decimal fields.
declaredFieldsWithAnnotation(Class<? extends Annotation>, Class<?>, Class<?>) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
 
declaredMethodsWithAnnotation(Class<? extends Annotation>, Class<?>, Class<?>) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.AvroCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.BitSetCoder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.BitSetCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.BooleanCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.ByteCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.Coder
Decodes a value of type T from the given input stream in the given context.
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.Coder
Deprecated.
only implement and call Coder.decode(InputStream)
decode(InputStream) - Method in class org.apache.beam.sdk.coders.DelegateCoder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.DelegateCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.DoubleCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.DurationCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.FloatCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.InstantCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.KvCoder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.KvCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.MapCoder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.MapCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.NullableCoder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.NullableCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.SerializableCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.ShardedKeyCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.SnappyCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.VarIntCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.VarLongCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.coders.VoidCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.ParamsCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResultCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.io.fs.MetadataCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.io.fs.MetadataCoderV2
 
decode(InputStream) - Method in class org.apache.beam.sdk.io.fs.ResourceIdCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
 
decode(InputStream) - Method in class org.apache.beam.sdk.io.ReadableFileCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.schemas.SchemaCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.testing.TestStream.TestStreamCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindow.Coder
 
decode(InputStream) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo.PaneInfoCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.util.BitSetCoder
Deprecated.
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.util.BitSetCoder
Deprecated.
 
decode(InputStream) - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
 
decode(InputStream) - Method in class org.apache.beam.sdk.util.WindowedValue.FullWindowedValueCoder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.util.WindowedValue.FullWindowedValueCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.util.WindowedValue.ValueOnlyWindowedValueCoder
Deprecated.
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.util.WindowedValue.ValueOnlyWindowedValueCoder
Deprecated.
 
decode(InputStream) - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow.Coder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow.Coder
 
decode(InputStream) - Method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadataCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
 
decode(InputStream) - Method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
 
decode(InputStream) - Method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
 
decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
 
decodeFromBase64(Coder<T>, String) - Static method in class org.apache.beam.sdk.util.CoderUtils
Parses a value from a base64-encoded String using the given coder.
decodeFromByteArray(Coder<T>, byte[]) - Static method in class org.apache.beam.sdk.util.CoderUtils
Decodes the given bytes using the specified Coder, and returns the resulting decoded value.
decodeFromByteArray(Coder<T>, byte[], Coder.Context) - Static method in class org.apache.beam.sdk.util.CoderUtils
 
decodeInt(InputStream) - Static method in class org.apache.beam.sdk.util.VarInt
Decodes an integer value from the given stream.
decodeLong(InputStream) - Static method in class org.apache.beam.sdk.util.VarInt
Decodes a long value from the given stream.
decodePane(byte) - Static method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
 
decodeToIterable(List<T>) - Method in class org.apache.beam.sdk.coders.CollectionCoder
Builds an instance of IterableT, this coder's associated Iterable-like subtype, from a list of decoded elements.
decodeToIterable(List<T>) - Method in class org.apache.beam.sdk.coders.DequeCoder
 
decodeToIterable(List<T>) - Method in class org.apache.beam.sdk.coders.IterableCoder
 
decodeToIterable(List<T>) - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
Builds an instance of IterableT, this coder's associated Iterable-like subtype, from a list of decoded elements.
decodeToIterable(List<T>, long, InputStream) - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
Builds an instance of IterableT, this coder's associated Iterable-like subtype, from a list of decoded elements with the InputStream at the position where this coder detected the end of the stream.
decodeToIterable(List<T>) - Method in class org.apache.beam.sdk.coders.ListCoder
 
decodeToIterable(List<T>) - Method in class org.apache.beam.sdk.coders.SetCoder
Builds an instance of IterableT, this coder's associated Iterable-like subtype, from a list of decoded elements.
Deduplicate - Class in org.apache.beam.sdk.transforms
A set of PTransforms which deduplicate input records over a time domain and threshold.
Deduplicate.KeyedValues<K,V> - Class in org.apache.beam.sdk.transforms
Deduplicates keyed values using the key over a specified time domain and threshold.
Deduplicate.Values<T> - Class in org.apache.beam.sdk.transforms
Deduplicates values over a specified time domain and threshold.
Deduplicate.WithRepresentativeValues<T,IdT> - Class in org.apache.beam.sdk.transforms
A PTransform that uses a SerializableFunction to obtain a representative value for each input element used for deduplication.
deepEquals(Object, Object, Schema.FieldType) - Static method in class org.apache.beam.sdk.values.Row.Equals
 
deepHashCode(Object, Schema.FieldType) - Static method in class org.apache.beam.sdk.values.Row.Equals
 
Default - Annotation Type in org.apache.beam.sdk.options
Default represents a set of annotations that can be used to annotate getter properties on PipelineOptions with information representing the default value to be returned if no value is specified.
DEFAULT - Static variable in class org.apache.beam.sdk.util.FluentBackoff
By default the BackOff created by this builder will use exponential backoff (base exponent 1.5) with an initial backoff of 1 second.
DEFAULT - Static variable in interface org.apache.beam.sdk.util.Sleeper
Provides the default implementation based on Thread.sleep(long).
Default.Boolean - Annotation Type in org.apache.beam.sdk.options
This represents that the default of the option is the specified boolean primitive value.
Default.Byte - Annotation Type in org.apache.beam.sdk.options
This represents that the default of the option is the specified byte primitive value.
Default.Character - Annotation Type in org.apache.beam.sdk.options
This represents that the default of the option is the specified char primitive value.
Default.Class - Annotation Type in org.apache.beam.sdk.options
This represents that the default of the option is the specified Class value.
Default.Double - Annotation Type in org.apache.beam.sdk.options
This represents that the default of the option is the specified double primitive value.
Default.Enum - Annotation Type in org.apache.beam.sdk.options
This represents that the default of the option is the specified enum.
Default.Float - Annotation Type in org.apache.beam.sdk.options
This represents that the default of the option is the specified float primitive value.
Default.InstanceFactory - Annotation Type in org.apache.beam.sdk.options
Value must be of type DefaultValueFactory and have a default constructor.
Default.Integer - Annotation Type in org.apache.beam.sdk.options
This represents that the default of the option is the specified int primitive value.
Default.Long - Annotation Type in org.apache.beam.sdk.options
This represents that the default of the option is the specified long primitive value.
Default.Short - Annotation Type in org.apache.beam.sdk.options
This represents that the default of the option is the specified short primitive value.
Default.String - Annotation Type in org.apache.beam.sdk.options
This represents that the default of the option is the specified String value.
DEFAULT_BUFFER_SIZE - Static variable in class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
 
DEFAULT_BYTE_ARRAY_CODER - Static variable in class org.apache.beam.sdk.io.TFRecordIO
The default coder, which returns each record of the input file as a byte array.
DEFAULT_DURATION - Static variable in class org.apache.beam.sdk.transforms.Deduplicate
The default duration is 10 mins.
DEFAULT_MAX_NUM_ELEMENTS - Static variable in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
The cost (in time and space) to compute quantiles to a given accuracy is a function of the total number of elements in the data set.
DEFAULT_SCHEME - Static variable in class org.apache.beam.sdk.io.FileSystems
 
DEFAULT_TIME_DOMAIN - Static variable in class org.apache.beam.sdk.transforms.Deduplicate
The default is the processing time domain.
DEFAULT_UNWINDOWED_SHARD_TEMPLATE - Static variable in class org.apache.beam.sdk.io.DefaultFilenamePolicy
The default sharding name template.
DEFAULT_WINDOWED_SHARD_TEMPLATE - Static variable in class org.apache.beam.sdk.io.DefaultFilenamePolicy
The default windowed sharding name template used when writing windowed files.
DefaultCoder - Annotation Type in org.apache.beam.sdk.coders
The DefaultCoder annotation specifies a Coder class to handle encoding and decoding instances of the annotated class.
DefaultCoder.DefaultCoderProviderRegistrar - Class in org.apache.beam.sdk.coders
A CoderProviderRegistrar that registers a CoderProvider which can use the @DefaultCoder annotation to provide coder providers that creates Coders.
DefaultCoderProviderRegistrar() - Constructor for class org.apache.beam.sdk.coders.DefaultCoder.DefaultCoderProviderRegistrar
 
DefaultConcludeTransform() - Constructor for class org.apache.beam.sdk.testing.PAssert.DefaultConcludeTransform
 
DefaultFilenamePolicy - Class in org.apache.beam.sdk.io
A default FileBasedSink.FilenamePolicy for windowed and unwindowed files.
DefaultFilenamePolicy.Params - Class in org.apache.beam.sdk.io
Encapsulates constructor parameters to DefaultFilenamePolicy.
DefaultFilenamePolicy.ParamsCoder - Class in org.apache.beam.sdk.io
defaultNaming(String, String) - Static method in class org.apache.beam.sdk.io.FileIO.Write
 
defaultNaming(ValueProvider<String>, ValueProvider<String>) - Static method in class org.apache.beam.sdk.io.FileIO.Write
Defines a default FileIO.Write.FileNaming which will use the prefix and suffix supplied to create a name based on the window, pane, number of shards, shard index, and compression.
DefaultPipelineOptionsRegistrar - Class in org.apache.beam.sdk.options
A PipelineOptionsRegistrar containing the PipelineOptions subclasses available by default.
DefaultPipelineOptionsRegistrar() - Constructor for class org.apache.beam.sdk.options.DefaultPipelineOptionsRegistrar
 
Defaults() - Constructor for class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
 
DefaultSchema - Annotation Type in org.apache.beam.sdk.schemas.annotations
The DefaultSchema annotation specifies a SchemaProvider class to handle obtaining a schema and row for the specified class.
DefaultSchema.DefaultSchemaProvider - Class in org.apache.beam.sdk.schemas.annotations
SchemaProvider for default schemas.
DefaultSchema.DefaultSchemaProviderRegistrar - Class in org.apache.beam.sdk.schemas.annotations
Registrar for default schemas.
DefaultSchemaProvider() - Constructor for class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProvider
 
DefaultSchemaProviderRegistrar() - Constructor for class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProviderRegistrar
 
DefaultTrigger - Class in org.apache.beam.sdk.transforms.windowing
A trigger that is equivalent to Repeatedly.forever(AfterWatermark.pastEndOfWindow()).
DefaultTypeConversionsFactory() - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.DefaultTypeConversionsFactory
 
defaultValue() - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
Returns the default value when there are no values added to the accumulator.
defaultValue() - Method in interface org.apache.beam.sdk.transforms.CombineFnBase.GlobalCombineFn
Returns the default value when there are no values added to the accumulator.
defaultValue() - Method in class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
 
defaultValue() - Method in class org.apache.beam.sdk.transforms.View.AsSingleton
Returns the default value of this transform, or null if there isn't one.
DefaultValueFactory<T> - Interface in org.apache.beam.sdk.options
An interface used with the Default.InstanceFactory annotation to specify the class that will be an instance factory to produce default values for a given getter on PipelineOptions.
delay(Duration) - Static method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform
For internal use only; no backwards-compatibility guarantees.
Delay() - Constructor for class org.apache.beam.sdk.transforms.windowing.TimestampTransform.Delay
 
delegate(HasDisplayData) - Method in interface org.apache.beam.sdk.transforms.display.DisplayData.Builder
Register display data from the specified component on behalf of the current component.
DelegateCoder<T,IntermediateT> - Class in org.apache.beam.sdk.coders
A DelegateCoder<T, IntermediateT> wraps a Coder for IntermediateT and encodes/decodes values of type T by converting to/from IntermediateT and then encoding/decoding using the underlying Coder<IntermediateT>.
DelegateCoder(Coder<IntermediateT>, DelegateCoder.CodingFunction<T, IntermediateT>, DelegateCoder.CodingFunction<IntermediateT, T>, TypeDescriptor<T>) - Constructor for class org.apache.beam.sdk.coders.DelegateCoder
 
DelegateCoder.CodingFunction<InputT,OutputT> - Interface in org.apache.beam.sdk.coders
A CodingFunction<InputT, OutputT> is a serializable function from InputT to OutputT that may throw any Exception.
DelegatingArgumentProvider(DoFnInvoker.ArgumentProvider<InputT, OutputT>, String) - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
DelegatingCounter - Class in org.apache.beam.sdk.metrics
Implementation of Counter that delegates to the instance for the current context.
DelegatingCounter(MetricName) - Constructor for class org.apache.beam.sdk.metrics.DelegatingCounter
 
DelegatingCounter(MetricName, boolean) - Constructor for class org.apache.beam.sdk.metrics.DelegatingCounter
 
DelegatingDistribution - Class in org.apache.beam.sdk.metrics
Implementation of Distribution that delegates to the instance for the current context.
DelegatingDistribution(MetricName) - Constructor for class org.apache.beam.sdk.metrics.DelegatingDistribution
 
DelegatingDistribution(MetricName, boolean) - Constructor for class org.apache.beam.sdk.metrics.DelegatingDistribution
 
DelegatingHistogram - Class in org.apache.beam.sdk.metrics
Implementation of Histogram that delegates to the instance for the current context.
DelegatingHistogram(MetricName, HistogramData.BucketType, boolean) - Constructor for class org.apache.beam.sdk.metrics.DelegatingHistogram
 
delete(Collection<ClassLoaderFileSystem.ClassLoaderResourceId>) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
 
delete(Collection<ResourceIdT>) - Method in class org.apache.beam.sdk.io.FileSystem
Deletes a collection of resources.
delete(Collection<ResourceId>, MoveOptions...) - Static method in class org.apache.beam.sdk.io.FileSystems
Deletes a collection of resources.
deleteTimer(Instant, TimeDomain) - Method in interface org.apache.beam.sdk.state.Timers
Removes the timer set in this context for the timestamp and timeDomain.
dependsOnlyOnEarliestTimestamp() - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
Returns true if the result of combination of many output timestamps actually depends only on the earliest.
dependsOnlyOnWindow() - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
Returns true if the result does not depend on what outputs were combined but only the window they are in.
DequeCoder<T> - Class in org.apache.beam.sdk.coders
A Coder for Deque, using the format of IterableLikeCoder.
DequeCoder(Coder<T>) - Constructor for class org.apache.beam.sdk.coders.DequeCoder
 
describe(Set<Class<? extends PipelineOptions>>) - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
Outputs the set of options available to be set for the passed in PipelineOptions interfaces.
describeMismatchSafely(ShardedFile, Description) - Method in class org.apache.beam.sdk.testing.FileChecksumMatcher
 
describeMismatchSafely(T, Description) - Method in class org.apache.beam.sdk.testing.JsonMatcher
 
describeTo(Description) - Method in class org.apache.beam.sdk.testing.FileChecksumMatcher
 
describeTo(Description) - Method in class org.apache.beam.sdk.testing.JsonMatcher
 
describeTo(Description) - Method in class org.apache.beam.sdk.testing.RegexMatcher
 
describeTo(Description) - Method in class org.apache.beam.sdk.testing.TestPipelineOptions.AlwaysPassMatcher
 
Description - Annotation Type in org.apache.beam.sdk.options
Descriptions are used to generate human readable output when the --help command is specified.
deserialize(JsonParser, DeserializationContext) - Method in class org.apache.beam.sdk.options.ValueProvider.Deserializer
 
deserialize(byte[]) - Method in interface org.apache.beam.sdk.schemas.io.payloads.PayloadSerializer
 
deserialize(JsonParser, DeserializationContext) - Method in class org.apache.beam.sdk.util.RowJson.RowJsonDeserializer
 
deserializeFromByteArray(byte[], String) - Static method in class org.apache.beam.sdk.util.SerializableUtils
Deserializes an object from the given array of bytes, e.g., as serialized using SerializableUtils.serializeToByteArray(java.io.Serializable), and returns it.
detect(String) - Static method in enum org.apache.beam.sdk.io.Compression
 
DIRECTORY_CONTAINER - Static variable in class org.apache.beam.sdk.io.ShardNameTemplate
Shard is a file within a directory.
DirectRunner() - Constructor for class org.apache.beam.sdk.options.PipelineOptions.DirectRunner
 
discardingFiredPanes() - Method in class org.apache.beam.sdk.transforms.windowing.Window
Returns a new Window PTransform that uses the registered WindowFn and Triggering behavior, and that discards elements in a pane after they are triggered.
dispatch(DoFnSignature.Parameter.StartBundleContextParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.FinishBundleContextParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.ProcessContextParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.ElementParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.SchemaElementParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.TimestampParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.TimeDomainParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.OutputReceiverParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.TaggedOutputReceiverParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.OnTimerContextParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.WindowParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.PaneInfoParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.RestrictionParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.RestrictionTrackerParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.WatermarkEstimatorParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.WatermarkEstimatorStateParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.StateParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.TimerParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.PipelineOptionsParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.SideInputParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.TimerFamilyParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.TimerIdParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.BundleFinalizerParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.KeyParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
 
dispatch(DoFnSignature.Parameter.StartBundleContextParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.FinishBundleContextParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.ProcessContextParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.ElementParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.SchemaElementParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.TaggedOutputReceiverParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.OutputReceiverParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.TimestampParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.TimerIdParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.TimeDomainParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.OnTimerContextParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.WindowParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.PaneInfoParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.RestrictionParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.RestrictionTrackerParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.WatermarkEstimatorParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.WatermarkEstimatorStateParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.BundleFinalizerParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.StateParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.TimerParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.PipelineOptionsParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.SideInputParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.TimerFamilyParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatch(DoFnSignature.Parameter.KeyParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatchBag(Coder<?>) - Method in interface org.apache.beam.sdk.state.StateSpec.Cases
 
dispatchBag(Coder<?>) - Method in class org.apache.beam.sdk.state.StateSpec.Cases.WithDefault
 
dispatchCombining(Combine.CombineFn<?, ?, ?>, Coder<?>) - Method in interface org.apache.beam.sdk.state.StateSpec.Cases
 
dispatchCombining(Combine.CombineFn<?, ?, ?>, Coder<?>) - Method in class org.apache.beam.sdk.state.StateSpec.Cases.WithDefault
 
dispatchDefault() - Method in class org.apache.beam.sdk.state.StateSpec.Cases.WithDefault
 
dispatchDefault(DoFnSignature.Parameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
dispatchMap(Coder<?>, Coder<?>) - Method in interface org.apache.beam.sdk.state.StateSpec.Cases
 
dispatchMap(Coder<?>, Coder<?>) - Method in class org.apache.beam.sdk.state.StateSpec.Cases.WithDefault
 
dispatchOrderedList(Coder<?>) - Method in interface org.apache.beam.sdk.state.StateSpec.Cases
 
dispatchSet(Coder<?>) - Method in interface org.apache.beam.sdk.state.StateSpec.Cases
 
dispatchSet(Coder<?>) - Method in class org.apache.beam.sdk.state.StateSpec.Cases.WithDefault
 
dispatchValue(Coder<?>) - Method in interface org.apache.beam.sdk.state.StateSpec.Cases
 
dispatchValue(Coder<?>) - Method in class org.apache.beam.sdk.state.StateSpec.Cases.WithDefault
 
DisplayData - Class in org.apache.beam.sdk.transforms.display
Static display data associated with a pipeline component.
DisplayData.Builder - Interface in org.apache.beam.sdk.transforms.display
Utility to build up display data from a component and its included subcomponents.
DisplayData.Identifier - Class in org.apache.beam.sdk.transforms.display
Unique identifier for a display data item within a component.
DisplayData.Item - Class in org.apache.beam.sdk.transforms.display
Items are the unit of display data.
DisplayData.ItemSpec<T> - Class in org.apache.beam.sdk.transforms.display
Specifies an DisplayData.Item to register as display data.
DisplayData.Path - Class in org.apache.beam.sdk.transforms.display
Structured path of registered display data within a component hierarchy.
DisplayData.Type - Enum in org.apache.beam.sdk.transforms.display
Display data type.
Distinct<T> - Class in org.apache.beam.sdk.transforms
Distinct<T> takes a PCollection<T> and returns a PCollection<T> that has all distinct elements of the input.
Distinct() - Constructor for class org.apache.beam.sdk.transforms.Distinct
 
Distinct.WithRepresentativeValues<T,IdT> - Class in org.apache.beam.sdk.transforms
A Distinct PTransform that uses a SerializableFunction to obtain a representative value for each input element.
Distribution - Interface in org.apache.beam.sdk.metrics
A metric that reports information about the distribution of reported values.
distribution(String, String) - Static method in class org.apache.beam.sdk.metrics.Metrics
Create a metric that records various statistics about the distribution of reported values.
distribution(Class<?>, String) - Static method in class org.apache.beam.sdk.metrics.Metrics
Create a metric that records various statistics about the distribution of reported values.
DistributionResult - Class in org.apache.beam.sdk.metrics
The result of a Distribution metric.
DistributionResult() - Constructor for class org.apache.beam.sdk.metrics.DistributionResult
 
doChecks(PAssert.PAssertionSite, ActualT, SerializableFunction<ActualT, Void>) - Static method in class org.apache.beam.sdk.testing.PAssert
 
DoFn<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
The argument to ParDo providing the code to use to process elements of the input PCollection.
DoFn() - Constructor for class org.apache.beam.sdk.transforms.DoFn
 
DoFn.AlwaysFetched - Annotation Type in org.apache.beam.sdk.transforms
Annotation for declaring that a state parameter is always fetched.
DoFn.BoundedPerElement - Annotation Type in org.apache.beam.sdk.transforms
Annotation on a splittable DoFn specifying that the DoFn performs a bounded amount of work per input element, so applying it to a bounded PCollection will produce also a bounded PCollection.
DoFn.BundleFinalizer - Interface in org.apache.beam.sdk.transforms
A parameter that is accessible during @StartBundle, @ProcessElement and @FinishBundle that 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 - Interface in org.apache.beam.sdk.transforms
An instance of a function that will be invoked after bundle finalization.
DoFn.Element - Annotation Type in org.apache.beam.sdk.transforms
DoFn.FieldAccess - Annotation Type in org.apache.beam.sdk.transforms
Annotation for specifying specific fields that are accessed in a Schema PCollection.
DoFn.FinishBundle - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method to use to finish processing a batch of elements.
DoFn.FinishBundleContext - Class in org.apache.beam.sdk.transforms
Information accessible while within the DoFn.FinishBundle method.
DoFn.GetInitialRestriction - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method that maps an element to an initial restriction for a splittable DoFn.
DoFn.GetInitialWatermarkEstimatorState - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method that maps an element and restriction to initial watermark estimator state for a splittable DoFn.
DoFn.GetRestrictionCoder - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method that returns the coder to use for the restriction of a splittable DoFn.
DoFn.GetSize - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method that returns the corresponding size for an element and restriction pair.
DoFn.GetWatermarkEstimatorStateCoder - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method that returns the coder to use for the watermark estimator state of a splittable DoFn.
DoFn.Key - Annotation Type in org.apache.beam.sdk.transforms
Parameter annotation for dereferencing input element key in KV pair.
DoFn.MultiOutputReceiver - Interface in org.apache.beam.sdk.transforms
Receives tagged output for a multi-output function.
DoFn.NewTracker - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method that creates a new RestrictionTracker for the restriction of a splittable DoFn.
DoFn.NewWatermarkEstimator - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method that creates a new WatermarkEstimator for the watermark state of a splittable DoFn.
DoFn.OnTimer - Annotation Type in org.apache.beam.sdk.transforms
Annotation for registering a callback for a timer.
DoFn.OnTimerContext - Class in org.apache.beam.sdk.transforms
Information accessible when running a DoFn.OnTimer method.
DoFn.OnTimerFamily - Annotation Type in org.apache.beam.sdk.transforms
Annotation for registering a callback for a timerFamily.
DoFn.OnWindowExpiration - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method to use for performing actions on window expiration.
DoFn.OnWindowExpirationContext - Class in org.apache.beam.sdk.transforms
 
DoFn.OutputReceiver<T> - Interface in org.apache.beam.sdk.transforms
Receives values of the given type.
DoFn.ProcessContext - Class in org.apache.beam.sdk.transforms
Information accessible when running a DoFn.ProcessElement method.
DoFn.ProcessContinuation - Class in org.apache.beam.sdk.transforms
When used as a return value of DoFn.ProcessElement, indicates whether there is more work to be done for the current element.
DoFn.ProcessElement - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method to use for processing elements.
DoFn.RequiresStableInput - Annotation Type in org.apache.beam.sdk.transforms
Experimental - no backwards compatibility guarantees.
DoFn.RequiresTimeSortedInput - Annotation Type in org.apache.beam.sdk.transforms
Experimental - no backwards compatibility guarantees.
DoFn.Restriction - Annotation Type in org.apache.beam.sdk.transforms
DoFn.Setup - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method to use to prepare an instance for processing bundles of elements.
DoFn.SideInput - Annotation Type in org.apache.beam.sdk.transforms
Parameter annotation for the SideInput for a DoFn.ProcessElement method.
DoFn.SplitRestriction - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method that splits restriction of a splittable DoFn into multiple parts to be processed in parallel.
DoFn.StartBundle - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method to use to prepare an instance for processing a batch of elements.
DoFn.StartBundleContext - Class in org.apache.beam.sdk.transforms
Information accessible while within the DoFn.StartBundle method.
DoFn.StateId - Annotation Type in org.apache.beam.sdk.transforms
Annotation for declaring and dereferencing state cells.
DoFn.Teardown - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method to use to clean up this instance before it is discarded.
DoFn.TimerFamily - Annotation Type in org.apache.beam.sdk.transforms
Parameter annotation for the TimerMap for a DoFn.ProcessElement method.
DoFn.TimerId - Annotation Type in org.apache.beam.sdk.transforms
Annotation for declaring and dereferencing timers.
DoFn.Timestamp - Annotation Type in org.apache.beam.sdk.transforms
DoFn.TruncateRestriction - Annotation Type in org.apache.beam.sdk.transforms
Annotation for the method that truncates the restriction of a splittable DoFn into a bounded one.
DoFn.UnboundedPerElement - Annotation Type in org.apache.beam.sdk.transforms
Annotation on a splittable DoFn specifying that the DoFn performs an unbounded amount of work per input element, so applying it to a bounded PCollection will produce an unbounded PCollection.
DoFn.WatermarkEstimatorState - Annotation Type in org.apache.beam.sdk.transforms
Parameter annotation for the watermark estimator state for the DoFn.NewWatermarkEstimator method.
DoFn.WindowedContext - Class in org.apache.beam.sdk.transforms
Information accessible to all methods in this DoFn where the context is in some window.
DoFnInfo<InputT,OutputT> - Class in org.apache.beam.sdk.util
Wrapper class holding the necessary information to serialize a DoFn.
DoFnInvoker<InputT,OutputT> - Interface in org.apache.beam.sdk.transforms.reflect
Interface for invoking the DoFn processing methods.
DoFnInvoker.ArgumentProvider<InputT,OutputT> - Interface in org.apache.beam.sdk.transforms.reflect
Interface for runner implementors to provide implementations of extra context information.
DoFnInvoker.BaseArgumentProvider<InputT,OutputT> - Class in org.apache.beam.sdk.transforms.reflect
This DoFnInvoker.ArgumentProvider throws UnsupportedOperationException for all parameters.
DoFnInvoker.DelegatingArgumentProvider<InputT,OutputT> - Class in org.apache.beam.sdk.transforms.reflect
An DoFnInvoker.ArgumentProvider that forwards all calls to the supplied delegate.
DoFnInvoker.FakeArgumentProvider<InputT,OutputT> - Class in org.apache.beam.sdk.transforms.reflect
A fake DoFnInvoker.ArgumentProvider used during testing.
DoFnInvokers - Class in org.apache.beam.sdk.transforms.reflect
Static utilities for working with DoFnInvoker.
DoFnOutputReceivers - Class in org.apache.beam.sdk.transforms
DoFnOutputReceivers() - Constructor for class org.apache.beam.sdk.transforms.DoFnOutputReceivers
 
DoFnSchemaInformation - Class in org.apache.beam.sdk.transforms
Represents information about how a DoFn extracts schemas.
DoFnSchemaInformation() - Constructor for class org.apache.beam.sdk.transforms.DoFnSchemaInformation
 
DoFnSchemaInformation.Builder - Class in org.apache.beam.sdk.transforms
The builder object.
DoFnSignature - Class in org.apache.beam.sdk.transforms.reflect
Describes the signature of a DoFn, in particular, which features it uses, which extra context it requires, types of the input and output elements, etc.
DoFnSignature() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature
 
DoFnSignature.BundleMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.StartBundle or DoFn.FinishBundle method.
DoFnSignature.DoFnMethod - Interface in org.apache.beam.sdk.transforms.reflect
A method delegated to an annotated method of an underlying DoFn.
DoFnSignature.FieldAccessDeclaration - Class in org.apache.beam.sdk.transforms.reflect
Decscribes a field access declaration.
DoFnSignature.GetInitialRestrictionMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.GetInitialRestriction method.
DoFnSignature.GetInitialWatermarkEstimatorStateMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.GetInitialWatermarkEstimatorState method.
DoFnSignature.GetRestrictionCoderMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.GetRestrictionCoder method.
DoFnSignature.GetSizeMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.GetSize method.
DoFnSignature.GetWatermarkEstimatorStateCoderMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.GetRestrictionCoder method.
DoFnSignature.LifecycleMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.Setup or DoFn.Teardown method.
DoFnSignature.MethodWithExtraParameters - Interface in org.apache.beam.sdk.transforms.reflect
A method delegated to an annotated method of an underlying DoFn that accepts a dynamic list of parameters.
DoFnSignature.NewTrackerMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.NewTracker method.
DoFnSignature.NewWatermarkEstimatorMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.NewWatermarkEstimator method.
DoFnSignature.OnTimerFamilyMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.OnTimerFamily method.
DoFnSignature.OnTimerMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.OnTimer method.
DoFnSignature.OnWindowExpirationMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.OnWindowExpiration method.
DoFnSignature.Parameter - Class in org.apache.beam.sdk.transforms.reflect
A descriptor for an optional parameter of the DoFn.ProcessElement method.
DoFnSignature.Parameter.BundleFinalizerParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type DoFn.BundleFinalizer.
DoFnSignature.Parameter.Cases<ResultT> - Interface in org.apache.beam.sdk.transforms.reflect
An interface for destructuring a DoFnSignature.Parameter.
DoFnSignature.Parameter.Cases.WithDefault<ResultT> - Class in org.apache.beam.sdk.transforms.reflect
A base class for a visitor with a default method for cases it is not interested in.
DoFnSignature.Parameter.ElementParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type DoFn.Element.
DoFnSignature.Parameter.FinishBundleContextParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type DoFn.FinishBundleContext.
DoFnSignature.Parameter.KeyParameter - Class in org.apache.beam.sdk.transforms.reflect
 
DoFnSignature.Parameter.OnTimerContextParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type DoFn.OnTimerContext.
DoFnSignature.Parameter.OnWindowExpirationContextParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type DoFn.OnWindowExpirationContext.
DoFnSignature.Parameter.OutputReceiverParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type DoFn.OutputReceiver.
DoFnSignature.Parameter.PaneInfoParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type PaneInfo.
DoFnSignature.Parameter.PipelineOptionsParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of a subtype of PipelineOptions.
DoFnSignature.Parameter.ProcessContextParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type DoFn.ProcessContext.
DoFnSignature.Parameter.RestrictionParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type DoFn.Restriction.
DoFnSignature.Parameter.RestrictionTrackerParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of a subclass of RestrictionTracker.
DoFnSignature.Parameter.SchemaElementParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a (@link Parameter} of type DoFn.Element where the type does not match the DoFn's input type.
DoFnSignature.Parameter.SchemaElementParameter.Builder - Class in org.apache.beam.sdk.transforms.reflect
Builder class.
DoFnSignature.Parameter.SideInputParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type DoFn.SideInput.
DoFnSignature.Parameter.SideInputParameter.Builder - Class in org.apache.beam.sdk.transforms.reflect
Builder class.
DoFnSignature.Parameter.StartBundleContextParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type DoFn.StartBundleContext.
DoFnSignature.Parameter.StateParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of a subclass of State, with an id indicated by its DoFn.StateId annotation.
DoFnSignature.Parameter.TaggedOutputReceiverParameter - Class in org.apache.beam.sdk.transforms.reflect
DoFnSignature.Parameter.TimeDomainParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter representing the time domain of a timer.
DoFnSignature.Parameter.TimerFamilyParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type DoFn.TimerFamily.
DoFnSignature.Parameter.TimerIdParameter - Class in org.apache.beam.sdk.transforms.reflect
 
DoFnSignature.Parameter.TimerParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type Timer, with an id indicated by its DoFn.TimerId annotation.
DoFnSignature.Parameter.TimestampParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type DoFn.Timestamp.
DoFnSignature.Parameter.WatermarkEstimatorParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type DoFn.WatermarkEstimatorState.
DoFnSignature.Parameter.WatermarkEstimatorStateParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type DoFn.WatermarkEstimatorState.
DoFnSignature.Parameter.WindowParameter - Class in org.apache.beam.sdk.transforms.reflect
Descriptor for a DoFnSignature.Parameter of type BoundedWindow.
DoFnSignature.ProcessElementMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.ProcessElement method.
DoFnSignature.SplitRestrictionMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.SplitRestriction method.
DoFnSignature.StateDeclaration - Class in org.apache.beam.sdk.transforms.reflect
Describes a state declaration; a field of type StateSpec annotated with DoFn.StateId.
DoFnSignature.TimerDeclaration - Class in org.apache.beam.sdk.transforms.reflect
Describes a timer declaration; a field of type TimerSpec annotated with DoFn.TimerId.
DoFnSignature.TimerFamilyDeclaration - Class in org.apache.beam.sdk.transforms.reflect
Describes a timer family declaration; a field of type TimerSpec annotated with DoFn.TimerFamily.
DoFnSignature.TruncateRestrictionMethod - Class in org.apache.beam.sdk.transforms.reflect
Describes a DoFn.TruncateRestriction method.
DoFnSignatures - Class in org.apache.beam.sdk.transforms.reflect
Utilities for working with DoFnSignature.
DoFnTester<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
Deprecated.
Use TestPipeline with the DirectRunner.
DoFnTester.CloningBehavior - Enum in org.apache.beam.sdk.transforms
Deprecated.
Use TestPipeline with the DirectRunner.
DoFnWithExecutionInformation - Class in org.apache.beam.sdk.util
The data that the Java SDK harness needs to execute a DoFn.
DoFnWithExecutionInformation() - Constructor for class org.apache.beam.sdk.util.DoFnWithExecutionInformation
 
dotExpression() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
dotExpression() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.FieldSpecifierContext
 
dotExpressionComponent() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
dotExpressionComponent() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionContext
 
dotExpressionComponent(int) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionContext
 
DotExpressionComponentContext(ParserRuleContext, int) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionComponentContext
 
DotExpressionComponentContext() - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionComponentContext
 
DotExpressionContext(ParserRuleContext, int) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionContext
 
DOUBLE - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
The type of double fields.
DoubleCoder - Class in org.apache.beam.sdk.coders
A DoubleCoder encodes Double values in 8 bytes using Java serialization.
doubles() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for Double.
doublesGlobally() - Static method in class org.apache.beam.sdk.transforms.Max
Returns a PTransform that takes an input PCollection<Double> and returns a PCollection<Double> whose contents is the maximum of the input PCollection's elements, or Double.NEGATIVE_INFINITY if there are no elements.
doublesGlobally() - Static method in class org.apache.beam.sdk.transforms.Min
Returns a PTransform that takes an input PCollection<Double> and returns a PCollection<Double> whose contents is the minimum of the input PCollection's elements, or Double.POSITIVE_INFINITY if there are no elements.
doublesGlobally() - Static method in class org.apache.beam.sdk.transforms.Sum
Returns a PTransform that takes an input PCollection<Double> and returns a PCollection<Double> whose contents is the sum of the input PCollection's elements, or 0 if there are no elements.
doublesPerKey() - Static method in class org.apache.beam.sdk.transforms.Max
Returns a PTransform that takes an input PCollection<KV<K, Double>> and returns a PCollection<KV<K, Double>> that contains an output element mapping each distinct key in the input PCollection to the maximum of the values associated with that key in the input PCollection.
doublesPerKey() - Static method in class org.apache.beam.sdk.transforms.Min
Returns a PTransform that takes an input PCollection<KV<K, Double>> and returns a PCollection<KV<K, Double>> that contains an output element mapping each distinct key in the input PCollection to the minimum of the values associated with that key in the input PCollection.
doublesPerKey() - Static method in class org.apache.beam.sdk.transforms.Sum
Returns a PTransform that takes an input PCollection<KV<K, Double>> and returns a PCollection<KV<K, Double>> that contains an output element mapping each distinct key in the input PCollection to the sum of the values associated with that key in the input PCollection.
DropFields - Class in org.apache.beam.sdk.schemas.transforms
A transform to drop fields from a schema.
DropFields() - Constructor for class org.apache.beam.sdk.schemas.transforms.DropFields
 
DropFields.Inner<T> - Class in org.apache.beam.sdk.schemas.transforms
Implementation class for DropFields.
DurationCoder - Class in org.apache.beam.sdk.coders
A Coder that encodes a joda Duration as a Long using the format of VarLongCoder.
durationMilliSec - Variable in class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
 
DynamicAvroDestinations<UserT,DestinationT,OutputT> - Class in org.apache.beam.sdk.io
A specialization of FileBasedSink.DynamicDestinations for AvroIO.
DynamicAvroDestinations() - Constructor for class org.apache.beam.sdk.io.DynamicAvroDestinations
 
DynamicDestinations() - Constructor for class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
 
DynamicFileDestinations - Class in org.apache.beam.sdk.io
Some helper classes that derive from FileBasedSink.DynamicDestinations.
DynamicFileDestinations() - Constructor for class org.apache.beam.sdk.io.DynamicFileDestinations
 

E

eitherOf(Watch.Growth.TerminationCondition<InputT, FirstStateT>, Watch.Growth.TerminationCondition<InputT, SecondStateT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
Returns a Watch.Growth.TerminationCondition that holds when at least one of the given two conditions holds.
element() - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContext
Returns the input element to be processed.
element(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provide a reference to the input element.
element(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
element(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
element() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn.AssignContext
Returns the current element.
element() - Method in class org.apache.beam.sdk.transforms.WithFailures.ExceptionElement
 
ElementByteSizeObservableIterable<V,InputT extends ElementByteSizeObservableIterator<V>> - Class in org.apache.beam.sdk.util.common
An abstract class used for iterables that notify observers about size in bytes of their elements, as they are being iterated over.
ElementByteSizeObservableIterable() - Constructor for class org.apache.beam.sdk.util.common.ElementByteSizeObservableIterable
 
ElementByteSizeObservableIterator<V> - Class in org.apache.beam.sdk.util.common
An abstract class used for iterators that notify observers about size in bytes of their elements, as they are being iterated over.
ElementByteSizeObservableIterator() - Constructor for class org.apache.beam.sdk.util.common.ElementByteSizeObservableIterator
 
ElementByteSizeObserver - Class in org.apache.beam.sdk.util.common
An observer that gets notified when additional bytes are read and/or used.
ElementByteSizeObserver() - Constructor for class org.apache.beam.sdk.util.common.ElementByteSizeObserver
 
elementCountAtLeast(int) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterPane
Creates a trigger that fires when the pane contains at least countElems elements.
ElementEvent() - Constructor for class org.apache.beam.sdk.testing.TestStream.ElementEvent
 
elementParameter(TypeDescriptor<?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
 
elements() - Static method in class org.apache.beam.sdk.transforms.ToString
Transforms each element of the input PCollection to a String using the Object.toString() method.
elementsRead() - Static method in class org.apache.beam.sdk.metrics.SourceMetrics
Counter of elements read by a source.
elementsReadBySplit(String) - Static method in class org.apache.beam.sdk.metrics.SourceMetrics
Counter of elements read by a source split.
elementsWritten() - Static method in class org.apache.beam.sdk.metrics.SinkMetrics
Counter of elements written to a sink.
elementT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.ElementParameter
 
elementT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter
 
elementT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SideInputParameter
 
EMPTY - Static variable in class org.apache.beam.sdk.io.range.ByteKey
An empty key.
empty() - Static method in class org.apache.beam.sdk.metrics.GaugeResult
 
EMPTY - Static variable in class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
 
empty() - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
Asserts that the iterable in question is empty.
empty() - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
 
empty() - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.empty().
empty(Schema) - Static method in class org.apache.beam.sdk.transforms.Create
Returns a new Create.Values transform that produces an empty PCollection of rows.
empty(Coder<T>) - Static method in class org.apache.beam.sdk.transforms.Create
Returns a new Create.Values transform that produces an empty PCollection.
empty(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.transforms.Create
Returns a new Create.Values transform that produces an empty PCollection.
empty() - Static method in class org.apache.beam.sdk.transforms.join.CoGbkResult
Returns an empty CoGbkResult.
empty(Pipeline) - Static method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
Returns an empty KeyedPCollectionTuple<K> on the given pipeline.
empty() - Static method in class org.apache.beam.sdk.transforms.Requirements
Describes an empty set of requirements.
empty() - Static method in class org.apache.beam.sdk.util.ApiSurface
Returns an empty ApiSurface.
empty(Pipeline) - Static method in class org.apache.beam.sdk.values.PCollectionList
Returns an empty PCollectionList that is part of the given Pipeline.
empty(Pipeline) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
Returns an empty PCollectionTuple that is part of the given Pipeline.
empty() - Static method in class org.apache.beam.sdk.values.TupleTagList
Returns an empty TupleTagList.
emptyArray() - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.emptyArray().
emptyIterable() - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.emptyIterable().
EmptyMatchTreatment - Enum in org.apache.beam.sdk.io.fs
Options for allowing or disallowing filepatterns that match no resources in FileSystems.match(java.util.List<java.lang.String>).
EmptyOnDeserializationThreadLocal<T> - Class in org.apache.beam.sdk.util
A Serializable ThreadLocal which discards any "stored" objects.
EmptyOnDeserializationThreadLocal() - Constructor for class org.apache.beam.sdk.util.EmptyOnDeserializationThreadLocal
 
enableAbandonedNodeEnforcement(boolean) - Method in class org.apache.beam.sdk.testing.TestPipeline
Enables the abandoned node detection.
enableAutoRunIfMissing(boolean) - Method in class org.apache.beam.sdk.testing.TestPipeline
If enabled, a pipeline.run() statement will be added automatically in case it is missing in the test.
encode(T, OutputStream) - Method in class org.apache.beam.sdk.coders.AvroCoder
 
encode(BigDecimal, OutputStream) - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
 
encode(BigDecimal, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
 
encode(Integer, OutputStream) - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
 
encode(Long, OutputStream) - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
 
encode(Short, OutputStream) - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
 
encode(BigInteger, OutputStream) - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
 
encode(BigInteger, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
 
encode(BitSet, OutputStream) - Method in class org.apache.beam.sdk.coders.BitSetCoder
 
encode(BitSet, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.BitSetCoder
 
encode(Boolean, OutputStream) - Method in class org.apache.beam.sdk.coders.BooleanCoder
 
encode(byte[], OutputStream) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
 
encode(byte[], OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
 
encode(Byte, OutputStream) - Method in class org.apache.beam.sdk.coders.ByteCoder
 
encode(T, OutputStream) - Method in class org.apache.beam.sdk.coders.Coder
Encodes the given value of type T onto the given output stream.
encode(T, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.Coder
Deprecated.
encode(T, OutputStream) - Method in class org.apache.beam.sdk.coders.DelegateCoder
 
encode(T, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.DelegateCoder
 
encode(Double, OutputStream) - Method in class org.apache.beam.sdk.coders.DoubleCoder
 
encode(ReadableDuration, OutputStream) - Method in class org.apache.beam.sdk.coders.DurationCoder
 
encode(Float, OutputStream) - Method in class org.apache.beam.sdk.coders.FloatCoder
 
encode(Instant, OutputStream) - Method in class org.apache.beam.sdk.coders.InstantCoder
 
encode(IterableT, OutputStream) - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
 
encode(KV<K, V>, OutputStream) - Method in class org.apache.beam.sdk.coders.KvCoder
 
encode(KV<K, V>, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.KvCoder
 
encode(T, OutputStream) - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
 
encode(Map<K, V>, OutputStream) - Method in class org.apache.beam.sdk.coders.MapCoder
 
encode(Map<K, V>, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.MapCoder
 
encode(T, OutputStream) - Method in class org.apache.beam.sdk.coders.NullableCoder
 
encode(T, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.NullableCoder
 
encode(T, OutputStream) - Method in class org.apache.beam.sdk.coders.SerializableCoder
 
encode(ShardedKey<KeyT>, OutputStream) - Method in class org.apache.beam.sdk.coders.ShardedKeyCoder
 
encode(T, OutputStream) - Method in class org.apache.beam.sdk.coders.SnappyCoder
 
encode(T, OutputStream) - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
 
encode(T, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
 
encode(String, OutputStream) - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
 
encode(String, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
 
encode(Integer, OutputStream) - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
 
encode(Integer, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
 
encode(Integer, OutputStream) - Method in class org.apache.beam.sdk.coders.VarIntCoder
 
encode(Long, OutputStream) - Method in class org.apache.beam.sdk.coders.VarLongCoder
 
encode(Void, OutputStream) - Method in class org.apache.beam.sdk.coders.VoidCoder
 
encode(DefaultFilenamePolicy.Params, OutputStream) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.ParamsCoder
 
encode(FileBasedSink.FileResult<DestinationT>, OutputStream) - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResultCoder
 
encode(MatchResult.Metadata, OutputStream) - Method in class org.apache.beam.sdk.io.fs.MetadataCoder
 
encode(MatchResult.Metadata, OutputStream) - Method in class org.apache.beam.sdk.io.fs.MetadataCoderV2
 
encode(ResourceId, OutputStream) - Method in class org.apache.beam.sdk.io.fs.ResourceIdCoder
 
encode(OffsetRange, OutputStream) - Method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
 
encode(FileIO.ReadableFile, OutputStream) - Method in class org.apache.beam.sdk.io.ReadableFileCoder
 
encode(T, OutputStream) - Method in class org.apache.beam.sdk.schemas.SchemaCoder
 
encode(TestStream<T>, OutputStream) - Method in class org.apache.beam.sdk.testing.TestStream.TestStreamCoder
 
encode(CoGbkResult, OutputStream) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
 
encode(RawUnionValue, OutputStream) - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
 
encode(RawUnionValue, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
 
encode(GlobalWindow, OutputStream) - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindow.Coder
 
encode(IntervalWindow, OutputStream) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
 
encode(PaneInfo, OutputStream) - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo.PaneInfoCoder
 
encode(BitSet, OutputStream) - Method in class org.apache.beam.sdk.util.BitSetCoder
Deprecated.
 
encode(BitSet, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.util.BitSetCoder
Deprecated.
 
encode(ShardedKey<K>, OutputStream) - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
 
encode(int, OutputStream) - Static method in class org.apache.beam.sdk.util.VarInt
Encodes the given value onto the stream.
encode(long, OutputStream) - Static method in class org.apache.beam.sdk.util.VarInt
Encodes the given value onto the stream.
encode(WindowedValue<T>, OutputStream) - Method in class org.apache.beam.sdk.util.WindowedValue.FullWindowedValueCoder
 
encode(WindowedValue<T>, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.util.WindowedValue.FullWindowedValueCoder
 
encode(WindowedValue<T>, OutputStream) - Method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
 
encode(WindowedValue<T>, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
 
encode(WindowedValue<T>, OutputStream) - Method in class org.apache.beam.sdk.util.WindowedValue.ValueOnlyWindowedValueCoder
Deprecated.
 
encode(WindowedValue<T>, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.util.WindowedValue.ValueOnlyWindowedValueCoder
Deprecated.
 
encode(FailsafeValueInSingleWindow<T, ErrorT>, OutputStream) - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow.Coder
 
encode(FailsafeValueInSingleWindow<T, ErrorT>, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow.Coder
 
encode(PCollectionViews.ValueOrMetadata<T, MetaT>, OutputStream) - Method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadataCoder
 
encode(TimestampedValue<T>, OutputStream) - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
 
encode(ValueInSingleWindow<T>, OutputStream) - Method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
 
encode(ValueInSingleWindow<T>, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
 
encode(ValueWithRecordId<ValueT>, OutputStream) - Method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
 
encode(ValueWithRecordId<ValueT>, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
 
encodeAndOwn(byte[], OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
Encodes the provided value with the identical encoding to ByteArrayCoder.encode(byte[], java.io.OutputStream), but with optimizations that take ownership of the value.
encodeToBase64(Coder<T>, T) - Static method in class org.apache.beam.sdk.util.CoderUtils
Encodes the given value using the specified Coder, and returns the Base64 encoding of the encoded bytes.
encodeToByteArray(Coder<T>, T) - Static method in class org.apache.beam.sdk.util.CoderUtils
Encodes the given value using the specified Coder, and returns the encoded bytes.
encodeToByteArray(Coder<T>, T, Coder.Context) - Static method in class org.apache.beam.sdk.util.CoderUtils
 
end() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
Returns the end of this window, exclusive.
endsWith(String) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.endsWith(java.lang.String).
ensureSerializable(T) - Static method in class org.apache.beam.sdk.util.SerializableUtils
 
ensureSerializable(Coder<?>) - Static method in class org.apache.beam.sdk.util.SerializableUtils
Serializes a Coder and verifies that it can be correctly deserialized.
ensureSerializableByCoder(Coder<T>, T, String) - Static method in class org.apache.beam.sdk.util.SerializableUtils
Serializes an arbitrary T with the given Coder<T> and verifies that it can be correctly deserialized.
ensureSerializableRoundTrip(T) - Static method in class org.apache.beam.sdk.util.SerializableUtils
 
enterArrayQualifier(FieldSpecifierNotationParser.ArrayQualifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Enter a parse tree produced by FieldSpecifierNotationParser.arrayQualifier().
enterArrayQualifier(FieldSpecifierNotationParser.ArrayQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Enter a parse tree produced by FieldSpecifierNotationParser.arrayQualifier().
enterArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Enter a parse tree produced by the arrayQualifierList labeled alternative in FieldSpecifierNotationParser.qualifierList().
enterArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Enter a parse tree produced by the arrayQualifierList labeled alternative in FieldSpecifierNotationParser.qualifierList().
enterCompositeTransform(TransformHierarchy.Node) - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
 
enterCompositeTransform(TransformHierarchy.Node) - Method in interface org.apache.beam.sdk.Pipeline.PipelineVisitor
Called for each composite transform after all topological predecessors have been visited but before any of its component transforms.
enterDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Enter a parse tree produced by FieldSpecifierNotationParser.dotExpression().
enterDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Enter a parse tree produced by FieldSpecifierNotationParser.dotExpression().
enterEveryRule(ParserRuleContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
enterFieldSpecifier(FieldSpecifierNotationParser.FieldSpecifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Enter a parse tree produced by FieldSpecifierNotationParser.fieldSpecifier().
enterFieldSpecifier(FieldSpecifierNotationParser.FieldSpecifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Enter a parse tree produced by FieldSpecifierNotationParser.fieldSpecifier().
enterMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Enter a parse tree produced by FieldSpecifierNotationParser.mapQualifier().
enterMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Enter a parse tree produced by FieldSpecifierNotationParser.mapQualifier().
enterMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Enter a parse tree produced by the mapQualifierList labeled alternative in FieldSpecifierNotationParser.qualifierList().
enterMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Enter a parse tree produced by the mapQualifierList labeled alternative in FieldSpecifierNotationParser.qualifierList().
enterPipeline(Pipeline) - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
 
enterPipeline(Pipeline) - Method in interface org.apache.beam.sdk.Pipeline.PipelineVisitor
Called before visiting anything values or transforms, as many uses of a visitor require access to the Pipeline object itself.
enterQualifiedComponent(FieldSpecifierNotationParser.QualifiedComponentContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
enterQualifiedComponent(FieldSpecifierNotationParser.QualifiedComponentContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
enterQualifyComponent(FieldSpecifierNotationParser.QualifyComponentContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Enter a parse tree produced by the qualifyComponent labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
enterQualifyComponent(FieldSpecifierNotationParser.QualifyComponentContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Enter a parse tree produced by the qualifyComponent labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierContext
 
enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierListContext
 
enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionContext
 
enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.FieldSpecifierContext
 
enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierContext
 
enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierListContext
 
enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
 
enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifyComponentContext
 
enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.SimpleIdentifierContext
 
enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.WildcardContext
 
enterSimpleIdentifier(FieldSpecifierNotationParser.SimpleIdentifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Enter a parse tree produced by the simpleIdentifier labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
enterSimpleIdentifier(FieldSpecifierNotationParser.SimpleIdentifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Enter a parse tree produced by the simpleIdentifier labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
enterWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Enter a parse tree produced by the wildcard labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
enterWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Enter a parse tree produced by the wildcard labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
entries() - Method in interface org.apache.beam.sdk.state.MapState
Returns an Iterable over the key-value pairs contained in this map.
entrySet() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
EnumerationType - Class in org.apache.beam.sdk.schemas.logicaltypes
This Schema.LogicalType represent an enumeration over a fixed set of values.
EnumerationType.Value - Class in org.apache.beam.sdk.schemas.logicaltypes
This class represents a single enum value.
equal(T) - Static method in class org.apache.beam.sdk.transforms.Filter
Returns a PTransform that takes an input PCollection<T> and returns a PCollection<T> with elements that equals to a given value.
equals(Object) - Method in class org.apache.beam.sdk.coders.AtomicCoder
.
equals(Object) - Method in class org.apache.beam.sdk.coders.AvroCoder
 
equals(Object) - Method in class org.apache.beam.sdk.coders.Coder.Context
Deprecated.
 
equals(Object) - Method in class org.apache.beam.sdk.coders.DelegateCoder
 
equals(Object) - Method in class org.apache.beam.sdk.coders.RowCoder
 
equals(Object) - Method in class org.apache.beam.sdk.coders.SerializableCoder
 
equals(Object) - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
 
equals(Object) - Method in class org.apache.beam.sdk.coders.StructuralByteArray
 
equals(Object) - Method in class org.apache.beam.sdk.coders.StructuredCoder
equals(Object) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
 
equals(Object) - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
 
equals(Object) - Method in class org.apache.beam.sdk.io.range.ByteKey
 
equals(Object) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
 
equals(Object) - Method in class org.apache.beam.sdk.io.range.OffsetRange
 
equals(Object) - Method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
 
equals(Object) - Method in class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
 
equals(Object) - Method in class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
 
equals(Object) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
 
equals(Object) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema
 
equals(Object) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema.GetterTypeSupplier
 
equals(Object) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema.SetterTypeSupplier
 
equals(Object) - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType.Value
 
equals(Object) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
 
equals(Object) - Method in class org.apache.beam.sdk.schemas.Schema
Returns true if two Schemas have the same fields in the same order.
equals(Object) - Method in class org.apache.beam.sdk.schemas.Schema.Field
 
equals(Object) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
equals(Object) - Method in class org.apache.beam.sdk.schemas.Schema.Options
 
equals(Object) - Method in class org.apache.beam.sdk.schemas.SchemaCoder
 
equals(Object) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
equals(Object) - Method in class org.apache.beam.sdk.testing.PAssert.PAssertionSite
 
equals(Object) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
Deprecated.
Object.equals(Object) is not supported on PAssert objects. If you meant to test object equality, use a variant of PAssert.PCollectionContentsAssert.containsInAnyOrder(T...) instead.
equals(Object) - Method in class org.apache.beam.sdk.testing.SuccessOrFailure
 
equals(Object) - Method in class org.apache.beam.sdk.testing.TestStream
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique
Deprecated.
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.CombineFns.CoCombineResult
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.display.DisplayData
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.join.RawUnionValue
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindow
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
 
equals(Object) - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
 
equals(Object) - Method in class org.apache.beam.sdk.util.SerializableThrowable
 
equals(Object) - Method in class org.apache.beam.sdk.util.ShardedKey
 
equals(Object) - Method in class org.apache.beam.sdk.util.UnownedInputStream
 
equals(Object) - Method in class org.apache.beam.sdk.util.UnownedOutputStream
 
equals(Object) - Method in class org.apache.beam.sdk.util.WindowedValue
 
equals(Object) - Method in class org.apache.beam.sdk.values.KV
 
equals(Object) - Method in class org.apache.beam.sdk.values.PCollectionList
 
equals(Object) - Method in class org.apache.beam.sdk.values.PCollectionTuple
 
equals(Object) - Method in class org.apache.beam.sdk.values.PCollectionViews.ListViewFn
Deprecated.
 
equals(Object) - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
 
equals(Object) - Method in class org.apache.beam.sdk.values.Row
 
Equals() - Constructor for class org.apache.beam.sdk.values.Row.Equals
 
equals(Object) - Method in class org.apache.beam.sdk.values.RowWithGetters
 
equals(Object) - Method in class org.apache.beam.sdk.values.ShardedKey
 
equals(Object) - Method in class org.apache.beam.sdk.values.TimestampedValue
 
equals(Object) - Method in class org.apache.beam.sdk.values.TupleTag
 
equals(Object) - Method in class org.apache.beam.sdk.values.TypeDescriptor
Two type descriptor are equal if and only if they represent the same type.
equals(Object) - Method in class org.apache.beam.sdk.values.TypeParameter
 
equals(Object) - Method in class org.apache.beam.sdk.values.ValueWithRecordId
 
equals(Object) - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
equalTo(T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.equalTo(Object).
equalTo(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.equalTo(Object).
equivalent(Schema) - Method in class org.apache.beam.sdk.schemas.Schema
Returns true if two Schemas have the same fields, but possibly in different orders.
equivalent(Schema.FieldType, Schema.EquivalenceNullablePolicy) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
Check whether two types are equivalent.
ERROR_ROW_SCHEMA - Static variable in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
 
ERROR_ROW_WITH_ERR_MSG_SCHEMA - Static variable in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
 
estimate() - Method in interface org.apache.beam.sdk.transforms.splittabledofn.GrowableOffsetRangeTracker.RangeEndEstimator
 
estimateFractionForKey(ByteKey) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
Returns the fraction of this range [startKey, endKey) that is in the interval [startKey, key).
estimateRowCount(PipelineOptions) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
Estimates the number of non empty rows.
estimatorStateT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.WatermarkEstimatorStateParameter
 
estimatorT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.WatermarkEstimatorParameter
 
ever() - Static method in class org.apache.beam.sdk.transforms.windowing.Never
Returns a trigger which never fires.
every(Duration) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
Returns a new SlidingWindows with the original size, that assigns timestamps into half-open intervals of the form [N * period, N * period + size), where 0 is the epoch.
exceptAll(PCollection<T>) - Static method in class org.apache.beam.sdk.transforms.Sets
Returns a new PTransform transform that follows SET ALL semantics to compute the difference all (exceptAll) with provided PCollection<T>.
exceptAll() - Static method in class org.apache.beam.sdk.transforms.Sets
Returns a new PTransform transform that follows SET ALL semantics which takes a PCollectionList<PCollection<T>> and returns a PCollection<T> containing the difference all (exceptAll) of collections done in order for all collections in PCollectionList<T>.
exceptDistinct(PCollection<T>) - Static method in class org.apache.beam.sdk.transforms.Sets
Returns a new PTransform transform that follows SET DISTINCT semantics to compute the difference (except) with provided PCollection<T>.
exceptDistinct() - Static method in class org.apache.beam.sdk.transforms.Sets
Returns a PTransform that takes a PCollectionList<PCollection<T>> and returns a PCollection<T> containing the difference (except) of collections done in order for all collections in PCollectionList<T>.
exception() - Method in class org.apache.beam.sdk.transforms.WithFailures.ExceptionElement
 
exception(Throwable) - Static method in class org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult
 
ExceptionAsMapHandler() - Constructor for class org.apache.beam.sdk.transforms.WithFailures.ExceptionAsMapHandler
 
ExceptionElement() - Constructor for class org.apache.beam.sdk.transforms.WithFailures.ExceptionElement
 
ExceptionOrResult() - Constructor for class org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult
 
exceptionsInto(TypeDescriptor<NewFailureT>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
Returns a new FlatMapElements.FlatMapWithFailures transform that catches exceptions raised while mapping elements, with the given type descriptor used for the failure collection but the exception handler yet to be specified using FlatMapElements.FlatMapWithFailures.exceptionsVia(ProcessFunction).
exceptionsInto(TypeDescriptor<NewFailureT>) - Method in class org.apache.beam.sdk.transforms.MapElements
Returns a new MapElements.MapWithFailures transform that catches exceptions raised while mapping elements, with the given type descriptor used for the failure collection but the exception handler yet to be specified using MapElements.MapWithFailures.exceptionsVia(ProcessFunction).
exceptionsVia(InferableFunction<WithFailures.ExceptionElement<InputT>, FailureT>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
Returns a new FlatMapElements.FlatMapWithFailures transform that catches exceptions raised while mapping elements, passing the raised exception instance and the input element being processed through the given exceptionHandler and emitting the result to a failure collection.
exceptionsVia(ProcessFunction<WithFailures.ExceptionElement<InputT>, FailureT>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements.FlatMapWithFailures
Returns a new FlatMapElements.FlatMapWithFailures transform that catches exceptions raised while mapping elements, passing the raised exception instance and the input element being processed through the given exceptionHandler and emitting the result to a failure collection.
exceptionsVia(InferableFunction<WithFailures.ExceptionElement<InputT>, FailureT>) - Method in class org.apache.beam.sdk.transforms.MapElements
Returns a new MapElements.MapWithFailures transform that catches exceptions raised while mapping elements, passing the raised exception instance and the input element being processed through the given exceptionHandler and emitting the result to a failure collection.
exceptionsVia(ProcessFunction<WithFailures.ExceptionElement<InputT>, FailureT>) - Method in class org.apache.beam.sdk.transforms.MapElements.MapWithFailures
Returns a PTransform that catches exceptions raised while mapping elements, passing the raised exception instance and the input element being processed through the given exceptionHandler and emitting the result to a failure collection.
exitArrayQualifier(FieldSpecifierNotationParser.ArrayQualifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Exit a parse tree produced by FieldSpecifierNotationParser.arrayQualifier().
exitArrayQualifier(FieldSpecifierNotationParser.ArrayQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Exit a parse tree produced by FieldSpecifierNotationParser.arrayQualifier().
exitArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Exit a parse tree produced by the arrayQualifierList labeled alternative in FieldSpecifierNotationParser.qualifierList().
exitArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Exit a parse tree produced by the arrayQualifierList labeled alternative in FieldSpecifierNotationParser.qualifierList().
exitDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Exit a parse tree produced by FieldSpecifierNotationParser.dotExpression().
exitDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Exit a parse tree produced by FieldSpecifierNotationParser.dotExpression().
exitEveryRule(ParserRuleContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
exitFieldSpecifier(FieldSpecifierNotationParser.FieldSpecifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Exit a parse tree produced by FieldSpecifierNotationParser.fieldSpecifier().
exitFieldSpecifier(FieldSpecifierNotationParser.FieldSpecifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Exit a parse tree produced by FieldSpecifierNotationParser.fieldSpecifier().
exitMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Exit a parse tree produced by FieldSpecifierNotationParser.mapQualifier().
exitMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Exit a parse tree produced by FieldSpecifierNotationParser.mapQualifier().
exitMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Exit a parse tree produced by the mapQualifierList labeled alternative in FieldSpecifierNotationParser.qualifierList().
exitMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Exit a parse tree produced by the mapQualifierList labeled alternative in FieldSpecifierNotationParser.qualifierList().
exitQualifiedComponent(FieldSpecifierNotationParser.QualifiedComponentContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
exitQualifiedComponent(FieldSpecifierNotationParser.QualifiedComponentContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
exitQualifyComponent(FieldSpecifierNotationParser.QualifyComponentContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Exit a parse tree produced by the qualifyComponent labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
exitQualifyComponent(FieldSpecifierNotationParser.QualifyComponentContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Exit a parse tree produced by the qualifyComponent labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierContext
 
exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierListContext
 
exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionContext
 
exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.FieldSpecifierContext
 
exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierContext
 
exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierListContext
 
exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
 
exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifyComponentContext
 
exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.SimpleIdentifierContext
 
exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.WildcardContext
 
exitSimpleIdentifier(FieldSpecifierNotationParser.SimpleIdentifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Exit a parse tree produced by the simpleIdentifier labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
exitSimpleIdentifier(FieldSpecifierNotationParser.SimpleIdentifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Exit a parse tree produced by the simpleIdentifier labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
exitWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
Exit a parse tree produced by the wildcard labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
exitWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
Exit a parse tree produced by the wildcard labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
expand(PBegin) - Method in class org.apache.beam.sdk.io.AvroIO.Parse
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.io.AvroIO.ParseAll
Deprecated.
 
expand(PCollection<FileIO.ReadableFile>) - Method in class org.apache.beam.sdk.io.AvroIO.ParseFiles
 
expand(PBegin) - Method in class org.apache.beam.sdk.io.AvroIO.Read
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.io.AvroIO.ReadAll
Deprecated.
 
expand(PCollection<FileIO.ReadableFile>) - Method in class org.apache.beam.sdk.io.AvroIO.ReadFiles
 
expand(PCollection<UserT>) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.io.AvroIO.Write
 
expand(PBegin) - Method in class org.apache.beam.sdk.io.BoundedReadFromUnboundedSource
 
expand(PBegin) - Method in class org.apache.beam.sdk.io.FileIO.Match
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.io.FileIO.MatchAll
 
expand(PCollection<MatchResult.Metadata>) - Method in class org.apache.beam.sdk.io.FileIO.ReadMatches
 
expand(PCollection<UserT>) - Method in class org.apache.beam.sdk.io.FileIO.Write
 
expand(PBegin) - Method in class org.apache.beam.sdk.io.GenerateSequence
 
expand(PBegin) - Method in class org.apache.beam.sdk.io.Read.Bounded
 
expand(PBegin) - Method in class org.apache.beam.sdk.io.Read.Unbounded
 
expand(PCollection<FileIO.ReadableFile>) - Method in class org.apache.beam.sdk.io.ReadAllViaFileBasedSource
 
expand(PBegin) - Method in class org.apache.beam.sdk.io.TextIO.Read
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
Deprecated.
 
expand(PCollection<FileIO.ReadableFile>) - Method in class org.apache.beam.sdk.io.TextIO.ReadFiles
 
expand(PCollection<UserT>) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.io.TextIO.Write
 
expand(PBegin) - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
 
expand(PCollection<FileIO.ReadableFile>) - Method in class org.apache.beam.sdk.io.TFRecordIO.ReadFiles
 
expand(PCollection<byte[]>) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
 
expand(PCollection<UserT>) - Method in class org.apache.beam.sdk.io.WriteFiles
 
expand() - Method in class org.apache.beam.sdk.io.WriteFilesResult
 
expand(PCollection<? extends InputT>) - Method in class org.apache.beam.sdk.schemas.io.DeadLetteredTransform
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.schemas.transforms.AddFields.Inner
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.schemas.transforms.Cast
 
expand(PCollectionTuple) - Method in class org.apache.beam.sdk.schemas.transforms.CoGroup.ExpandCrossProduct
 
expand(PCollectionTuple) - Method in class org.apache.beam.sdk.schemas.transforms.CoGroup.Impl
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.schemas.transforms.DropFields.Inner
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.schemas.transforms.Filter.Inner
 
expand(PCollection<InputT>) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
 
expand(PCollection<InputT>) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
 
expand(PCollection<InputT>) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
 
expand(PCollection<InputT>) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineGlobally
 
expand(PCollection<InputT>) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
 
expand(PCollection) - Method in class org.apache.beam.sdk.schemas.transforms.Join.Impl
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.schemas.transforms.RenameFields.Inner
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.schemas.transforms.Select.Fields
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.schemas.transforms.Select.Flattened
 
expand(PCollection<SuccessOrFailure>) - Method in class org.apache.beam.sdk.testing.PAssert.DefaultConcludeTransform
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.testing.PAssert.GroupThenAssert
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.testing.PAssert.GroupThenAssertForSingleton
 
expand(PBegin) - Method in class org.apache.beam.sdk.testing.PAssert.OneSideInputAssert
 
expand(PBegin) - Method in class org.apache.beam.sdk.testing.TestStream
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.Globally
Deprecated.
 
expand(PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.PerKey
Deprecated.
 
expand(PCollection<InputT>) - Method in class org.apache.beam.sdk.transforms.Combine.Globally
 
expand(PCollection<InputT>) - Method in class org.apache.beam.sdk.transforms.Combine.GloballyAsSingletonView
 
expand(PCollection<? extends KV<K, ? extends Iterable<InputT>>>) - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
 
expand(PCollection<KV<K, InputT>>) - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
 
expand(PCollection<KV<K, InputT>>) - Method in class org.apache.beam.sdk.transforms.Combine.PerKeyWithHotKeyFanout
 
expand(PBegin) - Method in class org.apache.beam.sdk.transforms.Create.OfValueProvider
 
expand(PBegin) - Method in class org.apache.beam.sdk.transforms.Create.TimestampedValues
 
expand(PBegin) - Method in class org.apache.beam.sdk.transforms.Create.Values
 
expand(PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.Deduplicate.KeyedValues
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.Deduplicate.Values
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.Deduplicate.WithRepresentativeValues
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.Distinct
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.Distinct.WithRepresentativeValues
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.Filter
 
expand(PCollection<? extends InputT>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
 
expand(PCollection<InputT>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements.FlatMapWithFailures
 
expand(PCollection<? extends Iterable<T>>) - Method in class org.apache.beam.sdk.transforms.Flatten.Iterables
 
expand(PCollectionList<T>) - Method in class org.apache.beam.sdk.transforms.Flatten.PCollections
 
expand(PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.GroupByKey
 
expand(PCollection<KV<K, InputT>>) - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches
 
expand(PCollection<KV<K, InputT>>) - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches.WithShardedKey
 
expand(PBegin) - Method in class org.apache.beam.sdk.transforms.Impulse
 
expand(KeyedPCollectionTuple<K>) - Method in class org.apache.beam.sdk.transforms.join.CoGroupByKey
 
expand() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
Expands the component PCollections, stripping off any tag-specific information.
expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
 
expand() - Method in class org.apache.beam.sdk.transforms.JsonToRow.ParseResult
 
expand(PCollection<? extends KV<K, ?>>) - Method in class org.apache.beam.sdk.transforms.Keys
 
expand(PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.KvSwap
 
expand(PCollection<? extends InputT>) - Method in class org.apache.beam.sdk.transforms.MapElements
 
expand(PCollection<InputT>) - Method in class org.apache.beam.sdk.transforms.MapElements.MapWithFailures
 
expand(PCollection<? extends InputT>) - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
 
expand(PCollection<? extends InputT>) - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.Partition
 
expand(PBegin) - Method in class org.apache.beam.sdk.transforms.PeriodicImpulse
 
expand(PCollection<PeriodicSequence.SequenceDefinition>) - Method in class org.apache.beam.sdk.transforms.PeriodicSequence
 
expand(InputT) - Method in class org.apache.beam.sdk.transforms.PTransform
Override this method to specify how this PTransform should be expanded on the given InputT.
expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.Regex.AllMatches
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.Regex.Find
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.Regex.FindAll
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.Regex.FindKV
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.Regex.FindName
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.Regex.FindNameKV
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.Regex.Matches
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.Regex.MatchesKV
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.Regex.MatchesName
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.Regex.MatchesNameKV
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.Regex.ReplaceAll
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.Regex.ReplaceFirst
 
expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.Regex.Split
 
expand(PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.Reshuffle
Deprecated.
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.Reshuffle.ViaRandomKey
Deprecated.
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.ToJson
 
expand(PCollection<? extends KV<?, V>>) - Method in class org.apache.beam.sdk.transforms.Values
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.View.AsIterable
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.View.AsList
 
expand(PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.View.AsMap
 
expand(PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.View.AsMultimap
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.View.AsSingleton
 
expand(PCollection<ElemT>) - Method in class org.apache.beam.sdk.transforms.View.CreatePCollectionView
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.View.VoidKeyToMultimapMaterialization
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.Wait.OnSignal
 
expand(PCollection<InputT>) - Method in class org.apache.beam.sdk.transforms.Watch.Growth
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.windowing.Window.Assign
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.windowing.Window
 
expand() - Method in class org.apache.beam.sdk.transforms.WithFailures.Result
 
expand(PCollection<V>) - Method in class org.apache.beam.sdk.transforms.WithKeys
 
expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.WithTimestamps
 
expand() - Method in class org.apache.beam.sdk.values.PBegin
 
expand() - Method in class org.apache.beam.sdk.values.PCollection
 
expand() - Method in class org.apache.beam.sdk.values.PCollectionList
 
expand() - Method in class org.apache.beam.sdk.values.PCollectionTuple
 
expand() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
 
expand() - Method in class org.apache.beam.sdk.values.PDone
A PDone contains no PValues.
expand() - Method in interface org.apache.beam.sdk.values.PInput
Expands this PInput into a list of its component output PValues.
expand() - Method in interface org.apache.beam.sdk.values.POutput
Expands this POutput into a list of its component output PValues.
expand() - Method in interface org.apache.beam.sdk.values.PValue
Deprecated.
A PValue always expands into itself. Calling PValue.expand() on a PValue is almost never appropriate.
expandInput(PInput) - Static method in class org.apache.beam.sdk.values.PValues
 
expandOutput(POutput) - Static method in class org.apache.beam.sdk.values.PValues
 
expandValue(PValue) - Static method in class org.apache.beam.sdk.values.PValues
 
Experimental - Annotation Type in org.apache.beam.sdk.annotations
Signifies that a public API (public class, method or field) is subject to incompatible changes, or even removal, in a future release.
Experimental.Kind - Enum in org.apache.beam.sdk.annotations
An enumeration of various kinds of experimental APIs.
ExperimentalOptions - Interface in org.apache.beam.sdk.options
Apache Beam provides a number of experimental features that can be enabled with this flag.
ExplicitShardedFile - Class in org.apache.beam.sdk.util
A sharded file where the file names are simply provided.
ExplicitShardedFile(Collection<String>) - Constructor for class org.apache.beam.sdk.util.ExplicitShardedFile
Constructs an ExplicitShardedFile for the given files.
explodeWindows() - Method in class org.apache.beam.sdk.util.WindowedValue
Returns a collection of WindowedValues identical to this one, except each is in exactly one of the windows that this WindowedValue is in.
ExposedByteArrayInputStream - Class in org.apache.beam.sdk.util
ByteArrayInputStream that allows accessing the entire internal buffer without copying.
ExposedByteArrayInputStream(byte[]) - Constructor for class org.apache.beam.sdk.util.ExposedByteArrayInputStream
 
ExposedByteArrayOutputStream - Class in org.apache.beam.sdk.util
ByteArrayOutputStream special cased to treat writes of a single byte-array specially.
ExposedByteArrayOutputStream() - Constructor for class org.apache.beam.sdk.util.ExposedByteArrayOutputStream
 
extend(String) - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
Extend the path by appending a sub-component path.
External() - Constructor for class org.apache.beam.sdk.io.GenerateSequence.External
 
ExternalConfiguration() - Constructor for class org.apache.beam.sdk.io.GenerateSequence.External.ExternalConfiguration
 
ExternalTransformBuilder<ConfigT,InputT extends PInput,OutputT extends POutput> - Interface in org.apache.beam.sdk.transforms
An interface for building a transform from an externally provided configuration.
ExternalTransformRegistrar - Interface in org.apache.beam.sdk.expansion
A registrar which contains a mapping from URNs to available ExternalTransformBuilders.
extractFromTypeParameters(T, Class<? super T>, TypeDescriptors.TypeVariableExtractor<T, V>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
Extracts a type from the actual type parameters of a parameterized class, subject to Java type erasure.
extractFromTypeParameters(TypeDescriptor<T>, Class<? super T>, TypeDescriptors.TypeVariableExtractor<T, V>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
Like TypeDescriptors.extractFromTypeParameters(Object, Class, TypeVariableExtractor), but takes a TypeDescriptor of the instance being analyzed rather than the instance itself.
extractOutput(ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
Deprecated.
 
extractOutput() - Method in interface org.apache.beam.sdk.transforms.Combine.AccumulatingCombineFn.Accumulator
Returns the output value that is the result of combining all the input values represented by this accumulator.
extractOutput(AccumT) - Method in class org.apache.beam.sdk.transforms.Combine.AccumulatingCombineFn
 
extractOutput(double[]) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
 
extractOutput(Combine.Holder<V>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
 
extractOutput(int[]) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
 
extractOutput(long[]) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
 
extractOutput(AccumT) - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
Returns the output value that is the result of combining all the input values represented by the given accumulator.
extractOutput(List<V>) - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
 
extractOutput(Object[]) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
 
extractOutput(Object[], CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
 
extractOutput(AccumT, CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
Returns the output value that is the result of combining all the input values represented by the given accumulator.
extractOutput(Top.BoundedHeap<KV<Integer, T>, SerializableComparator<KV<Integer, T>>>) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
 
extractTimestampsFromValues() - Static method in class org.apache.beam.sdk.transforms.Reify
Extracts the timestamps from each value in a KV.
extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.BundleMethod
Types of optional parameters of the annotated method, in the order they appear.
extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialRestrictionMethod
Types of optional parameters of the annotated method, in the order they appear.
extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialWatermarkEstimatorStateMethod
Types of optional parameters of the annotated method, in the order they appear.
extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetSizeMethod
Types of optional parameters of the annotated method, in the order they appear.
extraParameters() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.MethodWithExtraParameters
Types of optional parameters of the annotated method, in the order they appear.
extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewTrackerMethod
Types of optional parameters of the annotated method, in the order they appear.
extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewWatermarkEstimatorMethod
Types of optional parameters of the annotated method, in the order they appear.
extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerFamilyMethod
Types of optional parameters of the annotated method, in the order they appear.
extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerMethod
Types of optional parameters of the annotated method, in the order they appear.
extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnWindowExpirationMethod
Types of optional parameters of the annotated method, in the order they appear.
extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
Types of optional parameters of the annotated method, in the order they appear.
extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.SplitRestrictionMethod
Types of parameters of the annotated method, in the order they appear.
extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TruncateRestrictionMethod
Types of parameters of the annotated method, in the order they appear.

F

Factory<T> - Interface in org.apache.beam.sdk.schemas
A Factory interface for schema-related objects for a specific Java type.
FailsafeValueInSingleWindow<T,ErrorT> - Class in org.apache.beam.sdk.values
An immutable tuple of value, timestamp, window, and pane.
FailsafeValueInSingleWindow() - Constructor for class org.apache.beam.sdk.values.FailsafeValueInSingleWindow
 
FailsafeValueInSingleWindow.Coder<T,ErrorT> - Class in org.apache.beam.sdk.values
Failure - Class in org.apache.beam.sdk.schemas.io
A generic failure of an SQL transform.
Failure() - Constructor for class org.apache.beam.sdk.schemas.io.Failure
 
failure(PAssert.PAssertionSite, Throwable) - Static method in class org.apache.beam.sdk.testing.SuccessOrFailure
 
Failure.Builder - Class in org.apache.beam.sdk.schemas.io
 
FAILURE_COUNTER - Static variable in class org.apache.beam.sdk.testing.PAssert
 
failures() - Method in class org.apache.beam.sdk.transforms.WithFailures.Result
 
failuresTo(List<PCollection<FailureElementT>>) - Method in class org.apache.beam.sdk.transforms.WithFailures.Result
Adds the failure collection to the passed list and returns just the output collection.
FakeArgumentProvider() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.FakeArgumentProvider
 
fewKeys() - Method in class org.apache.beam.sdk.transforms.GroupByKey
Returns whether it groups just few keys.
Field() - Constructor for class org.apache.beam.sdk.schemas.Schema.Field
 
field(String, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.transforms.AddFields.Inner
Add a new field of the specified type.
field(String, Schema.FieldType, Object) - Method in class org.apache.beam.sdk.schemas.transforms.AddFields.Inner
Add a new field of the specified type.
field() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.FieldAccessDeclaration
 
field() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.StateDeclaration
 
field() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TimerDeclaration
 
field() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TimerFamilyDeclaration
 
fieldAccess(FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.transforms.Select
Select a set of fields described in a FieldAccessDescriptor.
FieldAccessDeclaration() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.FieldAccessDeclaration
 
fieldAccessDeclarations() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Field access declaration.
FieldAccessDescriptor - Class in org.apache.beam.sdk.schemas
Used inside of a DoFn to describe which fields in a schema type need to be accessed for processing.
FieldAccessDescriptor() - Constructor for class org.apache.beam.sdk.schemas.FieldAccessDescriptor
 
fieldAccessDescriptor(FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.transforms.CoGroup.By
Join by the following field access descriptor.
FieldAccessDescriptor.FieldDescriptor - Class in org.apache.beam.sdk.schemas
Description of a single field.
FieldAccessDescriptor.FieldDescriptor.Builder - Class in org.apache.beam.sdk.schemas
Builder class.
FieldAccessDescriptor.FieldDescriptor.ListQualifier - Enum in org.apache.beam.sdk.schemas
Qualifier for a list selector.
FieldAccessDescriptor.FieldDescriptor.MapQualifier - Enum in org.apache.beam.sdk.schemas
Qualifier for a map selector.
FieldAccessDescriptor.FieldDescriptor.Qualifier - Class in org.apache.beam.sdk.schemas
OneOf union for a collection selector.
FieldAccessDescriptor.FieldDescriptor.Qualifier.Kind - Enum in org.apache.beam.sdk.schemas
The kind of qualifier.
FieldAccessDescriptorParser - Class in org.apache.beam.sdk.schemas.parser
Parser for textual field-access selector.
FieldAccessDescriptorParser() - Constructor for class org.apache.beam.sdk.schemas.parser.FieldAccessDescriptorParser
 
fieldAccessString() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter
 
FieldDescriptor() - Constructor for class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
 
fieldFromType(TypeDescriptor, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.StaticSchemaInference
Map a Java field type to a Beam Schema FieldType.
fieldIds(Integer...) - Static method in class org.apache.beam.sdk.schemas.transforms.CoGroup.By
Join by the following field ids.
fieldIds(Integer...) - Static method in class org.apache.beam.sdk.schemas.transforms.Select
Select a set of top-level field ids from the row.
fieldIdsAccessed() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return the field ids accessed.
fieldNames(String...) - Static method in class org.apache.beam.sdk.schemas.transforms.CoGroup.By
Join by the following field names.
fieldNames(String...) - Static method in class org.apache.beam.sdk.schemas.transforms.Select
Select a set of top-level field names from the row.
fieldNamesAccessed() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return the field names accessed.
fields(String...) - Static method in class org.apache.beam.sdk.schemas.transforms.DropFields
 
fields(Integer...) - Static method in class org.apache.beam.sdk.schemas.transforms.DropFields
 
fields(FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.transforms.DropFields
 
Fields() - Constructor for class org.apache.beam.sdk.schemas.transforms.Select.Fields
 
fields(String) - Static method in class org.apache.beam.sdk.state.StateKeySpec
 
fields(FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.state.StateKeySpec
 
FieldsEqual() - Constructor for class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual
 
fieldSpecifier() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
FieldSpecifierContext(ParserRuleContext, int) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.FieldSpecifierContext
 
FieldSpecifierNotationBaseListener - Class in org.apache.beam.sdk.schemas.parser.generated
This class provides an empty implementation of FieldSpecifierNotationListener, which can be extended to create a listener which only needs to handle a subset of the available methods.
FieldSpecifierNotationBaseListener() - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
 
FieldSpecifierNotationBaseVisitor<T> - Class in org.apache.beam.sdk.schemas.parser.generated
This class provides an empty implementation of FieldSpecifierNotationVisitor, which can be extended to create a visitor which only needs to handle a subset of the available methods.
FieldSpecifierNotationBaseVisitor() - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
 
FieldSpecifierNotationLexer - Class in org.apache.beam.sdk.schemas.parser.generated
 
FieldSpecifierNotationLexer(CharStream) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
FieldSpecifierNotationListener - Interface in org.apache.beam.sdk.schemas.parser.generated
This interface defines a complete listener for a parse tree produced by FieldSpecifierNotationParser.
FieldSpecifierNotationParser - Class in org.apache.beam.sdk.schemas.parser.generated
 
FieldSpecifierNotationParser(TokenStream) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
FieldSpecifierNotationParser.ArrayQualifierContext - Class in org.apache.beam.sdk.schemas.parser.generated
 
FieldSpecifierNotationParser.ArrayQualifierListContext - Class in org.apache.beam.sdk.schemas.parser.generated
 
FieldSpecifierNotationParser.DotExpressionComponentContext - Class in org.apache.beam.sdk.schemas.parser.generated
 
FieldSpecifierNotationParser.DotExpressionContext - Class in org.apache.beam.sdk.schemas.parser.generated
 
FieldSpecifierNotationParser.FieldSpecifierContext - Class in org.apache.beam.sdk.schemas.parser.generated
 
FieldSpecifierNotationParser.MapQualifierContext - Class in org.apache.beam.sdk.schemas.parser.generated
 
FieldSpecifierNotationParser.MapQualifierListContext - Class in org.apache.beam.sdk.schemas.parser.generated
 
FieldSpecifierNotationParser.QualifiedComponentContext - Class in org.apache.beam.sdk.schemas.parser.generated
 
FieldSpecifierNotationParser.QualifierListContext - Class in org.apache.beam.sdk.schemas.parser.generated
 
FieldSpecifierNotationParser.QualifyComponentContext - Class in org.apache.beam.sdk.schemas.parser.generated
 
FieldSpecifierNotationParser.SimpleIdentifierContext - Class in org.apache.beam.sdk.schemas.parser.generated
 
FieldSpecifierNotationParser.WildcardContext - Class in org.apache.beam.sdk.schemas.parser.generated
 
FieldSpecifierNotationVisitor<T> - Interface in org.apache.beam.sdk.schemas.parser.generated
This interface defines a complete generic visitor for a parse tree produced by FieldSpecifierNotationParser.
FieldType() - Constructor for class org.apache.beam.sdk.schemas.Schema.FieldType
 
FieldTypeDescriptors - Class in org.apache.beam.sdk.schemas
Utilities for converting between Schema field types and TypeDescriptors that define Java objects which can represent these field types.
FieldTypeDescriptors() - Constructor for class org.apache.beam.sdk.schemas.FieldTypeDescriptors
 
fieldTypeForJavaType(TypeDescriptor) - Static method in class org.apache.beam.sdk.schemas.FieldTypeDescriptors
FieldValueGetter<ObjectT,ValueT> - Interface in org.apache.beam.sdk.schemas
For internal use only; no backwards-compatibility guarantees.
fieldValueGetters(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.AutoValueSchema
 
fieldValueGetters(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.AvroRecordSchema
 
fieldValueGetters(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
Implementing class should override to return FieldValueGetters.
fieldValueGetters(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema
 
fieldValueGetters(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.JavaFieldSchema
 
FieldValueSetter<ObjectT,ValueT> - Interface in org.apache.beam.sdk.schemas
For internal use only; no backwards-compatibility guarantees.
FieldValueTypeInformation - Class in org.apache.beam.sdk.schemas
Represents type information for a Java type that will be used to infer a Schema type.
FieldValueTypeInformation() - Constructor for class org.apache.beam.sdk.schemas.FieldValueTypeInformation
 
FieldValueTypeInformation.Builder - Class in org.apache.beam.sdk.schemas
 
fieldValueTypeInformations(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.AutoValueSchema
 
fieldValueTypeInformations(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.AvroRecordSchema
 
fieldValueTypeInformations(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
Implementing class should override to return a list of type-informations.
fieldValueTypeInformations(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema
 
fieldValueTypeInformations(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.JavaFieldSchema
 
FieldValueTypeSupplier - Interface in org.apache.beam.sdk.schemas.utils
A naming policy for schema fields.
FileBasedReader(FileBasedSource<T>) - Constructor for class org.apache.beam.sdk.io.FileBasedSource.FileBasedReader
Subclasses should not perform IO operations at the constructor.
FileBasedSink<UserT,DestinationT,OutputT> - Class in org.apache.beam.sdk.io
Abstract class for file-based output.
FileBasedSink(ValueProvider<ResourceId>, FileBasedSink.DynamicDestinations<?, DestinationT, OutputT>) - Constructor for class org.apache.beam.sdk.io.FileBasedSink
Construct a FileBasedSink with the given temp directory, producing uncompressed files.
FileBasedSink(ValueProvider<ResourceId>, FileBasedSink.DynamicDestinations<?, DestinationT, OutputT>, FileBasedSink.WritableByteChannelFactory) - Constructor for class org.apache.beam.sdk.io.FileBasedSink
Construct a FileBasedSink with the given temp directory and output channel type.
FileBasedSink(ValueProvider<ResourceId>, FileBasedSink.DynamicDestinations<?, DestinationT, OutputT>, Compression) - Constructor for class org.apache.beam.sdk.io.FileBasedSink
Construct a FileBasedSink with the given temp directory and output channel type.
FileBasedSink.CompressionType - Enum in org.apache.beam.sdk.io
Deprecated.
FileBasedSink.DynamicDestinations<UserT,DestinationT,OutputT> - Class in org.apache.beam.sdk.io
A class that allows value-dependent writes in FileBasedSink.
FileBasedSink.FilenamePolicy - Class in org.apache.beam.sdk.io
A naming policy for output files.
FileBasedSink.FileResult<DestinationT> - Class in org.apache.beam.sdk.io
Result of a single bundle write.
FileBasedSink.FileResultCoder<DestinationT> - Class in org.apache.beam.sdk.io
A coder for FileBasedSink.FileResult objects.
FileBasedSink.OutputFileHints - Interface in org.apache.beam.sdk.io
Provides hints about how to generate output files, such as a suggested filename suffix (e.g.
FileBasedSink.WritableByteChannelFactory - Interface in org.apache.beam.sdk.io
Implementations create instances of WritableByteChannel used by FileBasedSink and related classes to allow decorating, or otherwise transforming, the raw data that would normally be written directly to the WritableByteChannel passed into FileBasedSink.WritableByteChannelFactory.create(WritableByteChannel).
FileBasedSink.WriteOperation<DestinationT,OutputT> - Class in org.apache.beam.sdk.io
Abstract operation that manages the process of writing to FileBasedSink.
FileBasedSink.Writer<DestinationT,OutputT> - Class in org.apache.beam.sdk.io
Abstract writer that writes a bundle to a FileBasedSink.
FileBasedSource<T> - Class in org.apache.beam.sdk.io
A common base class for all file-based Sources.
FileBasedSource(ValueProvider<String>, EmptyMatchTreatment, long) - Constructor for class org.apache.beam.sdk.io.FileBasedSource
Create a FileBaseSource based on a file or a file pattern specification, with the given strategy for treating filepatterns that do not match any files.
FileBasedSource(ValueProvider<String>, long) - Constructor for class org.apache.beam.sdk.io.FileBasedSource
FileBasedSource(MatchResult.Metadata, long, long, long) - Constructor for class org.apache.beam.sdk.io.FileBasedSource
Create a FileBasedSource based on a single file.
FileBasedSource.FileBasedReader<T> - Class in org.apache.beam.sdk.io
A reader that implements code common to readers of FileBasedSources.
FileBasedSource.Mode - Enum in org.apache.beam.sdk.io
A given FileBasedSource represents a file resource of one of these types.
FileChecksumMatcher - Class in org.apache.beam.sdk.testing
Matcher to verify checksum of the contents of an ShardedFile in E2E test.
fileContentsHaveChecksum(String) - Static method in class org.apache.beam.sdk.testing.FileChecksumMatcher
 
FileIO - Class in org.apache.beam.sdk.io
General-purpose transforms for working with files: listing files (matching), reading and writing.
FileIO() - Constructor for class org.apache.beam.sdk.io.FileIO
 
FileIO.Match - Class in org.apache.beam.sdk.io
Implementation of FileIO.match().
FileIO.MatchAll - Class in org.apache.beam.sdk.io
Implementation of FileIO.matchAll().
FileIO.MatchConfiguration - Class in org.apache.beam.sdk.io
Describes configuration for matching filepatterns, such as EmptyMatchTreatment and continuous watching for matching files.
FileIO.ReadableFile - Class in org.apache.beam.sdk.io
A utility class for accessing a potentially compressed file.
FileIO.ReadMatches - Class in org.apache.beam.sdk.io
Implementation of FileIO.readMatches().
FileIO.ReadMatches.DirectoryTreatment - Enum in org.apache.beam.sdk.io
Enum to control how directories are handled.
FileIO.Sink<ElementT> - Interface in org.apache.beam.sdk.io
Specifies how to write elements to individual files in FileIO.write() and FileIO.writeDynamic().
FileIO.Write<DestinationT,UserT> - Class in org.apache.beam.sdk.io
Implementation of FileIO.write() and FileIO.writeDynamic().
FileIO.Write.FileNaming - Interface in org.apache.beam.sdk.io
A policy for generating names for shard files.
FilenamePolicy() - Constructor for class org.apache.beam.sdk.io.FileBasedSink.FilenamePolicy
 
filepattern(String) - Method in class org.apache.beam.sdk.io.FileIO.Match
Matches the given filepattern.
filepattern(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.FileIO.Match
FilePatternMatchingShardedFile - Class in org.apache.beam.sdk.util
A sharded file which matches a given file pattern.
FilePatternMatchingShardedFile(String) - Constructor for class org.apache.beam.sdk.util.FilePatternMatchingShardedFile
Constructs an FilePatternMatchingShardedFile for the given file pattern.
FileResult(ResourceId, int, BoundedWindow, PaneInfo, DestinationT) - Constructor for class org.apache.beam.sdk.io.FileBasedSink.FileResult
 
FileResultCoder(Coder<BoundedWindow>, Coder<DestinationT>) - Constructor for class org.apache.beam.sdk.io.FileBasedSink.FileResultCoder
 
FileSystem<ResourceIdT extends ResourceId> - Class in org.apache.beam.sdk.io
File system interface in Beam.
FileSystem() - Constructor for class org.apache.beam.sdk.io.FileSystem
 
FileSystemRegistrar - Interface in org.apache.beam.sdk.io
A registrar that creates FileSystem instances from PipelineOptions.
FileSystems - Class in org.apache.beam.sdk.io
Clients facing FileSystem utility.
FileSystems() - Constructor for class org.apache.beam.sdk.io.FileSystems
 
FileSystemUtils - Class in org.apache.beam.sdk.io
 
FileSystemUtils() - Constructor for class org.apache.beam.sdk.io.FileSystemUtils
 
Filter - Class in org.apache.beam.sdk.schemas.transforms
A PTransform for filtering a collection of schema types.
Filter() - Constructor for class org.apache.beam.sdk.schemas.transforms.Filter
 
Filter<T> - Class in org.apache.beam.sdk.transforms
PTransforms for filtering from a PCollection the elements satisfying a predicate, or satisfying an inequality with a given value based on the elements' natural ordering.
Filter.Inner<T> - Class in org.apache.beam.sdk.schemas.transforms
Implementation of the filter.
finalizeCheckpoint() - Method in class org.apache.beam.sdk.io.CountingSource.CounterMark
 
finalizeCheckpoint() - Method in interface org.apache.beam.sdk.io.UnboundedSource.CheckpointMark
Called by the system to signal that this checkpoint mark has been committed along with all the records which have been read from the UnboundedSource.UnboundedReader since the previous checkpoint was taken.
finalizeCheckpoint() - Method in class org.apache.beam.sdk.io.UnboundedSource.CheckpointMark.NoopCheckpointMark
 
finalizeDestination(DestinationT, BoundedWindow, Integer, Collection<FileBasedSink.FileResult<DestinationT>>) - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
 
find(String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.Find PTransform that checks if a portion of the line matches the Regex.
find(Pattern) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.Find PTransform that checks if a portion of the line matches the Regex.
find(String, int) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.Find PTransform that checks if a portion of the line matches the Regex.
find(Pattern, int) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.Find PTransform that checks if a portion of the line matches the Regex.
find(String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.FindName PTransform that checks if a portion of the line matches the Regex.
find(Pattern, String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.FindName PTransform that checks if a portion of the line matches the Regex.
Find(Pattern, int) - Constructor for class org.apache.beam.sdk.transforms.Regex.Find
 
findAll(String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.FindAll PTransform that checks if a portion of the line matches the Regex.
findAll(Pattern) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.FindAll PTransform that checks if a portion of the line matches the Regex.
FindAll(Pattern) - Constructor for class org.apache.beam.sdk.transforms.Regex.FindAll
 
findClassLoader(ClassLoader) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
Finds the appropriate ClassLoader to be used by the ServiceLoader.load(java.lang.Class<S>, java.lang.ClassLoader) call, which by default would use the proposed ClassLoader, which can be null.
findClassLoader(Class<?>...) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
Find the common classloader of all these classes.
findClassLoader() - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
Finds the appropriate ClassLoader to be used by the ServiceLoader.load(java.lang.Class<S>, java.lang.ClassLoader) call, which by default would use the context ClassLoader, which can be null.
findKV(String, int, int) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.FindKV PTransform that checks if a portion of the line matches the Regex.
findKV(Pattern, int, int) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.FindKV PTransform that checks if a portion of the line matches the Regex.
findKV(String, String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.FindNameKV PTransform that checks if a portion of the line matches the Regex.
findKV(Pattern, String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.FindNameKV PTransform that checks if a portion of the line matches the Regex.
FindKV(Pattern, int, int) - Constructor for class org.apache.beam.sdk.transforms.Regex.FindKV
 
FindName(Pattern, String) - Constructor for class org.apache.beam.sdk.transforms.Regex.FindName
 
FindNameKV(Pattern, String, String) - Constructor for class org.apache.beam.sdk.transforms.Regex.FindNameKV
 
finish() - Method in class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
Finishes the encoding by flushing any buffered data, and outputting a final count of 0.
finishBundle() - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
finishBundle() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.FinishBundle method.
FinishBundleContext() - Constructor for class org.apache.beam.sdk.transforms.DoFn.FinishBundleContext
 
finishBundleContext(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provide a DoFn.FinishBundleContext to use with the given DoFn.
finishBundleContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
finishBundleContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
finishBundleContext() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
finishSpecifying() - Method in interface org.apache.beam.sdk.state.StateSpec
For internal use only; no backwards-compatibility guarantees.
finishSpecifying(PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PCollection
After building, finalizes this PValue to make it ready for running.
finishSpecifying(PInput, PTransform<?, ?>) - Method in interface org.apache.beam.sdk.values.PValue
After building, finalizes this PValue to make it ready for being used as an input to a PTransform.
finishSpecifying(PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PValueBase
 
finishSpecifyingInput() - Method in class org.apache.beam.sdk.runners.TransformHierarchy
Finish specifying all of the input PValues of the current TransformHierarchy.Node.
finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.io.WriteFilesResult
 
finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.transforms.JsonToRow.ParseResult
 
finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.transforms.WithFailures.Result
 
finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PCollection
 
finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PCollectionList
 
finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
 
finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PDone
Does nothing; there is nothing to finish specifying.
finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in interface org.apache.beam.sdk.values.POutput
As part of applying the producing PTransform, finalizes this output to make it ready for being used as an input and for running.
finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PValueBase
 
finishWrite() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
fireTimestamp() - Method in class org.apache.beam.sdk.transforms.DoFn.OnTimerContext
Returns the firing timestamp of the current timer.
first - Variable in class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
 
fixDefaults() - Method in class org.apache.beam.sdk.values.WindowingStrategy
Fixes all the defaults so that equals can be used to check that two strategies are the same, regardless of the state of "defaulted-ness".
FixedBytes - Class in org.apache.beam.sdk.schemas.logicaltypes
A LogicalType representing a fixed-size byte array.
fixedSizeGlobally(int) - Static method in class org.apache.beam.sdk.transforms.Sample
Returns a PTransform that takes a PCollection<T>, selects sampleSize elements, uniformly at random, and returns a PCollection<Iterable<T>> containing the selected elements.
fixedSizePerKey(int) - Static method in class org.apache.beam.sdk.transforms.Sample
Returns a PTransform that takes an input PCollection<KV<K, V>> and returns a PCollection<KV<K, Iterable<V>>> that contains an output element mapping each distinct key in the input PCollection to a sample of sampleSize values associated with that key in the input PCollection, taken uniformly at random.
FixedWindows - Class in org.apache.beam.sdk.transforms.windowing
A WindowFn that windows values into fixed-size timestamp-based windows.
FlatMapElements<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
PTransforms for mapping a simple function that returns iterables over the elements of a PCollection and merging the results.
FlatMapElements.FlatMapWithFailures<InputT,OutputT,FailureT> - Class in org.apache.beam.sdk.transforms
A PTransform that adds exception handling to FlatMapElements.
Flatten - Class in org.apache.beam.sdk.transforms
Flatten<T> takes multiple PCollection<T>s bundled into a PCollectionList<T> and returns a single PCollection<T> containing all the elements in all the input PCollections.
Flatten() - Constructor for class org.apache.beam.sdk.transforms.Flatten
 
Flatten.Iterables<T> - Class in org.apache.beam.sdk.transforms
FlattenIterables<T> takes a PCollection<Iterable<T>> and returns a PCollection<T> that contains all the elements from each iterable.
Flatten.PCollections<T> - Class in org.apache.beam.sdk.transforms
A PTransform that flattens a PCollectionList into a PCollection containing all the elements of all the PCollections in its input.
Flattened() - Constructor for class org.apache.beam.sdk.schemas.transforms.Select.Flattened
 
flattenedSchema() - Static method in class org.apache.beam.sdk.schemas.transforms.Select
Selects every leaf-level field.
FlattenWithHeterogeneousCoders - Interface in org.apache.beam.sdk.testing
Category tag for tests that use a Flatten where the input PCollectionList contains PCollections heterogeneous coders.
FLOAT - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
The type of float fields.
FloatCoder - Class in org.apache.beam.sdk.coders
A FloatCoder encodes Float values in 4 bytes using Java serialization.
floats() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for Float.
FluentBackoff - Class in org.apache.beam.sdk.util
A fluent builder for BackOff objects that allows customization of the retry algorithm.
flush() - Method in class org.apache.beam.sdk.io.AvroIO.Sink
 
flush() - Method in interface org.apache.beam.sdk.io.FileIO.Sink
Flushes the buffered state (if any) before the channel is closed.
flush() - Method in class org.apache.beam.sdk.io.TextIO.Sink
 
flush() - Method in class org.apache.beam.sdk.io.TFRecordIO.Sink
 
flush() - Method in class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
 
fn(ProcessFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Contextful
fn(SerializableFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Contextful
Binary compatibility adapter for Contextful.fn(ProcessFunction).
fn(Contextful.Fn<InputT, OutputT>, Requirements) - Static method in class org.apache.beam.sdk.transforms.Contextful
Same with Contextful.of(ClosureT, org.apache.beam.sdk.transforms.Requirements) but with better type inference behavior for the case of Contextful.Fn.
fnClass() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Class of the original DoFn from which this signature was produced.
forCoder(TypeDescriptor<?>, Coder<?>) - Static method in class org.apache.beam.sdk.coders.CoderProviders
Creates a CoderProvider that always returns the given coder for the specified type.
forever(Trigger) - Static method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
Create a composite trigger that repeatedly executes the trigger repeated, firing each time it fires and ignoring any indications to finish.
forField(Field) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
 
forFn(DoFn<InputT, OutputT>, WindowingStrategy<?, ?>, Iterable<PCollectionView<?>>, Coder<InputT>, TupleTag<OutputT>, DoFnSchemaInformation, Map<String, PCollectionView<?>>) - Static method in class org.apache.beam.sdk.util.DoFnInfo
Creates a DoFnInfo for the given DoFn.
forFn(DoFn<InputT, OutputT>, WindowingStrategy<?, ?>, Iterable<PCollectionView<?>>, Coder<InputT>, Map<TupleTag<?>, Coder<?>>, TupleTag<OutputT>, DoFnSchemaInformation, Map<String, PCollectionView<?>>) - Static method in class org.apache.beam.sdk.util.DoFnInfo
Creates a DoFnInfo for the given DoFn.
forGetter(Method) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
 
formatAnnotation(Annotation) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
A Function that returns a concise string for a Annotation.
formatMethod(Method) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
Returns a string representation of the signature of a Method.
formatMethodWithClass(Method) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
Returns a string representation of the class + method signature for a Method.
formatRecord(ElementT, Schema) - Method in interface org.apache.beam.sdk.io.AvroIO.RecordFormatter
Deprecated.
 
formatRecord(UserT) - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
Convert an input record type into the output type.
formatTimestamp(Instant) - Static method in class org.apache.beam.sdk.transforms.windowing.BoundedWindow
Formats a Instant timestamp with additional Beam-specific metadata, such as indicating whether the timestamp is the end of the global window or one of the distinguished values BoundedWindow.TIMESTAMP_MIN_VALUE or BoundedWindow.TIMESTAMP_MIN_VALUE.
forNewInput(Instant, InputT) - Method in interface org.apache.beam.sdk.transforms.Watch.Growth.TerminationCondition
Called by the Watch transform to create a new independent termination state for a newly arrived InputT.
forOneOf(String, boolean, Map<String, FieldValueTypeInformation>) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
 
forSchema(Schema) - Static method in class org.apache.beam.sdk.util.RowJson.RowJsonDeserializer
Creates a deserializer for a Row Schema.
forSchema(Schema) - Static method in class org.apache.beam.sdk.util.RowJson.RowJsonSerializer
Creates a serializer for a Row Schema.
forSetter(Method) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
 
forSetter(Method, String) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
 
forTransformHierarchy(TransformHierarchy, PipelineOptions) - Static method in class org.apache.beam.sdk.Pipeline
 
forTypeName(Schema.TypeName) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
forValueWithCoder(T, Coder<T>) - Static method in class org.apache.beam.sdk.util.MutationDetectors
Creates a new MutationDetector for the provided value that uses the provided Coder to perform deep copies and comparisons by serializing and deserializing values.
from(String) - Method in class org.apache.beam.sdk.io.AvroIO.Parse
Reads from the given filename or filepattern.
from(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.AvroIO.Parse
from(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.AvroIO.Read
Reads from the given filename or filepattern.
from(String) - Method in class org.apache.beam.sdk.io.AvroIO.Read
from(String, Row, Schema) - Method in class org.apache.beam.sdk.io.AvroSchemaIOProvider
Produce a SchemaIO given a String representing the data's location, the schema of the data that resides there, and some IO-specific configuration object.
from(ValueProvider<String>) - Static method in class org.apache.beam.sdk.io.AvroSource
Reads from the given file name or pattern ("glob").
from(MatchResult.Metadata) - Static method in class org.apache.beam.sdk.io.AvroSource
 
from(String) - Static method in class org.apache.beam.sdk.io.AvroSource
from(FileBasedSource<T>) - Static method in class org.apache.beam.sdk.io.CompressedSource
Creates a CompressedSource from an underlying FileBasedSource.
from(long) - Static method in class org.apache.beam.sdk.io.GenerateSequence
Specifies the minimum number to generate (inclusive).
from(BoundedSource<T>) - Method in class org.apache.beam.sdk.io.Read.Builder
Returns a new Read.Bounded PTransform reading from the given BoundedSource.
from(UnboundedSource<T, ?>) - Method in class org.apache.beam.sdk.io.Read.Builder
Returns a new Read.Unbounded PTransform reading from the given UnboundedSource.
from(BoundedSource<T>) - Static method in class org.apache.beam.sdk.io.Read
Returns a new Read.Bounded PTransform reading from the given BoundedSource.
from(UnboundedSource<T, ?>) - Static method in class org.apache.beam.sdk.io.Read
Returns a new Read.Unbounded PTransform reading from the given UnboundedSource.
from(String) - Method in class org.apache.beam.sdk.io.TextIO.Read
Reads text files that reads from the file(s) with the given filename or filename pattern.
from(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.TextIO.Read
Same as from(filepattern), but accepting a ValueProvider.
from(String) - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
Returns a transform for reading TFRecord files that reads from the file(s) with the given filename or filename pattern.
from(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
Same as from(filepattern), but accepting a ValueProvider.
from(Map<String, String>) - Static method in class org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides
Expects a map keyed by logger Names with values representing LogLevels.
from(String, Row, Schema) - Method in interface org.apache.beam.sdk.schemas.io.SchemaIOProvider
Produce a SchemaIO given a String representing the data's location, the schema of the data that resides there, and some IO-specific configuration object.
from(HasDisplayData) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
Collect the DisplayData from a component.
from(double, double) - Static method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.Progress
A representation for the amount of known completed and remaining work.
fromArgs(String...) - Method in class org.apache.beam.sdk.options.PipelineOptionsFactory.Builder
Sets the command line arguments to parse when constructing the PipelineOptions.
fromArgs(String...) - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
Sets the command line arguments to parse when constructing the PipelineOptions.
fromAvroType(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils.FixedBytesField
Create a AvroUtils.FixedBytesField from an AVRO type.
fromBeamFieldType(Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils.FixedBytesField
fromCanonical(Compression) - Static method in enum org.apache.beam.sdk.io.FileBasedSink.CompressionType
Deprecated.
 
fromClass(Class<?>) - Method in class org.apache.beam.sdk.util.InstanceBuilder
Sets the factory class to use for instance construction.
fromClassName(String) - Method in class org.apache.beam.sdk.util.InstanceBuilder
Sets the class name to be constructed.
fromComponents(List<Coder<?>>, byte[]) - Static method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
Create a Coder from its component coders.
fromFactoryMethod(String) - Method in class org.apache.beam.sdk.util.InstanceBuilder
Sets the name of the factory method used to construct the instance.
fromFile(File, boolean) - Static method in class org.apache.beam.sdk.io.LocalResources
 
fromLong(Long, Schema, LogicalType) - Method in class org.apache.beam.sdk.coders.AvroCoder.JodaTimestampConversion
 
fromOptions(PipelineOptions) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderFileSystemRegistrar
 
fromOptions(PipelineOptions) - Method in interface org.apache.beam.sdk.io.FileSystemRegistrar
Create zero or more filesystems from the given PipelineOptions.
fromOptions(PipelineOptions) - Method in class org.apache.beam.sdk.io.LocalFileSystemRegistrar
 
fromOptions(PipelineOptions) - Static method in class org.apache.beam.sdk.PipelineRunner
Constructs a runner from the provided PipelineOptions.
fromOptions(PipelineOptions) - Static method in class org.apache.beam.sdk.testing.CrashingRunner
 
fromOptions(PipelineOptions) - Static method in class org.apache.beam.sdk.testing.TestPipeline
 
fromParams(DefaultFilenamePolicy.Params) - Static method in class org.apache.beam.sdk.io.DefaultFilenamePolicy
fromPath(Path, boolean) - Static method in class org.apache.beam.sdk.io.LocalResources
 
fromProcessFunctionWithOutputType(ProcessFunction<InputT, OutputT>, TypeDescriptor<OutputT>) - Static method in class org.apache.beam.sdk.transforms.InferableFunction
 
fromRawEvents(Coder<T>, List<TestStream.Event<T>>) - Static method in class org.apache.beam.sdk.testing.TestStream
For internal use only.
fromRow(Row) - Static method in class org.apache.beam.sdk.values.Row
Creates a row builder based on the specified row.
fromRowFunction(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProvider
Given a type, returns a function that converts from a Row object to that type.
fromRowFunction(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
 
fromRowFunction(TypeDescriptor<T>) - Method in interface org.apache.beam.sdk.schemas.SchemaProvider
Given a type, returns a function that converts from a Row object to that type.
fromRows(Class<OutputT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Convert
Convert a PCollection<Row> into a PCollection<OutputT>.
fromRows(TypeDescriptor<OutputT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Convert
Convert a PCollection<Row> into a PCollection<Row>.
fromSerializableFunctionWithOutputType(SerializableFunction<InputT, OutputT>, TypeDescriptor<OutputT>) - Static method in class org.apache.beam.sdk.transforms.SimpleFunction
 
fromStandardParameters(ValueProvider<ResourceId>, String, String, boolean) - Static method in class org.apache.beam.sdk.io.DefaultFilenamePolicy
fromStaticMethods(Class<?>, Class<?>) - Static method in class org.apache.beam.sdk.coders.CoderProviders
Creates a CoderProvider from a class's static <T> Coder<T> of(TypeDescriptor<T>, List<Coder<?>>) method.
fromString(String, boolean) - Static method in class org.apache.beam.sdk.io.LocalResources
 
fromString(ValueProvider<String>, boolean) - Static method in class org.apache.beam.sdk.io.LocalResources
 
fromSupplier(SerializableMatchers.SerializableSupplier<Matcher<T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
Constructs a SerializableMatcher from a non-serializable Matcher via indirection through SerializableMatchers.SerializableSupplier.
fullOuterJoin(PCollection<RhsT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Join
Perform a full outer join.
fullyExpand(Map<TupleTag<?>, PValue>) - Static method in class org.apache.beam.sdk.values.PValues
Returns all the tagged PCollections represented in the given PValue.

G

Gauge - Interface in org.apache.beam.sdk.metrics
A metric that reports the latest value out of reported values.
gauge(String, String) - Static method in class org.apache.beam.sdk.metrics.Metrics
Create a metric that can have its new value set, and is aggregated by taking the last reported value.
gauge(Class<?>, String) - Static method in class org.apache.beam.sdk.metrics.Metrics
Create a metric that can have its new value set, and is aggregated by taking the last reported value.
GaugeResult - Class in org.apache.beam.sdk.metrics
The result of a Gauge metric.
GaugeResult() - Constructor for class org.apache.beam.sdk.metrics.GaugeResult
 
GaugeResult.EmptyGaugeResult - Class in org.apache.beam.sdk.metrics
Empty GaugeResult, representing no values reported.
generate(Schema) - Static method in class org.apache.beam.sdk.coders.RowCoderGenerator
 
GenerateSequence - Class in org.apache.beam.sdk.io
A PTransform that produces longs starting from the given value, and either up to the given limit or until Long.MAX_VALUE / until the given time elapses.
GenerateSequence() - Constructor for class org.apache.beam.sdk.io.GenerateSequence
 
GenerateSequence.External - Class in org.apache.beam.sdk.io
Exposes GenerateSequence as an external transform for cross-language usage.
GenerateSequence.External.ExternalConfiguration - Class in org.apache.beam.sdk.io
Parameters class to expose the transform to an external SDK.
GenericDlq - Class in org.apache.beam.sdk.schemas.io
Helper to generate a DLQ transform to write PCollection to an external system.
GenericDlqProvider - Interface in org.apache.beam.sdk.schemas.io
A Provider for generic DLQ transforms that handle deserialization failures.
get() - Method in interface org.apache.beam.sdk.options.ValueProvider
Returns the runtime value wrapped by this ValueProvider in case it is ValueProvider.isAccessible(), otherwise fails.
get() - Method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
 
get() - Method in class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
 
get() - Method in class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
 
get(Class<?>) - Method in class org.apache.beam.sdk.schemas.AutoValueSchema.AbstractGetterTypeSupplier
 
get(ObjectT) - Method in interface org.apache.beam.sdk.schemas.FieldValueGetter
 
get(Class<?>) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema.GetterTypeSupplier
 
get(Class<?>) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema.SetterTypeSupplier
 
get(Class<?>) - Method in class org.apache.beam.sdk.schemas.JavaFieldSchema.JavaFieldTypeSupplier
 
get(Object) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
get(Class<?>) - Method in interface org.apache.beam.sdk.schemas.utils.FieldValueTypeSupplier
Return all the FieldValueTypeInformations.
get(Class<?>, Schema) - Method in interface org.apache.beam.sdk.schemas.utils.FieldValueTypeSupplier
Return all the FieldValueTypeInformations.
get(K) - Method in interface org.apache.beam.sdk.state.MapState
A deferred lookup, using null values if the item is not found.
get(String) - Method in interface org.apache.beam.sdk.state.TimerMap
 
get() - Method in interface org.apache.beam.sdk.testing.SerializableMatchers.SerializableSupplier
 
get(TupleTag<V>) - Method in class org.apache.beam.sdk.transforms.CombineFns.CoCombineResult
Returns the value represented by the given TupleTag.
get(TupleTag<T>) - Method in interface org.apache.beam.sdk.transforms.DoFn.MultiOutputReceiver
Returns an DoFn.OutputReceiver for the given tag.
get() - Method in interface org.apache.beam.sdk.transforms.Materializations.IterableView
Returns an iterable for all values.
get() - Method in interface org.apache.beam.sdk.transforms.Materializations.MultimapView
Returns an iterable of all keys.
get(K) - Method in interface org.apache.beam.sdk.transforms.Materializations.MultimapView
Returns an iterable of all the values for the specified key.
get() - Method in class org.apache.beam.sdk.util.BucketingFunction
Return the (bucketized) combined value of all samples.
get(CompletionStage<T>) - Static method in class org.apache.beam.sdk.util.MoreFutures
Gets the result of the given future.
get(CompletionStage<T>, long, TimeUnit) - Static method in class org.apache.beam.sdk.util.MoreFutures
Gets the result of the given future.
get(long) - Method in class org.apache.beam.sdk.util.MovingFunction
Return the minimum/maximum/sum of all retained values within samplePeriodMs of nowMsSinceEpoch.
get() - Static method in class org.apache.beam.sdk.util.NoopLock
 
get() - Method in interface org.apache.beam.sdk.util.ThrowingSupplier
 
get(int) - Method in class org.apache.beam.sdk.values.PCollectionList
Returns the PCollection at the given index (origin zero).
get(TupleTag<T>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
Returns the PCollection associated with the given TupleTag in this PCollectionTuple.
get(String) - Method in class org.apache.beam.sdk.values.PCollectionTuple
Returns the PCollection associated with the given tag in this PCollectionTuple.
get() - Method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadata
 
get(int) - Method in class org.apache.beam.sdk.values.TupleTagList
Returns the TupleTag at the given index (origin zero).
getAccum() - Method in interface org.apache.beam.sdk.state.CombiningState
Read the merged accumulator for this state cell.
getAccumulatedBucketSize(int) - Method in interface org.apache.beam.sdk.util.HistogramData.BucketType
 
getAccumulatedBucketSize(int) - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
 
getAccumulatorCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
 
getAccumulatorCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
Deprecated.
 
getAccumulatorCoder(CoderRegistry, Coder<Double>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
 
getAccumulatorCoder(CoderRegistry, Coder<V>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
 
getAccumulatorCoder(CoderRegistry, Coder<Integer>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
 
getAccumulatorCoder(CoderRegistry, Coder<Long>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
 
getAccumulatorCoder(CoderRegistry, Coder<InputT>) - Method in interface org.apache.beam.sdk.transforms.CombineFnBase.GlobalCombineFn
Returns the Coder to use for accumulator AccumT values, or null if it is not able to be inferred.
getAccumulatorCoder(CoderRegistry, Coder<DataT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
 
getAccumulatorCoder(CoderRegistry, Coder<DataT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
 
getAccumulatorCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
 
getAccumulatorCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.Top.TopCombineFn
 
getAccumulatorCoder() - Method in class org.apache.beam.sdk.util.AppliedCombineFn
 
getAdditionalInputs() - Method in class org.apache.beam.sdk.io.WriteFiles
 
getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
Returns the side inputs of this Combine, tagged with the tag of the PCollectionView.
getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
Returns the side inputs of this Combine, tagged with the tag of the PCollectionView.
getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
Returns the side inputs of this ParDo, tagged with the tag of the PCollectionView.
getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
Returns the side inputs of this ParDo, tagged with the tag of the PCollectionView.
getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.PTransform
Returns all PValues that are consumed as inputs to this PTransform that are independent of the expansion of the InputT within PTransform.expand(PInput).
getAdditionalOutputTags() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
 
getAll(TupleTag<V>) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
Returns the values from the table represented by the given TupleTag<V> as an Iterable<V> (which may be empty if there are no results).
getAll(String) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
Like CoGbkResult.getAll(TupleTag) but using a String instead of a TupleTag.
getAll() - Method in class org.apache.beam.sdk.values.PCollectionList
Returns an immutable List of all the PCollections in this PCollectionList.
getAll() - Method in class org.apache.beam.sdk.values.PCollectionTuple
Returns an immutable Map from TupleTag to corresponding PCollection, for all the members of this PCollectionTuple.
getAll() - Method in class org.apache.beam.sdk.values.TupleTagList
Returns an immutable List of all the TupleTags in this TupleTagList.
getAllFields() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
If true, all fields are being accessed.
getAllMetadata() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
Deprecated.
use schema options instead.
getAllowedLateness() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
getAllowedTimestampSkew() - Method in class org.apache.beam.sdk.transforms.DoFn
Deprecated.
This method permits a DoFn to emit elements behind the watermark. These elements are considered late, and if behind the allowed lateness of a downstream PCollection may be silently dropped. See https://issues.apache.org/jira/browse/BEAM-644 for details on a replacement.
getAllowedTimestampSkew() - Method in class org.apache.beam.sdk.transforms.WithTimestamps
Deprecated.
This method permits a to elements to be emitted behind the watermark. These elements are considered late, and if behind the allowed lateness of a downstream PCollection may be silently dropped. See https://issues.apache.org/jira/browse/BEAM-644 for details on a replacement.
getAnnotatedConstructor(Class) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
 
getAnnotatedCreateMethod(Class) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
 
getAnyExposurePath(Class<?>) - Method in class org.apache.beam.sdk.util.ApiSurface
Returns a path from an exposed class to a root class.
getAppliedFn(CoderRegistry, Coder<? extends KV<K, ? extends Iterable<InputT>>>, WindowingStrategy<?, ?>) - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
Returns the Combine.CombineFn bound to its coders.
getAppName() - Method in interface org.apache.beam.sdk.options.ApplicationNameOptions
Name of application, for display purposes.
getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Date
 
getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
 
getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
 
getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
 
getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
 
getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
 
getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Time
 
getArgument() - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
An optional argument to configure the type.
getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Date
 
getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
 
getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
 
getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
 
getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
 
getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
 
getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
 
getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Time
 
getArgumentType() - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
A schema type representing how to interpret the argument.
getArgumentTypes(Method) - Method in class org.apache.beam.sdk.values.TypeDescriptor
Returns a list of argument types for the given method, which must be a part of the class.
getArray(String) - Method in class org.apache.beam.sdk.values.Row
Get an array value by field name, IllegalStateException is thrown if schema doesn't match.
getArray(int) - Method in class org.apache.beam.sdk.values.Row
Get an array value by field index, IllegalStateException is thrown if schema doesn't match.
getATN() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
getATN() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
getAttempted() - Method in class org.apache.beam.sdk.metrics.MetricResult
Return the value of this metric across all attempts of executing all parts of the pipeline.
getAvroBytesToRowFunction(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Returns a function mapping encoded AVRO GenericRecords to Beam Rows.
getBaseAutoValueClass(Class<?>) - Static method in class org.apache.beam.sdk.schemas.utils.AutoValueUtils
 
getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Date
 
getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
 
getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
 
getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
 
getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
 
getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
 
getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
 
getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Time
 
getBaseType() - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
The base Schema.FieldType used to store values of this type.
getBaseValue(String, Class<T>) - Method in class org.apache.beam.sdk.values.Row
Returns the base type for this field.
getBaseValue(String) - Method in class org.apache.beam.sdk.values.Row
Returns the base type for this field.
getBaseValue(int, Class<T>) - Method in class org.apache.beam.sdk.values.Row
Returns the base type for this field.
getBaseValue(int) - Method in class org.apache.beam.sdk.values.Row
Returns the base type for this field.
getBaseValues() - Method in class org.apache.beam.sdk.values.Row
Return a list of data values.
getBatchingParams() - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches
Returns user supplied parameters for batching.
getBatchingParams() - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches.WithShardedKey
Returns user supplied parameters for batching.
getBatchSize() - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches.BatchingParams
 
getBoolean(String) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.BOOLEAN value by field name, IllegalStateException is thrown if schema doesn't match.
getBoolean(int) - Method in class org.apache.beam.sdk.values.Row
Get a Boolean value by field index, ClassCastException is thrown if schema doesn't match.
getBucketIndex(double) - Method in interface org.apache.beam.sdk.util.HistogramData.BucketType
 
getBucketIndex(double) - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
 
getBucketSize(int) - Method in interface org.apache.beam.sdk.util.HistogramData.BucketType
 
getBucketSize(int) - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
 
getBuilderCreator(Class<?>, Schema, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.AutoValueUtils
Try to find an accessible builder class for creating an AutoValue class.
getByte(String) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.BYTE value by field name, IllegalStateException is thrown if schema doesn't match.
getByte(int) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.BYTE value by field index, ClassCastException is thrown if schema doesn't match.
getBytes() - Method in class org.apache.beam.sdk.io.range.ByteKey
Returns a newly-allocated byte[] representing this ByteKey.
getBytes(String) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.BYTES value by field name, IllegalStateException is thrown if schema doesn't match.
getBytes(int) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.BYTES value by field index, ClassCastException is thrown if schema doesn't match.
getBytesPerOffset() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
Returns approximately how many bytes of data correspond to a single offset in this source.
getBytesWithoutClosing(InputStream) - Static method in class org.apache.beam.sdk.util.StreamUtils
Efficient converting stream to bytes.
getCaseEnumType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
Returns the EnumerationType that is used to represent the case type.
getCaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
Returns the enumeration that specified which OneOf field is set.
getChannel(int) - Method in class org.apache.beam.sdk.util.ShardingWritableByteChannel
Returns the WritableByteChannel associated with the given shard number.
getChannelFactory() - Method in class org.apache.beam.sdk.io.CompressedSource
 
getChannelNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
getCheckpointMark() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
Returns a UnboundedSource.CheckpointMark representing the progress of this UnboundedReader.
getCheckpointMarkCoder() - Method in class org.apache.beam.sdk.io.UnboundedSource
Returns a Coder for encoding and decoding the checkpoints for this source.
getClasses() - Method in class org.apache.beam.sdk.values.TypeDescriptor
Returns a set of TypeDescriptors, one for each superclass (including this class).
getClazz() - Method in class org.apache.beam.sdk.schemas.utils.ReflectUtils.ClassWithSchema
 
getCloningBehavior() - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
getClosingBehavior() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
getClosure() - Method in class org.apache.beam.sdk.transforms.Contextful
Returns the closure.
getClosureOfMethodsOnInterface(Class<?>) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
Returns all the methods visible from iface.
getClosureOfMethodsOnInterfaces(Iterable<? extends Class<?>>) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
Returns all the methods visible from the provided interfaces.
getCodec(DestinationT) - Method in class org.apache.beam.sdk.io.DynamicAvroDestinations
Return an AVRO codec for a given destination.
getCodedType(TypeDescriptor) - Static method in class org.apache.beam.sdk.util.CoderUtils
If coderType is a subclass of Coder<T> for a specific type T, returns T.class.
getCoder(Class<T>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
Returns the Coder to use for values of the given class.
getCoder(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
Returns the Coder to use for values of the given type.
getCoder(TypeDescriptor<OutputT>, TypeDescriptor<InputT>, Coder<InputT>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
Deprecated.
This method is to change in an unknown backwards incompatible way once support for this functionality is refined.
getCoder(Class<? extends T>, Class<T>, Map<Type, ? extends Coder<?>>, TypeVariable<?>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
Deprecated.
This method is to change in an unknown backwards incompatible way once support for this functionality is refined.
getCoder() - Method in class org.apache.beam.sdk.coders.DelegateCoder
Returns the coder used to encode/decode the intermediate values produced/consumed by the coding functions of this DelegateCoder.
getCoder() - Static method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
Returns a Coder suitable for IntervalWindow.
getCoder() - Method in class org.apache.beam.sdk.values.PCollection
Returns the Coder used by this PCollection to encode and decode the values stored in it.
getCoderArguments() - Method in class org.apache.beam.sdk.coders.AtomicCoder
If this is a Coder for a parameterized type, returns the list of Coders being used for each of the parameters in the same order they appear within the parameterized type's type signature.
getCoderArguments() - Method in class org.apache.beam.sdk.coders.Coder
If this is a Coder for a parameterized type, returns the list of Coders being used for each of the parameters in the same order they appear within the parameterized type's type signature.
getCoderArguments() - Method in class org.apache.beam.sdk.coders.CustomCoder
If this is a Coder for a parameterized type, returns the list of Coders being used for each of the parameters in the same order they appear within the parameterized type's type signature.
getCoderArguments() - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
 
getCoderArguments() - Method in class org.apache.beam.sdk.coders.KvCoder
 
getCoderArguments() - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
 
getCoderArguments() - Method in class org.apache.beam.sdk.coders.MapCoder
If this is a Coder for a parameterized type, returns the list of Coders being used for each of the parameters in the same order they appear within the parameterized type's type signature.
getCoderArguments() - Method in class org.apache.beam.sdk.coders.NullableCoder
 
getCoderArguments() - Method in class org.apache.beam.sdk.coders.ShardedKeyCoder
 
getCoderArguments() - Method in class org.apache.beam.sdk.coders.SnappyCoder
 
getCoderArguments() - Method in class org.apache.beam.sdk.coders.VarLongCoder
 
getCoderArguments() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResultCoder
 
getCoderArguments() - Method in class org.apache.beam.sdk.testing.TestStream.TestStreamCoder
 
getCoderArguments() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
 
getCoderArguments() - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
 
getCoderArguments() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindow.Coder
 
getCoderArguments() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
 
getCoderArguments() - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
 
getCoderArguments() - Method in class org.apache.beam.sdk.util.WindowedValue.FullWindowedValueCoder
If this is a Coder for a parameterized type, returns the list of Coders being used for each of the parameters in the same order they appear within the parameterized type's type signature.
getCoderArguments() - Method in class org.apache.beam.sdk.util.WindowedValue.ValueOnlyWindowedValueCoder
Deprecated.
 
getCoderArguments() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow.Coder
 
getCoderArguments() - Method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadataCoder
 
getCoderArguments() - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
 
getCoderArguments() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
 
getCoderArguments() - Method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
 
getCoderInternal() - Method in interface org.apache.beam.sdk.values.PCollectionView
Deprecated.
this method will be removed entirely. The PCollection underlying a side input, including its Coder, is part of the side input's specification with a ParDo transform, which will obtain that information via a package-private channel.
getCoderInternal() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
 
getCoderProvider() - Static method in class org.apache.beam.sdk.coders.AvroCoder
Returns a CoderProvider which uses the AvroCoder if possible for all types.
getCoderProvider() - Static method in class org.apache.beam.sdk.coders.SerializableCoder
Returns a CoderProvider which uses the SerializableCoder if possible for all types.
getCoderProviders() - Method in interface org.apache.beam.sdk.coders.CoderProviderRegistrar
Returns a list of coder providers which will be registered by default within each coder registry instance.
getCoderProviders() - Method in class org.apache.beam.sdk.coders.DefaultCoder.DefaultCoderProviderRegistrar
 
getCoderProviders() - Method in class org.apache.beam.sdk.coders.SerializableCoder.SerializableCoderProviderRegistrar
 
getCoderRegistry() - Method in class org.apache.beam.sdk.Pipeline
Returns the CoderRegistry that this Pipeline uses.
getCoGbkResultSchema() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
Returns the CoGbkResultSchema associated with this KeyedPCollectionTuple.
getCollection() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple.TaggedKeyedPCollection
Returns the underlying PCollection of this TaggedKeyedPCollection.
getCollectionElementType() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
getCombineFn() - Method in class org.apache.beam.sdk.transforms.Combine.GloballyAsSingletonView
 
getCommitted() - Method in class org.apache.beam.sdk.metrics.MetricResult
Return the value of this metric across all successfully completed parts of the pipeline.
getCommittedOrNull() - Method in class org.apache.beam.sdk.metrics.MetricResult
Return the value of this metric across all attempts of executing all parts of the pipeline.
getComponents() - Method in class org.apache.beam.sdk.coders.AtomicCoder
Returns the list of Coders that are components of this Coder.
getComponents() - Method in class org.apache.beam.sdk.coders.StructuredCoder
Returns the list of Coders that are components of this Coder.
getComponents() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
Hierarchy list of component paths making up the full path, starting with the top-level child component path.
getComponents() - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
 
getComponents() - Method in class org.apache.beam.sdk.util.WindowedValue.FullWindowedValueCoder
 
getComponents() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow.Coder
 
getComponents() - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
 
getComponents() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
 
getComponentType() - Method in class org.apache.beam.sdk.values.TypeDescriptor
Returns the component type if this type is an array type, otherwise returns null.
getCompression() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
Returns the method with which this file will be decompressed in FileIO.ReadableFile.open().
getCompression() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
 
getComputeNumShards() - Method in class org.apache.beam.sdk.io.WriteFiles
 
getConstructorCreator(Class<?>, Schema, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.AutoValueUtils
Try to find an accessible constructor for creating an AutoValue class.
getConstructorCreator(Class, Constructor, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
 
getConstructorCreator(Class, Constructor, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
 
getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterAll
 
getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterEach
 
getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterFirst
 
getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
 
getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
 
getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
 
getContinuationTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
 
getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
 
getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
 
getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
 
getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.Never.NeverTrigger
 
getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
 
getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
 
getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.ReshuffleTrigger
Deprecated.
 
getContinuationTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
Return a trigger to use after a GroupByKey to preserve the intention of this trigger.
getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
Subclasses should override this to return the Trigger.getContinuationTrigger() of this Trigger.
getContinuationTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger.OnceTrigger
 
getConvertedSchemaInformation(Schema, TypeDescriptor<T>, SchemaRegistry) - Static method in class org.apache.beam.sdk.schemas.utils.ConvertHelpers
Get the coder used for converting from an inputSchema to a given type.
getConvertedType() - Method in class org.apache.beam.sdk.coders.AvroCoder.JodaTimestampConversion
 
getConvertPrimitive(Schema.FieldType, TypeDescriptor<?>, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.ConvertHelpers
Returns a function to convert a Row into a primitive type.
getCount() - Method in class org.apache.beam.sdk.metrics.DistributionResult
 
getCount() - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
 
getCount(int) - Method in class org.apache.beam.sdk.util.HistogramData
Get the bucket count for the given bucketIndex.
getCounter(MetricName) - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
Return the Counter that should be used for implementing the given metricName in this container.
getCounters() - Method in class org.apache.beam.sdk.metrics.MetricQueryResults
Return the metric results for the counters that matched the filter.
getCreator(Class<T>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Get an object creator for an AVRO-generated SpecificRecord.
getCumulativeString(Set<MetricName>) - Method in interface org.apache.beam.sdk.metrics.MetricsLogger
 
getCurrent() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
 
getCurrent() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
Gets the current record from the delegate reader.
getCurrent() - Method in class org.apache.beam.sdk.io.Source.Reader
Returns the value of the data item that was read by the last Source.Reader.start() or Source.Reader.advance() call.
getCurrent() - Method in class org.apache.beam.sdk.runners.TransformHierarchy
 
getCurrentBlock() - Method in class org.apache.beam.sdk.io.AvroSource.AvroReader
 
getCurrentBlock() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
Returns the current block (the block that was read by the last successful call to BlockBasedSource.BlockBasedReader.readNextBlock()).
getCurrentBlockOffset() - Method in class org.apache.beam.sdk.io.AvroSource.AvroReader
 
getCurrentBlockOffset() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
Returns the largest offset such that starting to read from that offset includes the current block.
getCurrentBlockSize() - Method in class org.apache.beam.sdk.io.AvroSource.AvroReader
 
getCurrentBlockSize() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
Returns the size of the current block in bytes as it is represented in the underlying file, if possible.
getCurrentContainer() - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
Return the MetricsContainer for the current thread.
getCurrentDirectory() - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderResourceId
 
getCurrentDirectory() - Method in interface org.apache.beam.sdk.io.fs.ResourceId
Returns the ResourceId that represents the current directory of this ResourceId.
getCurrentOffset() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
 
getCurrentOffset() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
 
getCurrentOffset() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
Returns the starting offset of the current record, which has been read by the last successful Source.Reader.start() or Source.Reader.advance() call.
getCurrentRecord() - Method in class org.apache.beam.sdk.io.BlockBasedSource.Block
Returns the current record.
getCurrentRecordId() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
Returns a unique identifier for the current record.
getCurrentSource() - Method in class org.apache.beam.sdk.io.AvroSource.AvroReader
 
getCurrentSource() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
Returns a Source describing the same input that this Reader currently reads (including items already read).
getCurrentSource() - Method in class org.apache.beam.sdk.io.FileBasedSource.FileBasedReader
 
getCurrentSource() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
 
getCurrentSource() - Method in class org.apache.beam.sdk.io.Source.Reader
Returns a Source describing the same input that this Reader currently reads (including items already read).
getCurrentSource() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
Returns the UnboundedSource that created this reader.
getCurrentTimestamp() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
By default, returns the minimum possible timestamp.
getCurrentTimestamp() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
 
getCurrentTimestamp() - Method in class org.apache.beam.sdk.io.Source.Reader
Returns the timestamp associated with the current data item.
getDateTime(String) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.DATETIME value by field name, IllegalStateException is thrown if schema doesn't match.
getDateTime(int) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.DATETIME value by field index, IllegalStateException is thrown if schema doesn't match.
getDatumWriterFactory(DestinationT) - Method in class org.apache.beam.sdk.io.DynamicAvroDestinations
Return a AvroSink.DatumWriterFactory for a given destination.
getDayOfMonth() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
 
getDayOfMonth() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
 
getDecimal(String) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.DECIMAL value by field name, IllegalStateException is thrown if schema doesn't match.
getDecimal(int) - Method in class org.apache.beam.sdk.values.Row
Get a BigDecimal value by field index, ClassCastException is thrown if schema doesn't match.
getDefaultDestination() - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
Returns the default destination.
getDefaultDockerRepoPrefix() - Method in class org.apache.beam.sdk.util.ReleaseInfo
Provides docker image default repo prefix (beam_).
getDefaultDockerRepoRoot() - Method in class org.apache.beam.sdk.util.ReleaseInfo
Provides docker image default root (apache).
getDefaultEnvironmentConfig() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
getDefaultEnvironmentType() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
getDefaultOutputCoder() - Method in class org.apache.beam.sdk.io.Source
Deprecated.
Override Source.getOutputCoder() instead.
getDefaultOutputCoder(CoderRegistry, Coder<Double>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
 
getDefaultOutputCoder(CoderRegistry, Coder<V>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
 
getDefaultOutputCoder(CoderRegistry, Coder<Integer>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
 
getDefaultOutputCoder(CoderRegistry, Coder<Long>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
 
getDefaultOutputCoder(CoderRegistry, Coder<InputT>) - Method in interface org.apache.beam.sdk.transforms.CombineFnBase.GlobalCombineFn
Returns the Coder to use by default for output OutputT values, or null if it is not able to be inferred.
getDefaultOutputCoder() - Method in class org.apache.beam.sdk.transforms.PTransform
Deprecated.
Instead, the PTransform should explicitly call PCollection.setCoder(org.apache.beam.sdk.coders.Coder<T>) on the returned PCollection.
getDefaultOutputCoder(InputT) - Method in class org.apache.beam.sdk.transforms.PTransform
Deprecated.
Instead, the PTransform should explicitly call PCollection.setCoder(org.apache.beam.sdk.coders.Coder<T>) on the returned PCollection.
getDefaultOutputCoder(InputT, PCollection<T>) - Method in class org.apache.beam.sdk.transforms.PTransform
Deprecated.
Instead, the PTransform should explicitly call PCollection.setCoder(org.apache.beam.sdk.coders.Coder<T>) on the returned PCollection.
getDefaultOutputCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
 
getDefaultSdkHarnessLogLevel() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
This option controls the default log level of all loggers without a log level override.
getDefaultValue() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
Deprecated.
Returns the default value that was specified.
getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
 
getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn
 
getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
 
getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
Return a WindowMappingFn that returns the earliest window that contains the end of the main-input window.
getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
Returns the default WindowMappingFn to use to map main input windows to side input windows.
getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.util.IdentityWindowFn
 
getDelay() - Method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform.Delay
 
getDelimiters() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
 
getDescription() - Method in class org.apache.beam.sdk.schemas.Schema.Field
Returns the field's description.
getDestination(UserT) - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
Returns an object that represents at a high level the destination being written to.
getDestination() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
 
getDestination() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
Return the user destination object for this writer.
getDestinationCoder() - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
Returns the coder for DestinationT.
getDestinationFile(boolean, FileBasedSink.DynamicDestinations<?, DestinationT, ?>, int, FileBasedSink.OutputFileHints) - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
 
getDirectoryTreatment() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
 
getDistribution(MetricName) - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
Return the Distribution that should be used for implementing the given metricName in this container.
getDistributions() - Method in class org.apache.beam.sdk.metrics.MetricQueryResults
Return the metric results for the distributions that matched the filter.
getDlqTransform(String) - Static method in class org.apache.beam.sdk.schemas.io.GenericDlq
 
getDoFn() - Method in class org.apache.beam.sdk.util.DoFnInfo
Returns the embedded function.
getDoFn() - Method in class org.apache.beam.sdk.util.DoFnWithExecutionInformation
 
getDoFnSchemaInformation(DoFn<?, ?>, PCollection<?>) - Static method in class org.apache.beam.sdk.transforms.ParDo
Extract information on how the DoFn uses schemas.
getDoFnSchemaInformation() - Method in class org.apache.beam.sdk.util.DoFnInfo
 
getDouble(String) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.DOUBLE value by field name, IllegalStateException is thrown if schema doesn't match.
getDouble(int) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.DOUBLE value by field index, ClassCastException is thrown if schema doesn't match.
getDynamicDestinations() - Method in class org.apache.beam.sdk.io.AvroSink
 
getDynamicDestinations() - Method in class org.apache.beam.sdk.io.FileBasedSink
getEarlyTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
 
getElemCoder() - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
 
getElementCoders() - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
 
getElementConverters() - Method in class org.apache.beam.sdk.transforms.DoFnSchemaInformation
The schema of the @Element parameter.
getElementCount() - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
The number of elements after which this trigger may fire.
getElements() - Method in class org.apache.beam.sdk.testing.TestStream.ElementEvent
 
getElements() - Method in class org.apache.beam.sdk.transforms.Create.Values
 
getElementType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
If the field is a container type, returns the element type.
getEmptyMatchTreatment() - Method in class org.apache.beam.sdk.io.FileBasedSource
 
getEmptyMatchTreatment() - Method in class org.apache.beam.sdk.io.FileIO.MatchConfiguration
 
getEmptyMatchTreatment() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
 
getEnclosingNode() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
Returns the enclosing composite transform node, or null if there is none.
getEncodedElementByteSize(BigDecimal) - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
Returns the size in bytes of the encoded value using this coder.
getEncodedElementByteSize(Integer) - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
Returns the size in bytes of the encoded value using this coder.
getEncodedElementByteSize(Long) - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
Returns the size in bytes of the encoded value using this coder.
getEncodedElementByteSize(Short) - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
Returns the size in bytes of the encoded value using this coder.
getEncodedElementByteSize(BigInteger) - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
Returns the size in bytes of the encoded value using this coder.
getEncodedElementByteSize(Boolean) - Method in class org.apache.beam.sdk.coders.BooleanCoder
 
getEncodedElementByteSize(byte[]) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
 
getEncodedElementByteSize(Byte) - Method in class org.apache.beam.sdk.coders.ByteCoder
Returns the size in bytes of the encoded value using this coder.
getEncodedElementByteSize(T) - Method in class org.apache.beam.sdk.coders.Coder
Returns the size in bytes of the encoded value using this coder.
getEncodedElementByteSize(Double) - Method in class org.apache.beam.sdk.coders.DoubleCoder
Returns the size in bytes of the encoded value using this coder.
getEncodedElementByteSize(Float) - Method in class org.apache.beam.sdk.coders.FloatCoder
Returns the size in bytes of the encoded value using this coder.
getEncodedElementByteSize(Instant) - Method in class org.apache.beam.sdk.coders.InstantCoder
 
getEncodedElementByteSize(T) - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
Overridden to short-circuit the default StructuredCoder behavior of encoding and counting the bytes.
getEncodedElementByteSize(T) - Method in class org.apache.beam.sdk.coders.NullableCoder
Overridden to short-circuit the default StructuredCoder behavior of encoding and counting the bytes.
getEncodedElementByteSize(String) - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
Returns the size in bytes of the encoded value using this coder.
getEncodedElementByteSize(Integer) - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
 
getEncodedElementByteSize(Integer) - Method in class org.apache.beam.sdk.coders.VarIntCoder
 
getEncodedElementByteSize(Long) - Method in class org.apache.beam.sdk.coders.VarLongCoder
 
getEncodedElementByteSize(Void) - Method in class org.apache.beam.sdk.coders.VoidCoder
 
getEncodedElementByteSize(OffsetRange) - Method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.AvroCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.ByteCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.Coder
Returns the TypeDescriptor for the type encoded.
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.CollectionCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.DelegateCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.DequeCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.DoubleCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.DurationCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.FloatCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.InstantCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.IterableCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.KvCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.ListCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.MapCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.NullableCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.SerializableCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.SetCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.VarIntCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.VarLongCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.VoidCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
 
getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
 
getEncodingPositions() - Method in class org.apache.beam.sdk.schemas.Schema
Gets the encoding positions for this schema.
getEndKey() - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
Returns the ByteKey representing the upper bound of this ByteKeyRange.
getEndOffset() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
Returns the specified ending offset of the source.
getEnvironmentCacheMillis() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
getEnvironmentExpirationMillis() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
getEnvironmentId() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
getEnvironmentOption(PortablePipelineOptions, String) - Static method in interface org.apache.beam.sdk.options.PortablePipelineOptions
Return the value for the specified environment option or empty string if not present.
getEnvironmentOptions() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
getError() - Method in class org.apache.beam.sdk.schemas.io.Failure
Information about the cause of the failure.
getErrorContext() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
Return a human readable representation of the current call context to be used during error reporting.
getErrorContext() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
getErrorContext() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.FakeArgumentProvider
 
getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.BoundedSource
An estimate of the total size (in bytes) of the data that would be read from this source.
getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSource
 
getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.OffsetBasedSource
 
getEvents() - Method in class org.apache.beam.sdk.testing.TestStream
Returns the sequence of Events in this TestStream.
getException() - Method in class org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult
 
getExperiments() - Method in interface org.apache.beam.sdk.options.ExperimentalOptions
 
getExperimentValue(PipelineOptions, String) - Static method in interface org.apache.beam.sdk.options.ExperimentalOptions
Return the value for the specified experiment or null if not present.
getExposedClasses() - Method in class org.apache.beam.sdk.util.ApiSurface
Returns exposed types in this set, including arrays and primitives as specified.
getFactory() - Method in class org.apache.beam.sdk.schemas.utils.AvroUtils.AvroConvertValueForGetter
 
getFactory() - Method in class org.apache.beam.sdk.schemas.utils.AvroUtils.AvroConvertValueForSetter
 
getFactory() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
 
getFactory() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
 
getFailedToParseLines() - Method in class org.apache.beam.sdk.transforms.JsonToRow.ParseResult
Returns a PCollection containing the Rows that didn't parse.
getFailsafeValue() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow
Returns the failsafe value of this FailsafeValueInSingleWindow.
getFanout() - Method in class org.apache.beam.sdk.transforms.Combine.GloballyAsSingletonView
 
getField() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
 
getField(int) - Method in class org.apache.beam.sdk.schemas.Schema
Return a field by index.
getField(String) - Method in class org.apache.beam.sdk.schemas.Schema
 
getFieldCount() - Method in class org.apache.beam.sdk.schemas.Schema
Return the count of fields.
getFieldCount() - Method in class org.apache.beam.sdk.values.Row
Return the size of data fields.
getFieldCount() - Method in class org.apache.beam.sdk.values.RowWithGetters
 
getFieldCount() - Method in class org.apache.beam.sdk.values.RowWithStorage
 
getFieldId() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
 
getFieldName() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
 
getFieldNames() - Method in class org.apache.beam.sdk.schemas.Schema
Return the list of all field names.
getFieldRename() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
 
getFields() - Method in class org.apache.beam.sdk.schemas.Schema
 
getFields(Class<?>) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
 
getFieldsAccessed() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
 
getFieldType(OneOfType.Value) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
 
getFieldTypes(Class<T>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Get field types for an AVRO-generated SpecificRecord or a POJO.
getFieldTypes(Class<?>, Schema, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
 
getFieldTypes(Class<?>, Schema, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
 
getFilename() - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderResourceId
 
getFilename(BoundedWindow, PaneInfo, int, int, Compression) - Method in interface org.apache.beam.sdk.io.FileIO.Write.FileNaming
Generates the filename.
getFilename() - Method in interface org.apache.beam.sdk.io.fs.ResourceId
Returns the name of the file or directory denoted by this ResourceId.
getFilenamePolicy(DestinationT) - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
Converts a destination into a FileBasedSink.FilenamePolicy.
getFileOrPatternSpec() - Method in class org.apache.beam.sdk.io.FileBasedSource
 
getFileOrPatternSpecProvider() - Method in class org.apache.beam.sdk.io.FileBasedSource
 
getFilePattern() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
 
getFilePattern() - Method in class org.apache.beam.sdk.util.NumberedShardedFile
 
getFilesToStage() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
List of local files to make available to workers.
getFloat(String) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.FLOAT value by field name, IllegalStateException is thrown if schema doesn't match.
getFloat(int) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.FLOAT value by field index, ClassCastException is thrown if schema doesn't match.
getFn() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
Returns the CombineFnBase.GlobalCombineFn used by this Combine operation.
getFn() - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
Returns the CombineFnBase.GlobalCombineFn used by this Combine operation.
getFn() - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
Returns the CombineFnBase.GlobalCombineFn used by this Combine operation.
getFn() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
 
getFn() - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
 
getFn() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Get the bound DoFn.
getFn() - Method in class org.apache.beam.sdk.util.AppliedCombineFn
 
getFractionConsumed() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
 
getFractionConsumed() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
Returns a value in [0, 1] representing approximately what fraction of the current source this reader has read so far, or null if such an estimate is not available.
getFractionConsumed() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
 
getFractionConsumed() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
 
getFractionConsumed() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
 
getFractionConsumed() - Method in interface org.apache.beam.sdk.io.range.RangeTracker
Returns the approximate fraction of positions in the source that have been consumed by successful RangeTracker.tryReturnRecordAt(boolean, PositionT) calls, or 0.0 if no such calls have happened.
getFractionOfBlockConsumed() - Method in class org.apache.beam.sdk.io.BlockBasedSource.Block
Returns the fraction of the block already consumed, if possible, as a value in [0, 1].
getFrom() - Method in class org.apache.beam.sdk.io.range.OffsetRange
 
getFromRowFunction() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
Returns the toRow conversion function.
getFromRowFunction(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Retrieve the function that converts a Row object to the specified type.
getFromRowFunction(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Retrieve the function that converts a Row object to the specified type.
getFromRowFunction(Class<T>) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
 
getFromRowFunction() - Method in class org.apache.beam.sdk.values.PCollection
Returns the attached schema's fromRowFunction.
getFullCoder(Coder<T>, Coder<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.util.WindowedValue
Returns the Coder to use for a WindowedValue<T>, using the given valueCoder and windowCoder.
getFullName() - Method in class org.apache.beam.sdk.runners.AppliedPTransform
 
getFullName() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
 
getGapDuration() - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
 
getGauge(MetricName) - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
Return the Gauge that should be used for implementing the given metricName in this container.
getGauges() - Method in class org.apache.beam.sdk.metrics.MetricQueryResults
Return the metric results for the gauges that matched the filter.
getGenericRecordToRowFunction(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
getGetters(Class<T>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Get generated getters for an AVRO-generated SpecificRecord or a POJO.
getGetters(Class<?>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
Return the list of FieldValueGetters for a Java Bean class
getGetters(Class<?>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
 
getGetters() - Method in class org.apache.beam.sdk.values.RowWithGetters
 
getGetterTarget() - Method in class org.apache.beam.sdk.values.RowWithGetters
 
getGrammarFileName() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
getGrammarFileName() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
getGroupingTableMaxSizeMb() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
Size (in MB) of each grouping table used to pre-combine elements.
getHistogram(MetricName, HistogramData.BucketType) - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
Return the Histogram that should be used for implementing the given metricName in this container.
getId() - Method in class org.apache.beam.sdk.values.TupleTag
Returns the id of this TupleTag.
getId() - Method in class org.apache.beam.sdk.values.ValueWithRecordId
 
getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Date
 
getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
 
getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
 
getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
 
getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
 
getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
 
getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
 
getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Time
 
getIdentifier() - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
The unique identifier for this type.
getIncompatibleGlobalWindowErrorMessage() - Method in interface org.apache.beam.sdk.transforms.CombineFnBase.GlobalCombineFn
Returns the error message for not supported default values in Combine.globally().
getIncompatibleGlobalWindowErrorMessage() - Method in class org.apache.beam.sdk.transforms.Top.TopCombineFn
 
getIndex(TupleTag<?>) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
Returns the index for the given tuple tag, if the tag is present in this schema, -1 if it isn't.
getIndex() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
The zero-based index of this trigger firing that produced this pane.
getInitialRestriction() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.GetInitialRestriction method.
GetInitialRestrictionMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialRestrictionMethod
 
getInitialWatermarkEstimatorState() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.GetInitialWatermarkEstimatorState method.
GetInitialWatermarkEstimatorStateMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialWatermarkEstimatorStateMethod
 
getInput() - Method in class org.apache.beam.sdk.runners.PTransformOverrideFactory.PTransformReplacement
 
getInputCoder() - Method in class org.apache.beam.sdk.util.DoFnInfo
 
getInputs() - Method in class org.apache.beam.sdk.runners.AppliedPTransform
 
getInputs() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
Returns the transform input, in fully expanded form.
getInputType() - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
Returns a TypeDescriptor capturing what is known statically about the input type of this CombineFn instance's most-derived class.
getInputTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.DoFn
Returns a TypeDescriptor capturing what is known statically about the input type of this DoFn instance's most-derived class.
getInputTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.InferableFunction
Returns a TypeDescriptor capturing what is known statically about the input type of this InferableFunction instance's most-derived class.
getInputValueCoder(Coder<KV<K, V>>) - Static method in class org.apache.beam.sdk.transforms.GroupByKey
Returns the Coder of the values of the input to this transform.
getInsertDefault() - Method in class org.apache.beam.sdk.transforms.Combine.GloballyAsSingletonView
 
getInt16(String) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.INT16 value by field name, IllegalStateException is thrown if schema doesn't match.
getInt16(int) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.INT16 value by field index, ClassCastException is thrown if schema doesn't match.
getInt32(String) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.INT32 value by field name, IllegalStateException is thrown if schema doesn't match.
getInt32(int) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.INT32 value by field index, ClassCastException is thrown if schema doesn't match.
getInt64(String) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.INT64 value by field name, IllegalStateException is thrown if schema doesn't match.
getInt64(int) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.INT64 value by field index, ClassCastException is thrown if schema doesn't match.
getInterfaces() - Method in class org.apache.beam.sdk.values.TypeDescriptor
Returns a set of TypeDescriptors, one for each interface implemented by this class.
getIsLazy() - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObserver
Returns whether byte counting for the current element is lazy, that is, whether the observer gets notified of the element's byte count only as element's pieces are being processed or iterated over.
getIterable(String) - Method in class org.apache.beam.sdk.values.Row
Get an iterable value by field name, IllegalStateException is thrown if schema doesn't match.
getIterable(int) - Method in class org.apache.beam.sdk.values.Row
Get an iterable value by field index, IllegalStateException is thrown if schema doesn't match.
getIterableComponentType(TypeDescriptor) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
For an array T[] or a subclass of Iterable, return a TypeDescriptor describing T.
getJobEndpoint() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
getJobName() - Method in interface org.apache.beam.sdk.options.PipelineOptions
 
getJsonToRowWithErrFn() - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError
 
getKey() - Method in class org.apache.beam.sdk.metrics.MetricResult
 
getKey() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
 
getKey() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
The key for the display item.
getKey() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
The key for the display item.
getKey() - Method in class org.apache.beam.sdk.util.ShardedKey
 
getKey() - Method in class org.apache.beam.sdk.values.KV
Returns the key of this KV.
getKey() - Method in class org.apache.beam.sdk.values.ShardedKey
 
getKeyCoder() - Method in class org.apache.beam.sdk.coders.KvCoder
 
getKeyCoder() - Method in class org.apache.beam.sdk.coders.MapCoder
 
getKeyCoder(Coder<KV<K, V>>) - Static method in class org.apache.beam.sdk.transforms.GroupByKey
Returns the Coder of the keys of the input to this transform, which is also used as the Coder of the keys of the output of this transform.
getKeyCoder() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
Returns the key Coder for all PCollections in this KeyedPCollectionTuple.
getKeyCoder() - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
 
getKeyedCollections() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
Returns a list of TaggedKeyedPCollections for the PCollections contained in this KeyedPCollectionTuple.
getKind() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
 
getKindString() - Method in class org.apache.beam.sdk.io.BoundedReadFromUnboundedSource
 
getKindString() - Method in class org.apache.beam.sdk.io.Read.Bounded
 
getKindString() - Method in class org.apache.beam.sdk.io.Read.Unbounded
 
getKindString() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
 
getKindString() - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
 
getKindString() - Method in class org.apache.beam.sdk.transforms.Combine.PerKeyWithHotKeyFanout
 
getKindString() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
 
getKindString() - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
 
getKindString() - Method in class org.apache.beam.sdk.transforms.PTransform
Returns the name to use by default for this PTransform (not including the names of any enclosing PTransforms).
getKindString() - Method in class org.apache.beam.sdk.transforms.windowing.Window
 
getKindString() - Method in class org.apache.beam.sdk.values.PValueBase
Returns a String capturing the kind of this PValueBase.
getKvCoder() - Method in class org.apache.beam.sdk.util.AppliedCombineFn
 
getLabel() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
Retrieve the optional label for an item.
getLabel() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
The optional label for an item.
getLastEmitted() - Method in class org.apache.beam.sdk.io.CountingSource.CounterMark
Returns the last value emitted by the reader.
getLastFieldId() - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
getLateTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
 
getLength() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
 
getLength(int) - Static method in class org.apache.beam.sdk.util.VarInt
Returns the length of the encoding of the given value (in bytes).
getLength(long) - Static method in class org.apache.beam.sdk.util.VarInt
Returns the length of the encoding of the given value (in bytes).
getLevenshteinDistance(String, String) - Static method in class org.apache.beam.sdk.util.StringUtils
Calculate the Levenshtein distance between two strings.
getLinkUrl() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
Retrieve the optional link URL for an item.
getLinkUrl() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
The optional link URL for an item.
getList() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
 
getLoadBalanceBundles() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
getLogicalType() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
getLogicalType(Class<LogicalTypeT>) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
Helper function for retrieving the concrete logical type subclass.
getLogicalTypeName() - Method in class org.apache.beam.sdk.coders.AvroCoder.JodaTimestampConversion
 
getLogicalTypeValue(String, Class<T>) - Method in class org.apache.beam.sdk.values.Row
 
getLogicalTypeValue(int, Class<T>) - Method in class org.apache.beam.sdk.values.Row
Returns the Logical Type input type for this field.
getMainInputs() - Method in class org.apache.beam.sdk.runners.AppliedPTransform
 
getMainOutput() - Method in class org.apache.beam.sdk.util.DoFnInfo
 
getMainOutputReceiver() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
The DoFnSignature.Parameter.OutputReceiverParameter for a main output, or null if there is none.
getMainOutputTag() - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
getMainOutputTag() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
 
getMainOutputTag() - Method in class org.apache.beam.sdk.util.DoFnWithExecutionInformation
 
getMainTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
The main trigger, which will continue firing until the "until" trigger fires.
getMap() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
 
getMap(String) - Method in class org.apache.beam.sdk.values.Row
Get a MAP value by field name, IllegalStateException is thrown if schema doesn't match.
getMap(int) - Method in class org.apache.beam.sdk.values.Row
Get a MAP value by field index, IllegalStateException is thrown if schema doesn't match.
getMapKeyType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
If the field is a map type, returns the key type.
getMapKeyType() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
getMapType(TypeDescriptor, int) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
 
getMapValueType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
If the field is a map type, returns the key type.
getMapValueType() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
getMatcher() - Method in class org.apache.beam.sdk.runners.PTransformOverride
Gets the PTransformMatcher to identify PTransforms to replace.
getMaterialization() - Method in class org.apache.beam.sdk.transforms.ViewFn
Gets the materialization of this ViewFn.
getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn
Deprecated.
 
getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.ListViewFn
Deprecated.
 
getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.MapViewFn
Deprecated.
 
getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn
Deprecated.
 
getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
Deprecated.
 
getMax() - Method in class org.apache.beam.sdk.metrics.DistributionResult
 
getMaxBufferingDuration() - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches.BatchingParams
 
getMaxEndOffset(PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSource
 
getMaxEndOffset(PipelineOptions) - Method in class org.apache.beam.sdk.io.OffsetBasedSource
Returns the actual ending offset of the current source.
getMean() - Method in class org.apache.beam.sdk.metrics.DistributionResult
 
getMean() - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
 
getMessage() - Method in exception org.apache.beam.sdk.coders.Coder.NonDeterministicException
 
getMessage() - Method in exception org.apache.beam.sdk.transforms.windowing.IncompatibleWindowException
 
getMetadata(DestinationT) - Method in class org.apache.beam.sdk.io.DynamicAvroDestinations
Return AVRO file metadata for a given destination.
getMetadata() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
Returns the MatchResult.Metadata of the file.
getMetadata(String) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
Deprecated.
use schema options instead.
getMetadata() - Method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadata
 
getMetadataString(String) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
Deprecated.
use schema options instead.
getMethod() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
 
getMethods(Class) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
Returns the list of non private/protected, non-static methods in the class, caching the results.
getMethodsMap(Class) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
 
getMetricLogger() - Method in interface org.apache.beam.sdk.metrics.MetricsLogger
 
getMetricsGraphiteHost() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
 
getMetricsGraphitePort() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
 
getMetricsHttpSinkUrl() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
 
getMetricsPushPeriod() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
 
getMetricsSink() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
 
getMimeType() - Method in enum org.apache.beam.sdk.io.FileBasedSink.CompressionType
Deprecated.
 
getMimeType() - Method in interface org.apache.beam.sdk.io.FileBasedSink.OutputFileHints
Returns the MIME type that should be used for the files that will hold the output data.
getMin() - Method in class org.apache.beam.sdk.metrics.DistributionResult
 
getMinBundleSize() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
Returns the minimum bundle size that should be used when splitting the source into sub-sources.
getMode() - Method in class org.apache.beam.sdk.io.FileBasedSource
 
getMode() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
getModeNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
getMonthOfYear() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
 
getMutableOutput(TupleTag<T>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
getName() - Method in class org.apache.beam.sdk.metrics.DelegatingCounter
 
getName() - Method in class org.apache.beam.sdk.metrics.DelegatingDistribution
 
getName() - Method in class org.apache.beam.sdk.metrics.DelegatingHistogram
 
getName() - Method in interface org.apache.beam.sdk.metrics.Metric
The MetricName given to this metric.
getName() - Method in class org.apache.beam.sdk.metrics.MetricName
The name of this metric.
getName() - Method in class org.apache.beam.sdk.metrics.MetricNameFilter
If set, the metric must have this name to match this MetricNameFilter.
getName() - Method in class org.apache.beam.sdk.metrics.MetricResult
Return the name of the metric.
getName() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
Returns the field name.
getName() - Method in class org.apache.beam.sdk.schemas.Schema.Field
Returns the field name.
getName() - Method in class org.apache.beam.sdk.transforms.PTransform
Returns the transform name.
getName() - Method in class org.apache.beam.sdk.util.ReleaseInfo
Provides the SDK name.
getName() - Method in class org.apache.beam.sdk.values.PCollection
Returns the name of this PCollection.
getName() - Method in interface org.apache.beam.sdk.values.PValue
Returns the name of this PValue.
getName() - Method in class org.apache.beam.sdk.values.PValueBase
Returns the name of this PValueBase.
getNameOverride(String, T) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
 
getNameOverride() - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
 
getNameOverride() - Method in class org.apache.beam.sdk.transforms.Top.TopCombineFn
 
getNameOverride() - Method in interface org.apache.beam.sdk.util.NameUtils.NameOverride
Return the name to use for this instance.
getNamespace() - Method in class org.apache.beam.sdk.metrics.MetricName
The namespace associated with this metric.
getNamespace() - Method in class org.apache.beam.sdk.metrics.MetricNameFilter
The inNamespace that a metric must be in to match this MetricNameFilter.
getNamespace() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
 
getNamespace() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
The namespace for the display item.
getNamespace() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
The namespace for the display item.
getNestedFieldsAccessed() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
 
getNewValue() - Method in exception org.apache.beam.sdk.util.IllegalMutationException
The value after the illegal mutation.
getNonSpeculativeIndex() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
The zero-based index of this trigger firing among non-speculative panes.
getNullable() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
getNumber() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
 
getNumber() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
 
getNumber() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
 
getNumBuckets() - Method in interface org.apache.beam.sdk.util.HistogramData.BucketType
 
getNumBuckets() - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
 
getNumSampledBytesPerFile() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
 
getNumShards() - Method in class org.apache.beam.sdk.util.ShardingWritableByteChannel
Returns the number of output shards.
getNumShardsProvider() - Method in class org.apache.beam.sdk.io.WriteFiles
 
getOffset() - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
 
getOffset() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
 
getOffset() - Method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform.AlignTo
 
getOnCreateMatcher() - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
 
getOneOfSchema() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
Returns the schema of the underlying Row that is used to represent the union.
getOneOfTypes() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
 
getOnly(TupleTag<V>) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
If there is a singleton value for the given tag, returns it.
getOnly(String) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
Like CoGbkResult.getOnly(TupleTag) but using a String instead of a TupleTag.
getOnly(TupleTag<V>, V) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
If there is a singleton value for the given tag, returns it.
getOnly(String, V) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
Like CoGbkResult.getOnly(TupleTag, Object) but using a String instead of a TupleTag.
getOnSuccessMatcher() - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
 
getOnTimeBehavior() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
getOptionNames() - Method in class org.apache.beam.sdk.schemas.Schema.Options
 
getOptions() - Method in class org.apache.beam.sdk.Pipeline
 
getOptions() - Method in class org.apache.beam.sdk.schemas.Schema.Field
Returns the fields Schema.Options.
getOptions() - Method in class org.apache.beam.sdk.schemas.Schema
 
getOptions() - Method in class org.apache.beam.sdk.testing.TestPipeline
 
getOptionsId() - Method in interface org.apache.beam.sdk.options.PipelineOptions
Provides a process wide unique ID for this PipelineOptions object, assigned at graph construction time.
getOrDefault(K, V) - Method in interface org.apache.beam.sdk.state.MapState
A deferred lookup.
getOriginal() - Method in class org.apache.beam.sdk.runners.PTransformOverrideFactory.ReplacementOutput
 
getOutName(int) - Method in class org.apache.beam.sdk.values.TupleTag
If this TupleTag is tagging output outputIndex of a PTransform, returns the name that should be used by default for the output.
getOutputCoder(SerializableFunction<InputT, OutputT>, Coder<InputT>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
Deprecated.
This method is to change in an unknown backwards incompatible way once support for this functionality is refined.
getOutputCoder() - Method in class org.apache.beam.sdk.io.AvroSource
 
getOutputCoder() - Method in class org.apache.beam.sdk.io.CompressedSource
Returns the delegate source's output coder.
getOutputCoder() - Method in class org.apache.beam.sdk.io.Source
Returns the Coder to use for the data read from this source.
getOutputCoders() - Method in class org.apache.beam.sdk.util.DoFnInfo
 
getOutputExecutablePath() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
getOutputFile() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
 
getOutputKvCoder(Coder<KV<K, V>>) - Static method in class org.apache.beam.sdk.transforms.GroupByKey
Returns the Coder of the output of this transform.
getOutputs() - Method in class org.apache.beam.sdk.runners.AppliedPTransform
 
getOutputs() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
Returns the transform output, in expanded form.
getOutputSchema(Schema, FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.utils.SelectHelpers
Get the output schema resulting from selecting the given FieldAccessDescriptor from the given schema.
getOutputStrategyInternal(WindowingStrategy<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.Window
Get the output strategy of this Window PTransform.
getOutputTime(Instant, GlobalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
 
getOutputTime(Instant, W) - Method in class org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn
 
getOutputTime(Instant, IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
Ensures that later sliding windows have an output time that is past the end of earlier windows.
getOutputTime(Instant, W) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
Returns the output timestamp to use for data depending on the given inputTimestamp in the specified window.
getOutputTime(Instant, BoundedWindow) - Method in class org.apache.beam.sdk.util.IdentityWindowFn
 
getOutputType() - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
Returns a TypeDescriptor capturing what is known statically about the output type of this CombineFn instance's most-derived class.
getOutputTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.DoFn
Returns a TypeDescriptor capturing what is known statically about the output type of this DoFn instance's most-derived class.
getOutputTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.InferableFunction
Returns a TypeDescriptor capturing what is known statically about the output type of this InferableFunction instance's most-derived class.
getOverrideFactory() - Method in class org.apache.beam.sdk.runners.PTransformOverride
Gets the PTransformOverrideFactory of this override.
getPane() - Method in class org.apache.beam.sdk.util.WindowedValue
Returns the pane of this WindowedValue in its window.
getPane() - Method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
 
getPane() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow
Returns the pane of this FailsafeValueInSingleWindow in its window.
getPane() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
Returns the pane of this ValueInSingleWindow in its window.
getPaneInfo() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
 
getParamWindowedValueCoder(Coder<T>) - Static method in class org.apache.beam.sdk.util.WindowedValue
Returns the ParamWindowedValueCoder from the given valueCoder.
getPath() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
 
getPath() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
The path for the display item within a component hierarchy.
getPayload() - Method in class org.apache.beam.sdk.schemas.io.Failure
Bytes containing the payload which has failed.
getPayload(WindowedValue.ParamWindowedValueCoder<?>) - Static method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
Returns the serialized payload that will be provided when deserializing this coder.
getPCollection() - Method in interface org.apache.beam.sdk.values.PCollectionView
For internal use only.
getPCollection() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
 
getPercentileString(String, String) - Method in class org.apache.beam.sdk.util.HistogramData
 
getPerDestinationOutputFilenames() - Method in class org.apache.beam.sdk.io.WriteFilesResult
Returns a PCollection of all output filenames generated by this WriteFiles organized by user destination type.
getPeriod() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
 
getPeriod() - Method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform.AlignTo
 
getPipeline() - Method in class org.apache.beam.sdk.io.WriteFilesResult
 
getPipeline() - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
 
getPipeline() - Method in class org.apache.beam.sdk.runners.AppliedPTransform
 
getPipeline() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
 
getPipeline() - Method in class org.apache.beam.sdk.transforms.JsonToRow.ParseResult
 
getPipeline() - Method in class org.apache.beam.sdk.transforms.WithFailures.Result
 
getPipeline() - Method in class org.apache.beam.sdk.values.PBegin
 
getPipeline() - Method in class org.apache.beam.sdk.values.PCollectionList
 
getPipeline() - Method in class org.apache.beam.sdk.values.PCollectionTuple
 
getPipeline() - Method in class org.apache.beam.sdk.values.PDone
 
getPipeline() - Method in interface org.apache.beam.sdk.values.PInput
Returns the owning Pipeline of this PInput.
getPipeline() - Method in interface org.apache.beam.sdk.values.POutput
Returns the owning Pipeline of this POutput.
getPipeline() - Method in class org.apache.beam.sdk.values.PValueBase
 
getPipelineOptions() - Method in class org.apache.beam.sdk.options.DefaultPipelineOptionsRegistrar
 
getPipelineOptions() - Method in class org.apache.beam.sdk.options.ManualDockerEnvironmentOptions.Options
 
getPipelineOptions() - Method in interface org.apache.beam.sdk.options.PipelineOptionsRegistrar
 
getPipelineOptions() - Method in class org.apache.beam.sdk.options.RemoteEnvironmentOptions.Options
 
getPipelineOptions() - Method in interface org.apache.beam.sdk.state.StateContext
Returns the PipelineOptions specified with the PipelineRunner.
getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.CombineWithContext.Context
Returns the PipelineOptions specified with the PipelineRunner invoking this KeyedCombineFn.
getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.DoFn.FinishBundleContext
Returns the PipelineOptions specified with the PipelineRunner invoking this DoFn.
getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.DoFn.StartBundleContext
Returns the PipelineOptions specified with the PipelineRunner invoking this DoFn.
getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
Returns the PipelineOptions specified with the PipelineRunner invoking this DoFn.
getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
getPipelineRunners() - Method in interface org.apache.beam.sdk.runners.PipelineRunnerRegistrar
Get the set of PipelineRunners to register.
getPositionForFractionConsumed(double) - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
Returns a position P such that the range [start, P) represents approximately the given fraction of the range [start, end).
getPrimary() - Method in class org.apache.beam.sdk.transforms.splittabledofn.SplitResult
Returns the primary restriction.
getProcessingTimeAdvance() - Method in class org.apache.beam.sdk.testing.TestStream.ProcessingTimeEvent
 
getProcessWideContainer() - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
Return the MetricsContainer for the current process.
getProgress() - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.OutputRangeTracker
 
getProgress() - Method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
 
getProgress() - Method in class org.apache.beam.sdk.transforms.splittabledofn.GrowableOffsetRangeTracker
 
getProgress() - Method in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
 
getProgress() - Method in interface org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.HasProgress
A representation for the amount of known completed and known remaining work.
getProperties() - Method in class org.apache.beam.sdk.util.ReleaseInfo
Returns an immutable map of all properties pertaining to this release.
getProviderRuntimeValues() - Method in interface org.apache.beam.sdk.testing.TestPipeline.TestValueProviderOptions
 
getQualifiers() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
 
getRange() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
Returns the current range.
getRangeFrom() - Method in interface org.apache.beam.sdk.util.HistogramData.BucketType
 
getRangeFrom() - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
 
getRangeTo() - Method in interface org.apache.beam.sdk.util.HistogramData.BucketType
 
getRangeTo() - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
 
getRawType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
Returns the raw class type.
getRawType() - Method in class org.apache.beam.sdk.values.TypeDescriptor
Returns the Class underlying the Type represented by this TypeDescriptor.
getReason() - Method in exception org.apache.beam.sdk.coders.CannotProvideCoderException
 
getReasons() - Method in exception org.apache.beam.sdk.coders.Coder.NonDeterministicException
 
getRecordType() - Method in class org.apache.beam.sdk.coders.SerializableCoder
 
getRegisteredOptions() - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
 
getReleaseInfo() - Static method in class org.apache.beam.sdk.util.ReleaseInfo
Returns an instance of ReleaseInfo.
getRepeatedTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
 
getReplacement() - Method in class org.apache.beam.sdk.runners.PTransformOverrideFactory.ReplacementOutput
 
getReplacementTransform(AppliedPTransform<InputT, OutputT, TransformT>) - Method in interface org.apache.beam.sdk.runners.PTransformOverrideFactory
Returns a PTransform that produces equivalent output to the provided transform.
getRequirements() - Method in class org.apache.beam.sdk.transforms.Contextful
Returns the requirements needed to run the closure.
getResidual() - Method in class org.apache.beam.sdk.transforms.splittabledofn.SplitResult
Returns the residual restriction.
getRestrictionCoder() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.GetRestrictionCoder method.
GetRestrictionCoderMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetRestrictionCoderMethod
 
getResult() - Method in class org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult
 
getResults() - Method in class org.apache.beam.sdk.transforms.JsonToRow.ParseResult
Returns a PCollection containing the Rows that have been parsed.
getRetainDockerContainers() - Method in interface org.apache.beam.sdk.options.ManualDockerEnvironmentOptions
 
getRootCause() - Method in exception org.apache.beam.sdk.coders.CannotProvideCoderException
Returns the inner-most CannotProvideCoderException when they are deeply nested.
getRootClasses() - Method in class org.apache.beam.sdk.util.ApiSurface
Returns all public classes originally belonging to the package in the ApiSurface.
getRow(String) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.ROW value by field name, IllegalStateException is thrown if schema doesn't match.
getRow(int) - Method in class org.apache.beam.sdk.values.Row
Get a Row value by field index, IllegalStateException is thrown if schema doesn't match.
getRowReceiver(TupleTag<T>) - Method in interface org.apache.beam.sdk.transforms.DoFn.MultiOutputReceiver
Returns a DoFn.OutputReceiver for publishing Row objects to the given tag.
getRowSchema() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
getRowSelector(Schema, FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.utils.SelectHelpers
 
getRowSelectorOptimized(Schema, FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.utils.SelectHelpers
 
getRowToAvroBytesFunction(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Returns a function mapping Beam Rows to encoded AVRO GenericRecords.
getRowToGenericRecordFunction(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierContext
 
getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionComponentContext
 
getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionContext
 
getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.FieldSpecifierContext
 
getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierContext
 
getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
 
getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifierListContext
 
getRuleNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
getRuleNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
getRunner() - Method in interface org.apache.beam.sdk.options.PipelineOptions
The pipeline runner that will be used to execute the pipeline.
getSamplingStrategy() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
 
getSavedValue() - Method in exception org.apache.beam.sdk.util.IllegalMutationException
The original value, before the illegal mutation.
getSchema() - Method in class org.apache.beam.sdk.coders.AvroCoder
Returns the schema used by this coder.
getSchema(DestinationT) - Method in class org.apache.beam.sdk.io.DynamicAvroDestinations
Return an AVRO schema for a given destination.
getSchema() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
Returns the schema associated with this type.
getSchema(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Retrieve a Schema for a given Class type.
getSchema(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Retrieve a Schema for a given TypeDescriptor type.
getSchema(Class<T>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
 
getSchema() - Method in class org.apache.beam.sdk.schemas.utils.ReflectUtils.ClassWithSchema
 
getSchema() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
 
getSchema() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
Returns the schema used by this CoGbkResult.
getSchema() - Method in class org.apache.beam.sdk.values.PCollection
Returns the attached schema.
getSchema() - Method in class org.apache.beam.sdk.values.Row.Builder
Return the schema for the row being built.
getSchema() - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
 
getSchema() - Method in class org.apache.beam.sdk.values.Row
Return Schema which describes the fields.
getSchemaCoder(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Retrieve a SchemaCoder for a given Class type.
getSchemaCoder(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Retrieve a SchemaCoder for a given TypeDescriptor type.
getSchemaElementParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
 
getSchemaInformation() - Method in class org.apache.beam.sdk.util.DoFnWithExecutionInformation
 
getSchemaProviders() - Method in class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProviderRegistrar
 
getSchemaProviders() - Method in interface org.apache.beam.sdk.schemas.SchemaProviderRegistrar
Returns a list of schema providers which will be registered by default within each schema registry instance.
getSchemaRegistry() - Method in class org.apache.beam.sdk.Pipeline
 
getScheme() - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderResourceId
 
getScheme() - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
 
getScheme() - Method in class org.apache.beam.sdk.io.FileSystem
Get the URI scheme which defines the namespace of the FileSystem.
getScheme() - Method in interface org.apache.beam.sdk.io.fs.ResourceId
Get the scheme which defines the namespace of the ResourceId.
getSdkHarnessLogLevelOverrides() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
This option controls the log levels for specifically named loggers.
getSdkVersion() - Method in class org.apache.beam.sdk.util.ReleaseInfo
Provides the SDK version.
getSdkWorkerParallelism() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
getSemiPersistDir() - Method in interface org.apache.beam.sdk.options.RemoteEnvironmentOptions
 
getSerializedATN() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
getSerializedATN() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
getSerializer(Schema, Map<String, Object>) - Method in class org.apache.beam.sdk.schemas.io.payloads.AvroPayloadSerializerProvider
 
getSerializer(Schema, Map<String, Object>) - Method in class org.apache.beam.sdk.schemas.io.payloads.JsonPayloadSerializerProvider
 
getSerializer(Schema, Map<String, Object>) - Method in interface org.apache.beam.sdk.schemas.io.payloads.PayloadSerializerProvider
Get a PayloadSerializer.
getSerializer(String, Schema, Map<String, Object>) - Static method in class org.apache.beam.sdk.schemas.io.payloads.PayloadSerializers
 
getSetFieldCreator(Class<T>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
 
getSetters(Class<?>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
Return the list of FieldValueSetters for a Java Bean class
getSetters(Class<?>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
 
getShard() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
 
getShardingFunction() - Method in class org.apache.beam.sdk.io.WriteFiles
 
getShardNumber() - Method in class org.apache.beam.sdk.values.ShardedKey
 
getShortValue() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
Return the optional short value for an item, or null if none is provided.
getShortValue() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
The optional short value for an item, or null if none is provided.
getSideInputMapping() - Method in class org.apache.beam.sdk.util.DoFnInfo
 
getSideInputMapping() - Method in class org.apache.beam.sdk.util.DoFnWithExecutionInformation
 
getSideInputParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
 
getSideInputs() - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
Override to specify that this object needs access to one or more side inputs.
getSideInputs() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
Returns the side inputs used by this Combine operation.
getSideInputs() - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
 
getSideInputs() - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
Returns the side inputs used by this Combine operation.
getSideInputs() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
 
getSideInputs() - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
 
getSideInputs() - Method in class org.apache.beam.sdk.transforms.Requirements
The side inputs that this Contextful needs access to.
getSideInputViews() - Method in class org.apache.beam.sdk.util.AppliedCombineFn
 
getSideInputViews() - Method in class org.apache.beam.sdk.util.DoFnInfo
 
getSideInputWindow(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.WindowMappingFn
Returns the window of the side input corresponding to the given window of the main input.
getSignature(Class<FnT>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
getSingleFileMetadata() - Method in class org.apache.beam.sdk.io.FileBasedSource
Returns the information about the single file that this source is reading from.
getSink() - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
Returns the FileBasedSink for this write operation.
getSink() - Method in class org.apache.beam.sdk.io.WriteFiles
 
getSize() - Method in class org.apache.beam.sdk.schemas.utils.AvroUtils.FixedBytesField
Get the size.
getSize() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.GetSize method.
getSize() - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
 
getSize() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
 
GetSizeMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetSizeMethod
 
getSource() - Method in class org.apache.beam.sdk.io.Read.Bounded
Returns the BoundedSource used to create this Read PTransform.
getSource() - Method in class org.apache.beam.sdk.io.Read.Unbounded
Returns the UnboundedSource used to create this Read PTransform.
getSource() - Method in class org.apache.beam.sdk.io.TextIO.Read
 
getSource() - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
 
getSplitBacklogBytes() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
Returns the size of the backlog of unread data in the underlying data source represented by this split of this source.
getSplitPointsConsumed() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
Returns the total amount of parallelism in the consumed (returned and processed) range of this reader's current BoundedSource (as would be returned by BoundedSource.BoundedReader.getCurrentSource()).
getSplitPointsConsumed() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
 
getSplitPointsConsumed() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
 
getSplitPointsConsumed() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
 
getSplitPointsProcessed() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
Returns the total number of split points that have been processed.
getSplitPointsRemaining() - Method in class org.apache.beam.sdk.io.AvroSource.AvroReader
 
getSplitPointsRemaining() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
Returns the total amount of parallelism in the unprocessed part of this reader's current BoundedSource (as would be returned by BoundedSource.BoundedReader.getCurrentSource()).
getSplitPointsRemaining() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
 
getSplitPointsRemaining() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
 
getStableUniqueNames() - Method in interface org.apache.beam.sdk.options.PipelineOptions
Whether to check for stable unique names on each transform.
getStart() - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
 
getStartDate() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
 
getStartDate() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
 
getStartDate() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
 
getStartKey() - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
Returns the ByteKey representing the lower bound of this ByteKeyRange.
getStartOffset() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
Returns the starting offset of the source.
getStartPosition() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
 
getStartPosition() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
 
getStartPosition() - Method in interface org.apache.beam.sdk.io.range.RangeTracker
Returns the starting position of the current range, inclusive.
getStartTime() - Method in class org.apache.beam.sdk.io.CountingSource.CounterMark
Returns the time the reader was started.
getState() - Method in interface org.apache.beam.sdk.PipelineResult
Retrieves the current state of the pipeline execution.
getState() - Method in interface org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimator
Get current state of the WatermarkEstimator instance, which can be used to recreate the WatermarkEstimator when processing the restriction.
getState() - Method in class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.Manual
 
getState() - Method in class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.MonotonicallyIncreasing
 
getState() - Method in class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.WallTime
 
getStateCoder() - Method in interface org.apache.beam.sdk.transforms.Watch.Growth.TerminationCondition
Used to encode the state of this Watch.Growth.TerminationCondition.
getStateSpecOrThrow(DoFnSignature.StateDeclaration, DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
getStaticCreator(Class, Method, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
 
getStaticCreator(Class, Method, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
 
getStopPosition() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
 
getStopPosition() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
 
getStopPosition() - Method in interface org.apache.beam.sdk.io.range.RangeTracker
Returns the ending position of the current range, exclusive.
getString(String) - Method in class org.apache.beam.sdk.values.Row
Get a Schema.TypeName.STRING value by field name, IllegalStateException is thrown if schema doesn't match.
getString(int) - Method in class org.apache.beam.sdk.values.Row
Get a String value by field index, ClassCastException is thrown if schema doesn't match.
getSuggestedFilenameSuffix() - Method in enum org.apache.beam.sdk.io.FileBasedSink.CompressionType
Deprecated.
 
getSuggestedFilenameSuffix() - Method in interface org.apache.beam.sdk.io.FileBasedSink.OutputFileHints
 
getSuggestedSuffix() - Method in enum org.apache.beam.sdk.io.Compression
 
getSum() - Method in class org.apache.beam.sdk.metrics.DistributionResult
 
getSum() - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
 
getSumAndReset() - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
 
getSupertype(Class<? super T>) - Method in class org.apache.beam.sdk.values.TypeDescriptor
Returns the generic form of a supertype.
getTag(int) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
Returns the tuple tag at the given index.
getTag() - Method in class org.apache.beam.sdk.values.TaggedPValue
Returns the local tag associated with the PValue.
getTagInternal() - Method in interface org.apache.beam.sdk.values.PCollectionView
Deprecated.
this method will be removed entirely. The PCollection underlying a side input, is part of the side input's specification with a ParDo transform, which will obtain that information via a package-private channel.
getTagInternal() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
Returns a unique TupleTag identifying this PCollectionView.
getTempDirectoryProvider() - Method in class org.apache.beam.sdk.io.FileBasedSink
Returns the directory inside which temprary files will be written according to the configured FileBasedSink.FilenamePolicy.
getTempFilename() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
 
getTempLocation() - Method in interface org.apache.beam.sdk.options.PipelineOptions
A pipeline level default location for storing temporary files.
getTempRoot() - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
 
GetterBasedSchemaProvider - Class in org.apache.beam.sdk.schemas
A SchemaProvider base class that vends schemas and rows based on FieldValueGetters.
GetterBasedSchemaProvider() - Constructor for class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
 
GetterTypeSupplier() - Constructor for class org.apache.beam.sdk.schemas.JavaBeanSchema.GetterTypeSupplier
 
getTestTimeoutSeconds() - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
 
getThrowable() - Method in class org.apache.beam.sdk.util.SerializableThrowable
 
getTimeDomain() - Method in interface org.apache.beam.sdk.state.TimerSpec
 
getTimerFamilySpecOrThrow(DoFnSignature.TimerFamilyDeclaration, DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
getTimerSpecOrThrow(DoFnSignature.TimerDeclaration, DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
getTimestamp() - Method in class org.apache.beam.sdk.metrics.GaugeResult.EmptyGaugeResult
 
getTimestamp() - Method in class org.apache.beam.sdk.metrics.GaugeResult
 
getTimestamp() - Method in class org.apache.beam.sdk.util.WindowedValue
Returns the timestamp of this WindowedValue.
getTimestamp() - Method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
 
getTimestamp() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow
Returns the timestamp of this FailsafeValueInSingleWindow.
getTimestamp() - Method in class org.apache.beam.sdk.values.TimestampedValue
 
getTimestamp() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
Returns the timestamp of this ValueInSingleWindow.
getTimestampCombiner() - Method in interface org.apache.beam.sdk.state.WatermarkHoldState
Return the TimestampCombiner which will be used to determine a watermark hold time given an element timestamp, and to combine watermarks from windows which are about to be merged.
getTimestampCombiner() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
getTimestampTransforms() - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
The transforms applied to the arrival time of an element to determine when this trigger allows output.
getTimeZone() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
 
getTimeZone() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
 
getTimeZone() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
 
getTiming() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
Return the timing of this pane.
getTo() - Method in class org.apache.beam.sdk.io.range.OffsetRange
 
getTokenNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
Deprecated.
getTokenNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
Deprecated.
getToKvs() - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
 
getToRowFunction() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
Returns the fromRow conversion function.
getToRowFunction(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Retrieve the function that converts an object of the specified type to a Row object.
getToRowFunction(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Retrieve the function that converts an object of the specified type to a Row object.
getToRowFunction(Class<T>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
 
getToRowFunction() - Method in class org.apache.beam.sdk.values.PCollection
Returns the attached schema's toRowFunction.
getTotalBacklogBytes() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
Returns the size of the backlog of unread data in the underlying data source represented by all splits of this source.
getTotalCount() - Method in class org.apache.beam.sdk.util.HistogramData
 
getTransform() - Method in class org.apache.beam.sdk.runners.AppliedPTransform
 
getTransform() - Method in class org.apache.beam.sdk.runners.PTransformOverrideFactory.PTransformReplacement
 
getTransform() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
Returns the transform associated with this transform node.
getTransformingMap(Map<K1, V1>, Function<K1, K2>, Function<V1, V2>) - Static method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils
 
getTrigger() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
getTruncatedRestriction() - Method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.TruncateResult
 
getTupleTag() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple.TaggedKeyedPCollection
Returns the TupleTag of this TaggedKeyedPCollection.
getTupleTagList() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
Returns the TupleTagList tuple associated with this schema.
getType() - Method in class org.apache.beam.sdk.coders.AvroCoder
Returns the type this coder encodes/decodes.
getType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
Returns the field type.
getType() - Method in class org.apache.beam.sdk.schemas.Schema.Field
Returns the fields Schema.FieldType.
getType(String) - Method in class org.apache.beam.sdk.schemas.Schema.Options
Get the type of an option.
getType() - Method in interface org.apache.beam.sdk.testing.TestStream.Event
 
getType() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
Retrieve the DisplayData.Type of display data.
getType() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
The DisplayData.Type of display data.
getType() - Method in class org.apache.beam.sdk.values.TypeDescriptor
Returns the Type represented by this TypeDescriptor.
getTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.ViewFn
Return the TypeDescriptor describing the output of this fn.
getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollection
Returns a TypeDescriptor<T> with some reflective information about T, if possible.
getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn
Deprecated.
 
getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.ListViewFn
Deprecated.
 
getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.MapViewFn
Deprecated.
 
getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn
Deprecated.
 
getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
Deprecated.
 
getTypeDescriptor() - Method in class org.apache.beam.sdk.values.TupleTag
Returns a TypeDescriptor capturing what is known statically about the type of this TupleTag instance's most-derived class.
getTypeName() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
getTypeParameter(String) - Method in class org.apache.beam.sdk.values.TypeDescriptor
Returns a TypeVariable for the named type parameter.
getTypes() - Method in class org.apache.beam.sdk.values.TypeDescriptor
Returns a set of TypeDescriptor, one for each superclass as well as each interface implemented by this class.
getUnionCoder() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
 
getUnionTag() - Method in class org.apache.beam.sdk.transforms.join.RawUnionValue
 
getUntilTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
The trigger that signals termination of this trigger.
getUrn() - Method in interface org.apache.beam.sdk.transforms.Materialization
Gets the URN describing this Materialization.
getUserAgent() - Method in interface org.apache.beam.sdk.options.PipelineOptions
A user agent string as per RFC2616, describing the pipeline to external services.
getUUID() - Method in class org.apache.beam.sdk.schemas.Schema
Get this schema's UUID.
getValue() - Method in class org.apache.beam.sdk.coders.StructuralByteArray
 
getValue() - Method in class org.apache.beam.sdk.io.range.ByteKey
Returns a read-only ByteBuffer representing this ByteKey.
getValue() - Method in class org.apache.beam.sdk.metrics.GaugeResult.EmptyGaugeResult
 
getValue() - Method in class org.apache.beam.sdk.metrics.GaugeResult
 
getValue() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType.Value
Return the integer enum value.
getValue(Class<T>) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
Returns the current value of the OneOf as the destination type.
getValue() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
Returns the current value of the OneOf.
getValue(String) - Method in class org.apache.beam.sdk.schemas.Schema.Options
Get the value of an option.
getValue(String, Class<T>) - Method in class org.apache.beam.sdk.schemas.Schema.Options
Get the value of an option.
getValue() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
Retrieve the value of the display item.
getValue() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
The value of the display item.
getValue() - Method in class org.apache.beam.sdk.transforms.join.RawUnionValue
 
getValue() - Method in class org.apache.beam.sdk.util.WeightedValue
 
getValue() - Method in class org.apache.beam.sdk.util.WindowedValue
Returns the value of this WindowedValue.
getValue() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow
Returns the value of this FailsafeValueInSingleWindow.
getValue() - Method in class org.apache.beam.sdk.values.KV
Returns the value of this KV.
getValue(int) - Method in class org.apache.beam.sdk.values.Row
Get value by field index, ClassCastException is thrown if schema doesn't match.
getValue(String) - Method in class org.apache.beam.sdk.values.Row
Get value by field name, ClassCastException is thrown if type doesn't match.
getValue(int) - Method in class org.apache.beam.sdk.values.RowWithGetters
 
getValue(int) - Method in class org.apache.beam.sdk.values.RowWithStorage
 
getValue() - Method in class org.apache.beam.sdk.values.TaggedPValue
Returns the PCollection.
getValue() - Method in class org.apache.beam.sdk.values.TimestampedValue
 
getValue() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
Returns the value of this ValueInSingleWindow.
getValue() - Method in class org.apache.beam.sdk.values.ValueWithRecordId
 
getValueCoder() - Method in class org.apache.beam.sdk.coders.KvCoder
 
getValueCoder() - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
Gets the value coder that will be prefixed by the length.
getValueCoder() - Method in class org.apache.beam.sdk.coders.MapCoder
 
getValueCoder() - Method in class org.apache.beam.sdk.coders.NullableCoder
Returns the inner Coder wrapped by this NullableCoder instance.
getValueCoder() - Method in class org.apache.beam.sdk.testing.TestStream
 
getValueCoder() - Method in class org.apache.beam.sdk.util.WindowedValue.WindowedValueCoder
Returns the value coder.
getValueCoder() - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
 
getValueCoder() - Method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
 
getValueOnlyCoder(Coder<T>) - Static method in class org.apache.beam.sdk.util.WindowedValue
Returns the ValueOnlyCoder from the given valueCoder.
getValueOrDefault(String, T) - Method in class org.apache.beam.sdk.schemas.Schema.Options
Get the value of an option.
getValues() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
 
getValues() - Method in class org.apache.beam.sdk.values.Row
Return the list of data values.
getValues() - Method in class org.apache.beam.sdk.values.RowWithGetters
 
getValues() - Method in class org.apache.beam.sdk.values.RowWithStorage
 
getValuesMap() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
 
getVersion() - Method in class org.apache.beam.sdk.util.ReleaseInfo
Provides the BEAM version.
getView() - Method in class org.apache.beam.sdk.transforms.View.CreatePCollectionView
Deprecated.
This should not be used to obtain the output of any given application of this PTransform. That should be obtained by inspecting the TransformHierarchy.Node that contains this View.CreatePCollectionView, as this view may have been replaced within pipeline surgery.
getViewFn() - Method in interface org.apache.beam.sdk.values.PCollectionView
Deprecated.
this method will be removed entirely. The ViewFn for a side input is an attribute of the side input's specification with a ParDo transform, which will obtain this specification via a package-private channel.
getViewFn() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
 
getVocabulary() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
getVocabulary() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
getWatchInterval() - Method in class org.apache.beam.sdk.io.FileIO.MatchConfiguration
 
getWatermark() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
Returns a timestamp before or at the timestamps of all future elements read by this reader.
getWatermark() - Method in class org.apache.beam.sdk.testing.TestStream.WatermarkEvent
 
getWatermarkEstimatorStateCoder() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.GetWatermarkEstimatorStateCoder method.
GetWatermarkEstimatorStateCoderMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetWatermarkEstimatorStateCoderMethod
 
getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterAll
 
getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterEach
 
getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterFirst
 
getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
 
getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
 
getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
 
getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
 
getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
 
getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
 
getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.Never.NeverTrigger
 
getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
 
getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
 
getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.ReshuffleTrigger
Deprecated.
 
getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
For internal use only; no backwards-compatibility guarantees.
getWeight() - Method in interface org.apache.beam.sdk.util.Weighted
Returns the weight of the object.
getWeight() - Method in class org.apache.beam.sdk.util.WeightedValue
 
getWidth() - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
 
getWindow() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
 
getWindow() - Method in interface org.apache.beam.sdk.util.WindowedValue.SingleWindowedValue
 
getWindow() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow
Returns the window of this FailsafeValueInSingleWindow.
getWindow() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
Returns the window of this ValueInSingleWindow.
getWindowCoder() - Method in class org.apache.beam.sdk.util.WindowedValue.FullWindowedValueCoder
 
getWindowedWrites() - Method in class org.apache.beam.sdk.io.WriteFiles
 
getWindowFn() - Method in class org.apache.beam.sdk.transforms.windowing.Window.Assign
 
getWindowFn() - Method in class org.apache.beam.sdk.transforms.windowing.Window
 
getWindowFn() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
getWindowingStrategy() - Method in class org.apache.beam.sdk.util.AppliedCombineFn
 
getWindowingStrategy() - Method in class org.apache.beam.sdk.util.DoFnInfo
 
getWindowingStrategy() - Method in class org.apache.beam.sdk.values.PCollection
Returns the WindowingStrategy of this PCollection.
getWindowingStrategyInternal() - Method in interface org.apache.beam.sdk.values.PCollectionView
Deprecated.
this method will be removed entirely. The PCollection underlying a side input, including its WindowingStrategy, is part of the side input's specification with a ParDo transform, which will obtain that information via a package-private channel.
getWindowingStrategyInternal() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
Returns the WindowingStrategy of this PCollectionView, which should be that of the underlying PCollection.
getWindowMappingFn() - Method in interface org.apache.beam.sdk.values.PCollectionView
For internal use only.
getWindowMappingFn() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
 
getWindows() - Method in class org.apache.beam.sdk.util.WindowedValue
Returns the windows of this WindowedValue.
getWindows() - Method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
 
getWindowsCoder() - Method in class org.apache.beam.sdk.util.WindowedValue.FullWindowedValueCoder
 
getWindowTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
 
getWindowTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
Returns a TypeDescriptor capturing what is known statically about the window type of this WindowFn instance's most-derived class.
getWithRunnerDeterminedShardingUnbounded() - Method in class org.apache.beam.sdk.io.WriteFiles
 
getWorkCompleted() - Method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.Progress
The known amount of completed work.
getWorkRemaining() - Method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.Progress
The known amount of work remaining.
getWritableByteChannelFactory() - Method in class org.apache.beam.sdk.io.FileBasedSink
getWriteOperation() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
Return the WriteOperation that this Writer belongs to.
Global() - Constructor for class org.apache.beam.sdk.schemas.transforms.Group.Global
 
globalDefault() - Static method in class org.apache.beam.sdk.values.WindowingStrategy
Return a fully specified, default windowing strategy.
globally() - Static method in class org.apache.beam.sdk.schemas.transforms.Group
Returns a transform that groups all elements in the input PCollection.
globally(int, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles
Returns a PTransform that takes a PCollection<T> and returns a PCollection<List<T>> whose single value is a List of the approximate N-tiles of the elements of the input PCollection.
globally(int) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles
Like ApproximateQuantiles.globally(int, Comparator), but sorts using the elements' natural ordering.
globally(int) - Static method in class org.apache.beam.sdk.transforms.ApproximateUnique
Deprecated.
Returns a PTransform that takes a PCollection<T> and returns a PCollection<Long> containing a single value that is an estimate of the number of distinct elements in the input PCollection.
globally(double) - Static method in class org.apache.beam.sdk.transforms.ApproximateUnique
Deprecated.
Like ApproximateUnique.globally(int), but specifies the desired maximum estimation error instead of the sample size.
Globally(int) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.Globally
Deprecated.
 
Globally(double) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.Globally
Deprecated.
 
globally(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
Returns a Combine.Globally PTransform that uses the given SerializableFunction to combine all the elements in each window of the input PCollection into a single value in the output PCollection.
globally(SerializableBiFunction<V, V, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
Returns a Combine.Globally PTransform that uses the given SerializableBiFunction to combine all the elements in each window of the input PCollection into a single value in the output PCollection.
globally(CombineFnBase.GlobalCombineFn<? super InputT, ?, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Combine
Returns a Combine.Globally PTransform that uses the given GloballyCombineFn to combine all the elements in each window of the input PCollection into a single value in the output PCollection.
globally() - Static method in class org.apache.beam.sdk.transforms.Count
Returns a PTransform that counts the number of elements in its input PCollection.
globally() - Static method in class org.apache.beam.sdk.transforms.Latest
Returns a PTransform that takes as input a PCollection<T> and returns a PCollection<T> whose contents is the latest element according to its event time, or null if there are no elements.
globally() - Static method in class org.apache.beam.sdk.transforms.Max
Returns a PTransform that takes an input PCollection<T> and returns a PCollection<T> whose contents is the maximum according to the natural ordering of T of the input PCollection's elements, or null if there are no elements.
globally(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Max
Returns a PTransform that takes an input PCollection<T> and returns a PCollection<T> whose contents is the maximum of the input PCollection's elements, or null if there are no elements.
globally() - Static method in class org.apache.beam.sdk.transforms.Mean
Returns a PTransform that takes an input PCollection<NumT> and returns a PCollection<Double> whose contents is the mean of the input PCollection's elements, or 0 if there are no elements.
globally() - Static method in class org.apache.beam.sdk.transforms.Min
Returns a PTransform that takes an input PCollection<T> and returns a PCollection<T> whose contents is the minimum according to the natural ordering of T of the input PCollection's elements, or null if there are no elements.
globally(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Min
Returns a PTransform that takes an input PCollection<T> and returns a PCollection<T> whose contents is the minimum of the input PCollection's elements, or null if there are no elements.
GlobalWindow - Class in org.apache.beam.sdk.transforms.windowing
The default window into which all data is placed (via GlobalWindows).
GlobalWindow.Coder - Class in org.apache.beam.sdk.transforms.windowing
GlobalWindow.Coder for encoding and decoding GlobalWindows.
GlobalWindows - Class in org.apache.beam.sdk.transforms.windowing
A WindowFn that assigns all data to the same window.
GlobalWindows() - Constructor for class org.apache.beam.sdk.transforms.windowing.GlobalWindows
 
greaterThan(T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.greaterThan(Comparable).
greaterThan(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.greaterThan(Comparable).
greaterThan(T) - Static method in class org.apache.beam.sdk.transforms.Filter
Returns a PTransform that takes an input PCollection<T> and returns a PCollection<T> with elements that are greater than a given value, based on the elements' natural ordering.
greaterThanEq(T) - Static method in class org.apache.beam.sdk.transforms.Filter
Returns a PTransform that takes an input PCollection<T> and returns a PCollection<T> with elements that are greater than or equal to a given value, based on the elements' natural ordering.
greaterThanOrEqualTo(T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.greaterThanOrEqualTo(Comparable).
greaterThanOrEqualTo(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.greaterThanOrEqualTo(Comparable).
Group - Class in org.apache.beam.sdk.schemas.transforms
A generic grouping transform for schema PCollections.
Group() - Constructor for class org.apache.beam.sdk.schemas.transforms.Group
 
Group.ByFields<InputT> - Class in org.apache.beam.sdk.schemas.transforms
a PTransform that groups schema elements based on the given fields.
Group.CombineFieldsByFields<InputT> - Class in org.apache.beam.sdk.schemas.transforms
a PTransform that does a per-key combine using an aggregation built up by calls to aggregateField and aggregateFields.
Group.CombineFieldsGlobally<InputT> - Class in org.apache.beam.sdk.schemas.transforms
a PTransform that does a global combine using an aggregation built up by calls to aggregateField and aggregateFields.
Group.CombineGlobally<InputT,OutputT> - Class in org.apache.beam.sdk.schemas.transforms
a PTransform that does a global combine using a provider Combine.CombineFn.
Group.Global<InputT> - Class in org.apache.beam.sdk.schemas.transforms
A PTransform for doing global aggregations on schema PCollections.
GroupByKey<K,V> - Class in org.apache.beam.sdk.transforms
GroupByKey<K, V> takes a PCollection<KV<K, V>>, groups the values by key and windows, and returns a PCollection<KV<K, Iterable<V>>> representing a map from each distinct key and window of the input PCollection to an Iterable over all the values associated with that key in the input per window.
groupedValues(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
Returns a Combine.GroupedValues PTransform that takes a PCollection of KVs where a key maps to an Iterable of values, e.g., the result of a GroupByKey, then uses the given SerializableFunction to combine all the values associated with a key, ignoring the key.
groupedValues(SerializableBiFunction<V, V, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
Returns a Combine.GroupedValues PTransform that takes a PCollection of KVs where a key maps to an Iterable of values, e.g., the result of a GroupByKey, then uses the given SerializableFunction to combine all the values associated with a key, ignoring the key.
groupedValues(CombineFnBase.GlobalCombineFn<? super InputT, ?, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Combine
Returns a Combine.GroupedValues PTransform that takes a PCollection of KVs where a key maps to an Iterable of values, e.g., the result of a GroupByKey, then uses the given CombineFn to combine all the values associated with a key, ignoring the key.
GroupingState<InputT,OutputT> - Interface in org.apache.beam.sdk.state
A ReadableState cell that combines multiple input values and outputs a single value of a different type.
GroupIntoBatches<K,InputT> - Class in org.apache.beam.sdk.transforms
A PTransform that batches inputs to a desired batch size.
GroupIntoBatches.BatchingParams - Class in org.apache.beam.sdk.transforms
Wrapper class for batching parameters supplied by users.
GroupIntoBatches.WithShardedKey - Class in org.apache.beam.sdk.transforms
 
GrowableOffsetRangeTracker - Class in org.apache.beam.sdk.transforms.splittabledofn
An OffsetRangeTracker for tracking a growable offset range.
GrowableOffsetRangeTracker(long, GrowableOffsetRangeTracker.RangeEndEstimator) - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.GrowableOffsetRangeTracker
 
GrowableOffsetRangeTracker.RangeEndEstimator - Interface in org.apache.beam.sdk.transforms.splittabledofn
Provides the estimated end offset of the range.
Growth() - Constructor for class org.apache.beam.sdk.transforms.Watch.Growth
 
growthOf(Watch.Growth.PollFn<InputT, OutputT>, Requirements) - Static method in class org.apache.beam.sdk.transforms.Watch
Watches the growth of the given poll function.
growthOf(Watch.Growth.PollFn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Watch
Watches the growth of the given poll function.
growthOf(Contextful<Watch.Growth.PollFn<InputT, OutputT>>, SerializableFunction<OutputT, KeyT>) - Static method in class org.apache.beam.sdk.transforms.Watch
Watches the growth of the given poll function, using the given "key function" to deduplicate outputs.

H

has(TupleTag<T>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
Returns whether this PCollectionTuple contains a PCollection with the given tag.
has(String) - Method in class org.apache.beam.sdk.values.PCollectionTuple
Returns whether this PCollectionTuple contains a PCollection with the given tag.
hasCommitted() - Method in class org.apache.beam.sdk.metrics.MetricResult
 
hasDefault() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
Deprecated.
Returns if a default value was specified.
HasDefaultTracker<RestrictionT extends HasDefaultTracker<RestrictionT,TrackerT>,TrackerT extends RestrictionTracker<RestrictionT,?>> - Interface in org.apache.beam.sdk.transforms.splittabledofn
Interface for restrictions for which a default implementation of DoFn.NewTracker is available, depending only on the restriction itself.
hasDefaultValue() - Method in class org.apache.beam.sdk.transforms.View.AsSingleton
Returns whether this transform has a default value.
HasDefaultWatermarkEstimator<WatermarkEstimatorStateT,WatermarkEstimatorT extends WatermarkEstimator<WatermarkEstimatorStateT>> - Interface in org.apache.beam.sdk.transforms.splittabledofn
Interface for watermark estimator state for which a default implementation of DoFn.NewWatermarkEstimator is available, depending only on the watermark estimator state itself.
HasDisplayData - Interface in org.apache.beam.sdk.transforms.display
Marker interface for PTransforms and components to specify display data used within UIs and diagnostic tools.
hasExperiment(PipelineOptions, String) - Static method in interface org.apache.beam.sdk.options.ExperimentalOptions
Returns true iff the provided pipeline options has the specified experiment enabled.
hasField(String) - Method in class org.apache.beam.sdk.schemas.Schema
Returns true if fieldName exists in the schema, false otherwise.
hasGlobWildcard(String) - Static method in class org.apache.beam.sdk.io.FileSystems
Checks whether the given spec contains a glob wildcard character.
hashCode() - Method in class org.apache.beam.sdk.coders.AtomicCoder
.
hashCode() - Method in class org.apache.beam.sdk.coders.AvroCoder
 
hashCode() - Method in class org.apache.beam.sdk.coders.Coder.Context
Deprecated.
 
hashCode() - Method in class org.apache.beam.sdk.coders.DelegateCoder
 
hashCode() - Method in class org.apache.beam.sdk.coders.RowCoder
 
hashCode() - Method in class org.apache.beam.sdk.coders.SerializableCoder
 
hashCode() - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
 
hashCode() - Method in class org.apache.beam.sdk.coders.StructuralByteArray
 
hashCode() - Method in class org.apache.beam.sdk.coders.StructuredCoder
 
hashCode() - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
 
hashCode() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
 
hashCode() - Method in class org.apache.beam.sdk.io.range.ByteKey
 
hashCode() - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
 
hashCode() - Method in class org.apache.beam.sdk.io.range.OffsetRange
 
hashCode() - Method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
 
hashCode() - Method in class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
 
hashCode() - Method in class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
 
hashCode() - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
 
hashCode() - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema.GetterTypeSupplier
 
hashCode() - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema
 
hashCode() - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema.SetterTypeSupplier
 
hashCode() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType.Value
 
hashCode() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
 
hashCode() - Method in class org.apache.beam.sdk.schemas.Schema.Field
 
hashCode() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
hashCode() - Method in class org.apache.beam.sdk.schemas.Schema
 
hashCode() - Method in class org.apache.beam.sdk.schemas.Schema.Options
 
hashCode() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
 
hashCode() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
hashCode() - Method in class org.apache.beam.sdk.testing.PAssert.PAssertionSite
 
hashCode() - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
Deprecated.
Object.hashCode() is not supported on PAssert objects.
hashCode() - Method in class org.apache.beam.sdk.testing.SuccessOrFailure
 
hashCode() - Method in class org.apache.beam.sdk.testing.TestStream
 
hashCode() - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique
Deprecated.
 
hashCode() - Method in class org.apache.beam.sdk.transforms.CombineFns.CoCombineResult
 
hashCode() - Method in class org.apache.beam.sdk.transforms.display.DisplayData
 
hashCode() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
 
hashCode() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
 
hashCode() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
 
hashCode() - Method in class org.apache.beam.sdk.transforms.join.RawUnionValue
 
hashCode() - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
 
hashCode() - Method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
 
hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
 
hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
 
hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
 
hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
 
hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
 
hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindow
 
hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
 
hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
 
hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
 
hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
 
hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
 
hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
 
hashCode() - Method in class org.apache.beam.sdk.util.SerializableThrowable
 
hashCode() - Method in class org.apache.beam.sdk.util.ShardedKey
 
hashCode() - Method in class org.apache.beam.sdk.util.UnownedInputStream
 
hashCode() - Method in class org.apache.beam.sdk.util.UnownedOutputStream
 
hashCode() - Method in class org.apache.beam.sdk.util.WindowedValue
 
hashCode() - Method in class org.apache.beam.sdk.values.KV
 
hashCode() - Method in class org.apache.beam.sdk.values.PCollectionList
 
hashCode() - Method in class org.apache.beam.sdk.values.PCollectionTuple
 
hashCode() - Method in class org.apache.beam.sdk.values.PCollectionViews.ListViewFn
Deprecated.
 
hashCode() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
 
hashCode() - Method in class org.apache.beam.sdk.values.Row
 
hashCode() - Method in class org.apache.beam.sdk.values.RowWithGetters
 
hashCode() - Method in class org.apache.beam.sdk.values.ShardedKey
 
hashCode() - Method in class org.apache.beam.sdk.values.TimestampedValue
 
hashCode() - Method in class org.apache.beam.sdk.values.TupleTag
 
hashCode() - Method in class org.apache.beam.sdk.values.TypeDescriptor
 
hashCode() - Method in class org.apache.beam.sdk.values.TypeParameter
 
hashCode() - Method in class org.apache.beam.sdk.values.ValueWithRecordId
 
hashCode() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
hasItem(T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.hasItem(Object).
hasItem(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.hasItem(Object).
hasItem(SerializableMatcher<? super T>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.hasItem(Matcher).
hasOption(String) - Method in class org.apache.beam.sdk.schemas.Schema.Options
 
hasOptions() - Method in class org.apache.beam.sdk.schemas.Schema.Options
 
hasReplacementJob() - Method in enum org.apache.beam.sdk.PipelineResult.State
 
hasReturnValue() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
Whether this DoFn returns a DoFn.ProcessContinuation or void.
hasSchema() - Method in class org.apache.beam.sdk.values.PCollection
Returns whether this PCollection has an attached schema.
hasSize(int) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.hasSize(int).
hasSize(SerializableMatcher<? super Integer>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.hasSize(Matcher).
hasUnresolvedParameters() - Method in class org.apache.beam.sdk.values.TypeDescriptor
Returns whether this TypeDescriptor has any unresolved type parameters, as opposed to being a concrete type.
Hidden - Annotation Type in org.apache.beam.sdk.options
Methods and/or interfaces annotated with @Hidden will be suppressed from being output when --help is specified on the command-line.
Histogram - Interface in org.apache.beam.sdk.metrics
A metric that reports information about the histogram of reported values.
HistogramData - Class in org.apache.beam.sdk.util
A histogram that supports estimated percentile with linear interpolation.
HistogramData(HistogramData.BucketType) - Constructor for class org.apache.beam.sdk.util.HistogramData
Create a histogram.
HistogramData.BucketType - Interface in org.apache.beam.sdk.util
 
HistogramData.LinearBuckets - Class in org.apache.beam.sdk.util
 

I

id() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.FieldAccessDeclaration
 
id() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerFamilyMethod
The id on the method's DoFn.TimerId annotation.
id() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerMethod
The id on the method's DoFn.TimerId annotation.
id() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.StateDeclaration
 
id() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TimerDeclaration
 
id() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TimerFamilyDeclaration
 
identifier() - Method in class org.apache.beam.sdk.io.AvroSchemaIOProvider
Returns an id that uniquely represents this IO.
identifier() - Method in class org.apache.beam.sdk.schemas.io.payloads.AvroPayloadSerializerProvider
 
identifier() - Method in class org.apache.beam.sdk.schemas.io.payloads.JsonPayloadSerializerProvider
 
identifier() - Method in interface org.apache.beam.sdk.schemas.io.Providers.Identifyable
Returns an id that uniquely represents this among others implementing its derived interface.
identifier() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIOProvider
Returns an id that uniquely represents this IO.
IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
 
IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
 
IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
 
IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.NanosDuration
 
IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.NanosInstant
 
IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
 
IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
IDENTIFIER() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
 
IDENTIFIER() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.SimpleIdentifierContext
 
Identifier() - Constructor for class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
 
identity() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
Returns the identity element of this operation, i.e.
identity() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
Returns the value that should be used for the combine of the empty set.
identity() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
Returns the identity element of this operation, i.e.
identity() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
Returns the identity element of this operation, i.e.
identity() - Static method in class org.apache.beam.sdk.transforms.SerializableFunctions
 
IDENTITY_ELEMENT - Static variable in class org.apache.beam.sdk.metrics.DistributionResult
The IDENTITY_ELEMENT is used to start accumulating distributions.
IdentityWindowFn<T> - Class in org.apache.beam.sdk.util
A WindowFn that leaves all associations between elements and windows unchanged.
IdentityWindowFn(Coder<? extends BoundedWindow>) - Constructor for class org.apache.beam.sdk.util.IdentityWindowFn
 
ignoreInput(Watch.Growth.TerminationCondition<?, StateT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
Wraps a given input-independent Watch.Growth.TerminationCondition as an equivalent condition with a given input type, passing null to the original condition as input.
IllegalMutationException - Exception in org.apache.beam.sdk.util
Thrown when a value appears to have been mutated, but that mutation is forbidden.
IllegalMutationException(String, Object, Object) - Constructor for exception org.apache.beam.sdk.util.IllegalMutationException
 
IllegalMutationException(String, Object, Object, Throwable) - Constructor for exception org.apache.beam.sdk.util.IllegalMutationException
 
immediate(T) - Static method in class org.apache.beam.sdk.state.ReadableStates
A ReadableState constructed from a constant value, hence immediately available.
immutableNames() - Method in class org.apache.beam.sdk.metrics.MetricsFilter
 
immutableNamesBuilder() - Method in class org.apache.beam.sdk.metrics.MetricsFilter.Builder
 
immutableSteps() - Method in class org.apache.beam.sdk.metrics.MetricsFilter
 
immutableStepsBuilder() - Method in class org.apache.beam.sdk.metrics.MetricsFilter.Builder
 
Impulse - Class in org.apache.beam.sdk.transforms
For internal use only; no backwards-compatibility guarantees.
in(Pipeline) - Static method in class org.apache.beam.sdk.values.PBegin
Returns a PBegin in the given Pipeline.
in(Pipeline) - Static method in class org.apache.beam.sdk.values.PDone
Creates a PDone in the given Pipeline.
inc() - Method in interface org.apache.beam.sdk.metrics.Counter
Increment the counter.
inc(long) - Method in interface org.apache.beam.sdk.metrics.Counter
Increment the counter by the given amount.
inc() - Method in class org.apache.beam.sdk.metrics.DelegatingCounter
Increment the counter.
inc(long) - Method in class org.apache.beam.sdk.metrics.DelegatingCounter
Increment the counter by the given amount.
include(String, HasDisplayData) - Method in interface org.apache.beam.sdk.transforms.display.DisplayData.Builder
Register display data from the specified subcomponent at the given path.
includingClass(Class<?>) - Method in class org.apache.beam.sdk.util.ApiSurface
Returns an ApiSurface like this one, but also including the given class.
includingPackage(String, ClassLoader) - Method in class org.apache.beam.sdk.util.ApiSurface
Returns an ApiSurface like this one, but also including the named package and all of its subpackages.
inCombinedNonLatePanes(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
Creates a new PAssert.IterableAssert like this one, but with the assertion restricted to only run on the provided window across all panes that were not produced by the arrival of late data.
inCombinedNonLatePanes(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
 
IncompatibleWindowException - Exception in org.apache.beam.sdk.transforms.windowing
Exception thrown by WindowFn.verifyCompatibility(WindowFn) if two compared WindowFns are not compatible, including the explanation of incompatibility.
IncompatibleWindowException(WindowFn<?, ?>, String) - Constructor for exception org.apache.beam.sdk.transforms.windowing.IncompatibleWindowException
 
incomplete(List<TimestampedValue<OutputT>>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
Constructs a Watch.Growth.PollResult with the given outputs and declares that new outputs might appear for the current input.
incomplete(Instant, List<OutputT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
Like Watch.Growth.PollResult.incomplete(List), but assigns the same timestamp to all new outputs.
index() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter
 
INDEX_OF_MAX - Static variable in class org.apache.beam.sdk.io.ShardNameTemplate
Shard name containing the index and max.
indexOf(String) - Method in class org.apache.beam.sdk.schemas.Schema
Find the index of a given field.
inEarlyGlobalWindowPanes() - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
Creates a new PAssert.IterableAssert like this one, but with the assertion restricted to only run on panes in the GlobalWindow that were emitted before the GlobalWindow closed.
inEarlyGlobalWindowPanes() - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
 
inEarlyPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
Creates a new PAssert.IterableAssert like this one, but with the assertion restricted to only run on the provided window across all panes that were produced by the arrival of early data.
inEarlyPane(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
 
inEarlyPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
Creates a new PAssert.SingletonAssert like this one, but with the assertion restricted to only run on the provided window, running the checker only on early panes for each key.
InferableFunction<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
A ProcessFunction which is not a functional interface.
InferableFunction() - Constructor for class org.apache.beam.sdk.transforms.InferableFunction
 
InferableFunction(ProcessFunction<InputT, OutputT>) - Constructor for class org.apache.beam.sdk.transforms.InferableFunction
 
inferType(Object) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
Infer the DisplayData.Type for the given object.
inFinalPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
Creates a new PAssert.IterableAssert like this one, but with the assertion restricted to only run on the provided window, running the checker only on the final pane for each key.
inFinalPane(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
 
inFinalPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
Creates a new PAssert.SingletonAssert like this one, but with the assertion restricted to only run on the provided window, running the checker only on the final pane for each key.
InjectPackageStrategy(Class<?>) - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.InjectPackageStrategy
 
inLatePane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
Creates a new PAssert.IterableAssert with the assertion restricted to only run on the provided window across all panes that were produced by the arrival of late data.
inLatePane(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
 
inLatePane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
Creates a new PAssert.SingletonAssert with the assertion restricted to only run on the provided window, running the checker only on late panes for each key.
inNamespace(String) - Static method in class org.apache.beam.sdk.metrics.MetricNameFilter
 
inNamespace(Class<?>) - Static method in class org.apache.beam.sdk.metrics.MetricNameFilter
 
Inner() - Constructor for class org.apache.beam.sdk.schemas.transforms.Filter.Inner
 
innerBroadcastJoin(PCollection<RhsT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Join
Perform an inner join, broadcasting the right side.
innerJoin(PCollection<RhsT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Join
Perform an inner join.
inOnlyPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
Creates a new PAssert.SingletonAssert like this one, but with the assertion restricted to only run on the provided window.
inOnTimePane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
Creates a new PAssert.IterableAssert like this one, but with the assertion restricted to only run on the provided window.
inOnTimePane(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
 
inOnTimePane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
Creates a new PAssert.SingletonAssert like this one, but with the assertion restricted to only run on the provided window, running the checker only on the on-time pane for each key.
inOrder(Trigger...) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterEach
Returns an AfterEach Trigger with the given subtriggers.
inOrder(List<Trigger>) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterEach
Returns an AfterEach Trigger with the given subtriggers.
inputOf(ProcessFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
Returns a type descriptor for the input of the given ProcessFunction, subject to Java type erasure: may contain unresolved type variables if the type was erased.
inputOf(SerializableFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
Binary compatibility adapter for TypeDescriptors.inputOf(ProcessFunction).
inputOf(Contextful.Fn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
Like TypeDescriptors.inputOf(ProcessFunction) but for Contextful.Fn.
INSTANCE - Static variable in class org.apache.beam.sdk.schemas.AutoValueSchema.AbstractGetterTypeSupplier
 
INSTANCE - Static variable in class org.apache.beam.sdk.schemas.JavaBeanSchema.GetterTypeSupplier
 
INSTANCE - Static variable in class org.apache.beam.sdk.schemas.JavaFieldSchema.JavaFieldTypeSupplier
 
INSTANCE - Static variable in class org.apache.beam.sdk.transforms.windowing.GlobalWindow.Coder
 
INSTANCE - Static variable in class org.apache.beam.sdk.transforms.windowing.GlobalWindow
Singleton instance of GlobalWindow.
INSTANCE - Static variable in class org.apache.beam.sdk.transforms.windowing.PaneInfo.PaneInfoCoder
 
INSTANCE - Static variable in class org.apache.beam.sdk.util.common.ReflectHelpers.ObjectsClassComparator
 
InstanceBuilder<T> - Class in org.apache.beam.sdk.util
Utility for creating objects dynamically.
InstantCoder - Class in org.apache.beam.sdk.coders
A Coder for joda Instant that encodes it as a big endian Long shifted such that lexicographic ordering of the bytes corresponds to chronological order.
INT16 - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
The type of int16 fields.
INT32 - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
The type of int32 fields.
INT64 - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
The type of int64 fields.
integers() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for Integer.
integersGlobally() - Static method in class org.apache.beam.sdk.transforms.Max
Returns a PTransform that takes an input PCollection<Integer> and returns a PCollection<Integer> whose contents is the maximum of the input PCollection's elements, or Integer.MIN_VALUE if there are no elements.
integersGlobally() - Static method in class org.apache.beam.sdk.transforms.Min
Returns a PTransform that takes an input PCollection<Integer> and returns a PCollection<Integer> whose contents is a single value that is the minimum of the input PCollection's elements, or Integer.MAX_VALUE if there are no elements.
integersGlobally() - Static method in class org.apache.beam.sdk.transforms.Sum
Returns a PTransform that takes an input PCollection<Integer> and returns a PCollection<Integer> whose contents is the sum of the input PCollection's elements, or 0 if there are no elements.
integersPerKey() - Static method in class org.apache.beam.sdk.transforms.Max
Returns a PTransform that takes an input PCollection<KV<K, Integer>> and returns a PCollection<KV<K, Integer>> that contains an output element mapping each distinct key in the input PCollection to the maximum of the values associated with that key in the input PCollection.
integersPerKey() - Static method in class org.apache.beam.sdk.transforms.Min
Returns a PTransform that takes an input PCollection<KV<K, Integer>> and returns a PCollection<KV<K, Integer>> that contains an output element mapping each distinct key in the input PCollection to the minimum of the values associated with that key in the input PCollection.
integersPerKey() - Static method in class org.apache.beam.sdk.transforms.Sum
Returns a PTransform that takes an input PCollection<KV<K, Integer>> and returns a PCollection<KV<K, Integer>> that contains an output element mapping each distinct key in the input PCollection to the sum of the values associated with that key in the input PCollection.
Internal - Annotation Type in org.apache.beam.sdk.annotations
Signifies that a publicly accessible API (public class, method or field) is intended for internal use only and not for public consumption.
interpolateKey(double) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
Returns a ByteKey key such that [startKey, key) represents approximately the specified fraction of the range [startKey, endKey).
intersectAll(PCollection<T>) - Static method in class org.apache.beam.sdk.transforms.Sets
Returns a new PTransform transform that follows SET ALL semantics to compute the intersection with provided PCollection<T>.
intersectAll() - Static method in class org.apache.beam.sdk.transforms.Sets
Returns a new PTransform transform that follows SET ALL semantics which takes a PCollectionList<PCollection<T>> and returns a PCollection<T> containing the intersection all of collections done in order for all collections in PCollectionList<T>.
intersectDistinct(PCollection<T>) - Static method in class org.apache.beam.sdk.transforms.Sets
Returns a new PTransform transform that follows SET DISTINCT semantics to compute the intersection with provided PCollection<T>.
intersectDistinct() - Static method in class org.apache.beam.sdk.transforms.Sets
Returns a PTransform that takes a PCollectionList<PCollection<T>> and returns a PCollection<T> containing the intersection of collections done in order for all collections in PCollectionList<T>.
intersects(IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
Returns whether this window intersects the given window.
IntervalWindow - Class in org.apache.beam.sdk.transforms.windowing
An implementation of BoundedWindow that represents an interval from IntervalWindow.start (inclusive) to IntervalWindow.end (exclusive).
IntervalWindow(Instant, Instant) - Constructor for class org.apache.beam.sdk.transforms.windowing.IntervalWindow
Creates a new IntervalWindow that represents the half-open time interval [start, end).
IntervalWindow(Instant, ReadableDuration) - Constructor for class org.apache.beam.sdk.transforms.windowing.IntervalWindow
 
IntervalWindow.IntervalWindowCoder - Class in org.apache.beam.sdk.transforms.windowing
Encodes an IntervalWindow as a pair of its upper bound and duration.
IntervalWindowCoder() - Constructor for class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
 
into(TypeDescriptor<OutputT>) - Static method in class org.apache.beam.sdk.transforms.FlatMapElements
Returns a new FlatMapElements transform with the given type descriptor for the output type, but the mapping function yet to be specified using FlatMapElements.via(ProcessFunction).
into(TypeDescriptor<OutputT>) - Static method in class org.apache.beam.sdk.transforms.MapElements
Returns a new MapElements transform with the given type descriptor for the output type, but the mapping function yet to be specified using MapElements.via(ProcessFunction).
into(WindowFn<? super T, ?>) - Static method in class org.apache.beam.sdk.transforms.windowing.Window
Creates a Window PTransform that uses the given WindowFn to window the data.
InvalidConfigurationException - Exception in org.apache.beam.sdk.schemas.io
Exception thrown when the configuration for a SchemaIO is invalid.
InvalidConfigurationException(String) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidConfigurationException
 
InvalidConfigurationException(String, Throwable) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidConfigurationException
 
InvalidConfigurationException(Throwable) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidConfigurationException
 
InvalidLocationException - Exception in org.apache.beam.sdk.schemas.io
Exception thrown when the configuration for a SchemaIO is invalid.
InvalidLocationException(String) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidLocationException
 
InvalidLocationException(String, Throwable) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidLocationException
 
InvalidLocationException(Throwable) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidLocationException
 
InvalidSchemaException - Exception in org.apache.beam.sdk.schemas.io
Exception thrown when the schema for a SchemaIO is invalid.
InvalidSchemaException(String) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidSchemaException
 
InvalidSchemaException(String, Throwable) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidSchemaException
 
InvalidSchemaException(Throwable) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidSchemaException
 
invokeFinishBundle(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.FinishBundle method on the bound DoFn.
invokeGetInitialRestriction(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.GetInitialRestriction method on the bound DoFn.
invokeGetInitialWatermarkEstimatorState(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.GetInitialWatermarkEstimatorState method on the bound DoFn.
invokeGetRestrictionCoder(CoderRegistry) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.GetRestrictionCoder method on the bound DoFn.
invokeGetSize(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.GetSize method on the bound DoFn.
invokeGetWatermarkEstimatorStateCoder(CoderRegistry) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.GetWatermarkEstimatorStateCoder method on the bound DoFn.
invokeNewTracker(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.NewTracker method on the bound DoFn.
invokeNewWatermarkEstimator(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.NewWatermarkEstimator method on the bound DoFn.
invokeOnTimer(String, String, DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the appropriate DoFn.OnTimer method on the bound DoFn.
invokeOnTimer(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.OnTimerInvoker
Invoke the DoFn.OnTimer method in the provided context.
invokeOnWindowExpiration(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.OnWindowExpiration method on the bound DoFn.
invokeProcessElement(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.ProcessElement method on the bound DoFn.
invokerFor(DoFn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnInvokers
Returns an DoFnInvoker for the given DoFn, using a default choice of DoFnInvokerFactory.
invokeSetup() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.Setup method on the bound DoFn.
invokeSplitRestriction(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.SplitRestriction method on the bound DoFn.
invokeStartBundle(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.StartBundle method on the bound DoFn.
invokeTeardown() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.Teardown method on the bound DoFn.
invokeTruncateRestriction(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
Invoke the DoFn.TruncateRestriction method on the bound DoFn.
inWindow(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
Creates a new PAssert.IterableAssert like this one, but with the assertion restricted to only run on the provided window.
inWindow(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
 
isAccessible() - Method in interface org.apache.beam.sdk.options.ValueProvider
Whether the contents of this ValueProvider is currently available via ValueProvider.get().
isAccessible() - Method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
 
isAccessible() - Method in class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
 
isAccessible() - Method in class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
 
isAllowedLatenessSpecified() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
isAlreadyMerged() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
isArray() - Method in class org.apache.beam.sdk.values.TypeDescriptor
Returns true if this type is known to be an array type.
isAtSplitPoint() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
Returns true if the reader is at a split point.
isAtSplitPoint() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
Returns true only for the first record; compressed sources cannot be split.
isAtSplitPoint() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
Returns whether the current record is at a split point (i.e., whether the current record would be the first record to be read by a source with a specified start offset of OffsetBasedSource.OffsetBasedReader.getCurrentOffset()).
isBlockOnRun() - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
 
isBounded() - Method in class org.apache.beam.sdk.io.AvroSchemaIOProvider
 
isBounded() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIOProvider
 
isBounded() - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.OutputRangeTracker
 
isBounded() - Method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
 
isBounded() - Method in class org.apache.beam.sdk.transforms.splittabledofn.GrowableOffsetRangeTracker
 
isBounded() - Method in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
 
isBounded() - Method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker
Return the boundedness of the current restriction.
isBounded() - Method in class org.apache.beam.sdk.values.PCollection
 
isBoundedPerElement() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Whether this DoFn does a bounded amount of work per element.
isCancelled(CompletionStage<?>) - Static method in class org.apache.beam.sdk.util.MoreFutures
Indicates whether the future is cancelled.
isCollectionType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
 
isCompatible(Trigger) - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
 
isCompatible(Trigger) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
 
isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
 
isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
 
isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
 
isCompatible(Trigger) - Method in class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
 
isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
 
isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
 
isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
 
isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
 
isCompatible(Trigger) - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
For internal use only; no backwards-compatibility guarantees.
isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
Deprecated.
please override verifyCompatibility to throw a useful error message; we will remove isCompatible at version 3.0.0
isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.util.IdentityWindowFn
 
isCompositeNode() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
Returns true if this node represents a composite transform that does not perform processing of its own, but merely encapsulates a sub-pipeline (which may be empty).
isCompositeType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
 
isCompressed(String) - Static method in enum org.apache.beam.sdk.io.CompressedSource.CompressionMode
Deprecated.
Returns whether the file's extension matches of one of the known compression formats.
isCompressed(String) - Method in enum org.apache.beam.sdk.io.Compression
 
isDateType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
 
isDecimal(Schema.TypeName) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
Checks if type is decimal.
isDirectory() - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderResourceId
 
isDirectory() - Method in interface org.apache.beam.sdk.io.fs.ResourceId
Returns true if this ResourceId represents a directory, false otherwise.
isDisjoint(IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
Returns whether this window is disjoint from the given window.
isDone() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
isDone() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
 
isDone() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
 
isDone(CompletionStage<?>) - Static method in class org.apache.beam.sdk.util.MoreFutures
Indicates whether the future is done.
isEmpty() - Method in class org.apache.beam.sdk.io.range.ByteKey
Returns true if the byte[] backing this ByteKey is of length 0.
isEmpty() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
isEmpty() - Method in interface org.apache.beam.sdk.state.GroupingState
Returns a ReadableState whose ReadableState.read() method will return true if this state is empty at the point when that ReadableState.read() call returns.
isEmpty() - Method in interface org.apache.beam.sdk.state.MapState
Returns a ReadableState whose ReadableState.read() method will return true if this state is empty at the point when that ReadableState.read() call returns.
isEmpty() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
 
isEmpty() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
 
isEmpty() - Method in class org.apache.beam.sdk.transforms.Requirements
Whether this is an empty set of requirements.
isEqualTo(T) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
Asserts that the value in question is equal to the provided value, according to Object.equals(java.lang.Object).
isException() - Method in class org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult
 
isFirst() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
Return true if this is the first pane produced for the associated window.
isGetter(Method) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
 
isIn(Collection<T>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.isIn(Collection).
isIn(Coder<T>, Collection<T>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.isIn(Collection).
isIn(T[]) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.isIn(Object[]).
isIn(Coder<T>, T[]) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.isIn(Object[]).
isInsertDefault() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
Returns whether or not this transformation applies a default value.
isIntegral(Schema.TypeName) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
Checks if type is integral.
isLast() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
Return true if this is the last pane that will be produced in the associated window.
isLogicalType(String) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
isLogicalType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
 
isMapType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
 
isMetadata() - Method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadata
 
isMetricsSupported() - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
Indicates whether metrics reporting is supported.
isModeSpecified() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
isNonMerging() - Method in class org.apache.beam.sdk.transforms.windowing.NonMergingWindowFn
 
isNonMerging() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
Returns true if this WindowFn never needs to merge any windows.
isNullable() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
Returns whether the field is nullable.
isNumericType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
 
isOneOf(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.isOneOf(T...).
isOneOf(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.isOneOf(T...).
isOpen() - Method in class org.apache.beam.sdk.util.ShardingWritableByteChannel
 
isPrimitiveType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
 
isReadSeekEfficient() - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata
 
isRegisterByteSizeObserverCheap(BigDecimal) - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(Integer) - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(Long) - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(Short) - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(BigInteger) - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(Boolean) - Method in class org.apache.beam.sdk.coders.BooleanCoder
 
isRegisterByteSizeObserverCheap(byte[]) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(Byte) - Method in class org.apache.beam.sdk.coders.ByteCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(T) - Method in class org.apache.beam.sdk.coders.Coder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(Double) - Method in class org.apache.beam.sdk.coders.DoubleCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(ReadableDuration) - Method in class org.apache.beam.sdk.coders.DurationCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(Float) - Method in class org.apache.beam.sdk.coders.FloatCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(Instant) - Method in class org.apache.beam.sdk.coders.InstantCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(IterableT) - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(KV<K, V>) - Method in class org.apache.beam.sdk.coders.KvCoder
Returns whether both keyCoder and valueCoder are considered not expensive.
isRegisterByteSizeObserverCheap(T) - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
LengthPrefixCoder is cheap if valueCoder is cheap.
isRegisterByteSizeObserverCheap(T) - Method in class org.apache.beam.sdk.coders.NullableCoder
NullableCoder is cheap if valueCoder is cheap.
isRegisterByteSizeObserverCheap(Integer) - Method in class org.apache.beam.sdk.coders.VarIntCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(Long) - Method in class org.apache.beam.sdk.coders.VarLongCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(Void) - Method in class org.apache.beam.sdk.coders.VoidCoder
Returns whether Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver) cheap enough to call for every element, that is, if this Coder can calculate the byte size of the element to be coded in roughly constant time (or lazily).
isRegisterByteSizeObserverCheap(OffsetRange) - Method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
 
isRegisterByteSizeObserverCheap(RawUnionValue) - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
Since this coder uses elementCoders.get(index) and coders that are known to run in constant time, we defer the return value to that coder.
isRegisterByteSizeObserverCheap(ShardedKey<K>) - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
 
isRootNode() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
 
isRowReceiver() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.OutputReceiverParameter
 
isSetter(Method) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
 
isSignificant() - Method in class org.apache.beam.sdk.util.BucketingFunction
Is the current result 'significant'? Ie is it drawn from enough buckets or from enough samples?
isSignificant() - Method in class org.apache.beam.sdk.util.MovingFunction
Is the current result 'significant'? Ie is it drawn from enough buckets or from enough samples?
isSingleWindowedValue() - Method in class org.apache.beam.sdk.util.WindowedValue
Returns true if this WindowedValue has exactly one window.
isSplittable() - Method in class org.apache.beam.sdk.io.CompressedSource
Determines whether a single file represented by this source is splittable.
isSplittable() - Method in class org.apache.beam.sdk.io.FileBasedSource
Determines whether a file represented by this source is can be split into bundles.
isSplittable() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
Whether this DoFn is splittable.
isSplittable(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
isStarted() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
Returns true if there has been a call to OffsetBasedSource.OffsetBasedReader.start().
isStarted() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
 
isStateful() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Deprecated.
use DoFnSignature.usesState(), it's cleaner
isStateful(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
isStreaming() - Method in interface org.apache.beam.sdk.options.StreamingOptions
Set to true if running a streaming pipeline.
isStringType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
 
isSubtypeOf(Schema.TypeName) - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
 
isSubtypeOf(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.values.TypeDescriptor
Return true if this type is a subtype of the given type.
isSuccess() - Method in class org.apache.beam.sdk.testing.SuccessOrFailure
 
isSupertypeOf(Schema.TypeName) - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
Whether this is a super type of the another type.
isSupertypeOf(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.values.TypeDescriptor
Returns true if this type is assignable from the given type.
isTerminal() - Method in enum org.apache.beam.sdk.PipelineResult.State
 
isTimestampCombinerSpecified() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
isTriggerSpecified() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
isUnknown() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
Return true if there is no timing information for the current PaneInfo.
isWholeStream - Variable in class org.apache.beam.sdk.coders.Coder.Context
Deprecated.
Whether the encoded or decoded value fills the remainder of the output or input (resp.) record/stream contents.
item(String, String) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
Create a display item for the specified key and string value.
item(String, ValueProvider<?>) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
Create a display item for the specified key and ValueProvider.
item(String, Integer) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
Create a display item for the specified key and integer value.
item(String, Long) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
Create a display item for the specified key and integer value.
item(String, Float) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
Create a display item for the specified key and floating point value.
item(String, Double) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
Create a display item for the specified key and floating point value.
item(String, Boolean) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
Create a display item for the specified key and boolean value.
item(String, Instant) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
Create a display item for the specified key and timestamp value.
item(String, Duration) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
Create a display item for the specified key and duration value.
item(String, Class<T>) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
Create a display item for the specified key and class value.
item(String, DisplayData.Type, T) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
Create a display item for the specified key, type, and value.
Item() - Constructor for class org.apache.beam.sdk.transforms.display.DisplayData.Item
 
items() - Method in class org.apache.beam.sdk.transforms.display.DisplayData
 
ItemSpec() - Constructor for class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
 
iterable(Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
iterable() - Static method in class org.apache.beam.sdk.transforms.Materializations
For internal use only; no backwards-compatibility guarantees.
ITERABLE_MATERIALIZATION_URN - Static variable in class org.apache.beam.sdk.transforms.Materializations
The URN for a Materialization where the primitive view type is an iterable of fully specified windowed values.
IterableCoder<T> - Class in org.apache.beam.sdk.coders
An IterableCoder encodes any Iterable in the format of IterableLikeCoder.
IterableCoder(Coder<T>) - Constructor for class org.apache.beam.sdk.coders.IterableCoder
 
IterableLikeCoder<T,IterableT extends java.lang.Iterable<T>> - Class in org.apache.beam.sdk.coders
An abstract base class with functionality for assembling a Coder for a class that implements Iterable.
IterableLikeCoder(Coder<T>, String) - Constructor for class org.apache.beam.sdk.coders.IterableLikeCoder
 
iterables() - Static method in class org.apache.beam.sdk.transforms.Flatten
Returns a PTransform that takes a PCollection<Iterable<T>> and returns a PCollection<T> containing all the elements from all the Iterables.
iterables() - Static method in class org.apache.beam.sdk.transforms.ToString
Transforms each item in the iterable of the input PCollection to a String using the Object.toString() method followed by a "," until the last element in the iterable.
iterables(String) - Static method in class org.apache.beam.sdk.transforms.ToString
Transforms each item in the iterable of the input PCollection to a String using the Object.toString() method followed by the specified delimiter until the last element in the iterable.
iterables(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for Iterable.
iterableView(PCollection<T>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
Returns a PCollectionView<Iterable<T>> capable of processing elements windowed using the provided WindowingStrategy.
IterableViewFn(PCollectionViews.TypeDescriptorSupplier<T>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn
Deprecated.
 
iterableViewUsingVoidKey(PCollection<KV<Void, T>>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
iterableWithSize(int) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.iterableWithSize(int).
iterableWithSize(SerializableMatcher<? super Integer>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.iterableWithSize(Matcher).
iterator() - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObservableIterable
Returns a new iterator for this iterable.
iterator() - Method in interface org.apache.beam.sdk.util.common.Reiterable
 

J

JavaBeanSchema - Class in org.apache.beam.sdk.schemas
A SchemaProvider for Java Bean objects.
JavaBeanSchema() - Constructor for class org.apache.beam.sdk.schemas.JavaBeanSchema
 
JavaBeanSchema.GetterTypeSupplier - Class in org.apache.beam.sdk.schemas
FieldValueTypeSupplier that's based on getter methods.
JavaBeanSchema.SetterTypeSupplier - Class in org.apache.beam.sdk.schemas
FieldValueTypeSupplier that's based on setter methods.
JavaBeanUtils - Class in org.apache.beam.sdk.schemas.utils
A set of utilities to generate getter and setter classes for JavaBean objects.
JavaBeanUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
 
JavaFieldSchema - Class in org.apache.beam.sdk.schemas
A SchemaProvider for Java POJO objects.
JavaFieldSchema() - Constructor for class org.apache.beam.sdk.schemas.JavaFieldSchema
 
JavaFieldSchema.JavaFieldTypeSupplier - Class in org.apache.beam.sdk.schemas
FieldValueTypeSupplier that's based on public fields.
JavaFieldTypeSupplier() - Constructor for class org.apache.beam.sdk.schemas.JavaFieldSchema.JavaFieldTypeSupplier
 
javaTypeForFieldType(Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.FieldTypeDescriptors
JobNameFactory() - Constructor for class org.apache.beam.sdk.options.PipelineOptions.JobNameFactory
 
JodaTimestampConversion() - Constructor for class org.apache.beam.sdk.coders.AvroCoder.JodaTimestampConversion
 
join(String, CoGroup.By) - Method in class org.apache.beam.sdk.schemas.transforms.CoGroup.ExpandCrossProduct
Select the following fields for the specified PCollection with the specified join args.
join(String, CoGroup.By) - Method in class org.apache.beam.sdk.schemas.transforms.CoGroup.Impl
Select the following fields for the specified PCollection with the specified join args.
join(CoGroup.By) - Static method in class org.apache.beam.sdk.schemas.transforms.CoGroup
Join all input PCollections using the same args.
join(String, CoGroup.By) - Static method in class org.apache.beam.sdk.schemas.transforms.CoGroup
Specify the following join arguments (including fields to join by_ for the specified PCollection.
Join - Class in org.apache.beam.sdk.schemas.transforms
A transform that performs equijoins across two schema PCollections.
Join() - Constructor for class org.apache.beam.sdk.schemas.transforms.Join
 
Join.FieldsEqual - Class in org.apache.beam.sdk.schemas.transforms
Predicate object to specify fields to compare when doing an equi-join.
Join.FieldsEqual.Impl - Class in org.apache.beam.sdk.schemas.transforms
Implementation class for FieldsEqual.
Join.Impl<LhsT,RhsT> - Class in org.apache.beam.sdk.schemas.transforms
Implementation class .
jsonBytesLike(String) - Static method in class org.apache.beam.sdk.testing.JsonMatcher
 
jsonBytesLike(Map<String, Object>) - Static method in class org.apache.beam.sdk.testing.JsonMatcher
 
JsonMatcher<T> - Class in org.apache.beam.sdk.testing
Matcher to compare a string or byte[] representing a JSON Object, independent of field order.
JsonMatcher(Map<String, Object>) - Constructor for class org.apache.beam.sdk.testing.JsonMatcher
 
JsonPayloadSerializerProvider - Class in org.apache.beam.sdk.schemas.io.payloads
 
JsonPayloadSerializerProvider() - Constructor for class org.apache.beam.sdk.schemas.io.payloads.JsonPayloadSerializerProvider
 
jsonStringLike(String) - Static method in class org.apache.beam.sdk.testing.JsonMatcher
 
jsonStringLike(Map<String, Object>) - Static method in class org.apache.beam.sdk.testing.JsonMatcher
 
jsonStringToByteArray(String) - Static method in class org.apache.beam.sdk.util.StringUtils
Converts the given string, encoded using StringUtils.byteArrayToJsonString(byte[]), into a byte array.
JsonToRow - Class in org.apache.beam.sdk.transforms
Experimental
JsonToRow() - Constructor for class org.apache.beam.sdk.transforms.JsonToRow
 
jsonToRow(ObjectMapper, String) - Static method in class org.apache.beam.sdk.util.RowJsonUtils
 
JsonToRow.JsonToRowWithErrFn - Class in org.apache.beam.sdk.transforms
 
JsonToRow.JsonToRowWithErrFn.Builder - Class in org.apache.beam.sdk.transforms
 
JsonToRow.JsonToRowWithErrFn.ParseWithError - Class in org.apache.beam.sdk.transforms
 
JsonToRow.JsonToRowWithErrFn.ParseWithError.Builder - Class in org.apache.beam.sdk.transforms
 
JsonToRow.ParseResult - Class in org.apache.beam.sdk.transforms
The result of a JsonToRow.withExceptionReporting(Schema) transform.
JsonToRow.ParseResult.Builder - Class in org.apache.beam.sdk.transforms
 
JsonToRowWithErrFn() - Constructor for class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
 
JvmInitializer - Interface in org.apache.beam.sdk.harness
A service interface for defining one-time initialization of the JVM during pipeline execution.

K

KEEP_NESTED_NAME - Static variable in class org.apache.beam.sdk.schemas.utils.SelectHelpers
This policy keeps the raw nested field name.
keepMostNestedFieldName() - Method in class org.apache.beam.sdk.schemas.transforms.Select.Flattened
For nested fields, keep just the most-nested field name.
key() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provide a reference to the input element key in KV pair.
key() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
key() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
KeyedPCollectionTuple<K> - Class in org.apache.beam.sdk.transforms.join
An immutable tuple of keyed PCollections with key type K.
KeyedPCollectionTuple.TaggedKeyedPCollection<K,V> - Class in org.apache.beam.sdk.transforms.join
A utility class to help ensure coherence of tag and input PCollection types.
keyedValues() - Static method in class org.apache.beam.sdk.transforms.Deduplicate
Returns a deduplication transform that deduplicates keyed values using the key for up to 10 mins within the processing time domain.
keys() - Method in interface org.apache.beam.sdk.state.MapState
Returns an Iterable over the keys contained in this map.
Keys<K> - Class in org.apache.beam.sdk.transforms
Keys<K> takes a PCollection of KV<K, V>s and returns a PCollection<K> of the keys.
keySet() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
keyT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.KeyParameter
 
keyT(TypeDescriptor<?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
knownBuilderInstances() - Method in interface org.apache.beam.sdk.expansion.ExternalTransformRegistrar
A mapping from URN to an ExternalTransformBuilder instance.
knownBuilders() - Method in interface org.apache.beam.sdk.expansion.ExternalTransformRegistrar
Deprecated.
Prefer implementing 'knownBuilderInstances'. This method will be removed in a future version of Beam.
knownBuilders() - Method in class org.apache.beam.sdk.io.GenerateSequence.External
 
kv(SerializableMatcher<? super K>, SerializableMatcher<? super V>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher that matches any KV with matching key and value.
KV<K,V> - Class in org.apache.beam.sdk.values
An immutable key/value pair.
KV.OrderByKey<K extends java.lang.Comparable<? super K>,V> - Class in org.apache.beam.sdk.values
A Comparator that orders KVs by the natural ordering of their keys.
KV.OrderByValue<K,V extends java.lang.Comparable<? super V>> - Class in org.apache.beam.sdk.values
A Comparator that orders KVs by the natural ordering of their values.
KvCoder<K,V> - Class in org.apache.beam.sdk.coders
A KvCoder encodes KVs.
kvs() - Static method in class org.apache.beam.sdk.transforms.ToString
Transforms each element of the input PCollection to a String by using the Object.toString() on the key followed by a "," followed by the Object.toString() of the value.
kvs(String) - Static method in class org.apache.beam.sdk.transforms.ToString
Transforms each element of the input PCollection to a String by using the Object.toString() on the key followed by the specified delimiter followed by the Object.toString() of the value.
kvs(TypeDescriptor<K>, TypeDescriptor<V>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
KvSwap<K,V> - Class in org.apache.beam.sdk.transforms
KvSwap<K, V> takes a PCollection<KV<K, V>> and returns a PCollection<KV<V, K>>, where all the keys and values have been swapped.
kvWithKey(K) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher that matches any KV with the specified key.
kvWithKey(Coder<K>, K) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher that matches any KV with the specified key.
kvWithKey(SerializableMatcher<? super K>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher that matches any KV with matching key.
kvWithValue(V) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher that matches any KV with the specified value.
kvWithValue(Coder<V>, V) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher that matches any KV with the specified value.
kvWithValue(SerializableMatcher<? super V>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher that matches any KV with matching value.

L

LargeKeys - Interface in org.apache.beam.sdk.testing
Category tags for tests which validate that a Beam runner can handle keys up to a given size.
LargeKeys.Above100KB - Interface in org.apache.beam.sdk.testing
Tests if a runner supports 100KB keys.
LargeKeys.Above100MB - Interface in org.apache.beam.sdk.testing
Tests if a runner supports 100MB keys.
LargeKeys.Above10KB - Interface in org.apache.beam.sdk.testing
Tests if a runner supports 10KB keys.
LargeKeys.Above10MB - Interface in org.apache.beam.sdk.testing
Tests if a runner supports 10MB keys.
LargeKeys.Above1MB - Interface in org.apache.beam.sdk.testing
Tests if a runner supports 1MB keys.
largest(int) - Static method in class org.apache.beam.sdk.transforms.Top
Returns a PTransform that takes an input PCollection<T> and returns a PCollection<List<T>> with a single element containing the largest count elements of the input PCollection<T>, in decreasing order, sorted according to their natural order.
Largest() - Constructor for class org.apache.beam.sdk.transforms.Top.Largest
Deprecated.
 
largestDoublesFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
Returns a Top.TopCombineFn that aggregates the largest count double values.
largestFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
Returns a Top.TopCombineFn that aggregates the largest count values.
largestIntsFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
Returns a Top.TopCombineFn that aggregates the largest count int values.
largestLongsFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
Returns a Top.TopCombineFn that aggregates the largest count long values.
largestPerKey(int) - Static method in class org.apache.beam.sdk.transforms.Top
Returns a PTransform that takes an input PCollection<KV<K, V>> and returns a PCollection<KV<K, List<V>>> that contains an output element mapping each distinct key in the input PCollection to the largest count values associated with that key in the input PCollection<KV<K, V>>, in decreasing order, sorted according to their natural order.
LargestUnique(long) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique
Deprecated.
Creates a heap to track the largest sampleSize elements.
last - Variable in class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
 
LAST_REPORTED_MILLIS - Static variable in interface org.apache.beam.sdk.metrics.MetricsLogger
 
lastAttemptedOffset - Variable in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
 
lastClaimedOffset - Variable in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
 
lastModifiedMillis() - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata
Last modification timestamp in milliseconds since Unix epoch.
Latest - Class in org.apache.beam.sdk.transforms
PTransform and Combine.CombineFn for computing the latest element in a PCollection.
leaveCompositeTransform(TransformHierarchy.Node) - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
 
leaveCompositeTransform(TransformHierarchy.Node) - Method in interface org.apache.beam.sdk.Pipeline.PipelineVisitor
Called for each composite transform after all of its component transforms and their outputs have been visited.
leavePipeline(Pipeline) - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
 
leavePipeline(Pipeline) - Method in interface org.apache.beam.sdk.Pipeline.PipelineVisitor
Called when all values and transforms in a Pipeline have been visited.
left(String...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual.Impl
 
left(Integer...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual.Impl
 
left(FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual.Impl
 
left(String...) - Static method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual
 
left(Integer...) - Static method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual
 
left(FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual
 
leftOuterBroadcastJoin(PCollection<RhsT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Join
Perform a left outer join, broadcasting the right side.
leftOuterJoin(PCollection<RhsT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Join
Perform a left outer join.
LengthPrefixCoder<T> - Class in org.apache.beam.sdk.coders
A Coder which is able to take any existing coder and wrap it such that it is only invoked in the outer context.
lessThan(T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.lessThan(Comparable).
lessThan(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.lessThan(Comparable).
lessThan(T) - Static method in class org.apache.beam.sdk.transforms.Filter
Returns a PTransform that takes an input PCollection and returns a PCollection with elements that are less than a given value, based on the elements' natural ordering.
lessThanEq(T) - Static method in class org.apache.beam.sdk.transforms.Filter
Returns a PTransform that takes an input PCollection<T> and returns a PCollection<T> with elements that are less than or equal to a given value, based on the elements' natural ordering.
lessThanOrEqualTo(T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.lessThanOrEqualTo(Comparable).
lessThanOrEqualTo(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.lessThanOrEqualTo(Comparable).
LHS_TAG - Static variable in class org.apache.beam.sdk.schemas.transforms.Join
 
LifecycleMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.LifecycleMethod
 
LimitNumberOfFiles(int) - Constructor for class org.apache.beam.sdk.io.TextRowCountEstimator.LimitNumberOfFiles
 
LimitNumberOfTotalBytes(long) - Constructor for class org.apache.beam.sdk.io.TextRowCountEstimator.LimitNumberOfTotalBytes
 
linear(double, double, int) - Static method in class org.apache.beam.sdk.util.HistogramData
Create a histogram with linear buckets.
LinearBuckets() - Constructor for class org.apache.beam.sdk.util.HistogramData.LinearBuckets
 
ListCoder<T> - Class in org.apache.beam.sdk.coders
A Coder for List, using the format of IterableLikeCoder.
ListCoder(Coder<T>) - Constructor for class org.apache.beam.sdk.coders.ListCoder
 
lists(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for List.
listView(PCollection<KV<Long, PCollectionViews.ValueOrMetadata<T, OffsetRange>>>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
Returns a PCollectionView<List<T>> capable of processing elements windowed using the provided WindowingStrategy.
ListViewFn(PCollectionViews.TypeDescriptorSupplier<T>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.ListViewFn
Deprecated.
 
listViewUsingVoidKey(PCollection<KV<Void, T>>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
listViewUsingVoidKey(PCollection<KV<Void, T>>, TupleTag<Materializations.MultimapView<Void, T>>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
loadProviders(Class<T>) - Static method in class org.apache.beam.sdk.schemas.io.Providers
 
loadServicesOrdered(Class<T>, ClassLoader) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
Returns instances of all implementations of the the specified iface.
loadServicesOrdered(Class<T>) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
A version of loadServicesOrdered that uses a default class loader.
LocalFileSystemRegistrar - Class in org.apache.beam.sdk.io
AutoService registrar for the LocalFileSystem.
LocalFileSystemRegistrar() - Constructor for class org.apache.beam.sdk.io.LocalFileSystemRegistrar
 
LocalResources - Class in org.apache.beam.sdk.io
Helper functions for producing a ResourceId that references a local file or directory.
lock() - Method in class org.apache.beam.sdk.util.NoopLock
 
lockInterruptibly() - Method in class org.apache.beam.sdk.util.NoopLock
 
logicalType(Schema.LogicalType<InputT, BaseT>) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
Creates a logical type based on a primitive field type.
longs() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for Long.
longsGlobally() - Static method in class org.apache.beam.sdk.transforms.Max
Returns a PTransform that takes an input PCollection<Long> and returns a PCollection<Long> whose contents is the maximum of the input PCollection's elements, or Long.MIN_VALUE if there are no elements.
longsGlobally() - Static method in class org.apache.beam.sdk.transforms.Min
Returns a PTransform that takes an input PCollection<Long> and returns a PCollection<Long> whose contents is the minimum of the input PCollection's elements, or Long.MAX_VALUE if there are no elements.
longsGlobally() - Static method in class org.apache.beam.sdk.transforms.Sum
Returns a PTransform that takes an input PCollection<Long> and returns a PCollection<Long> whose contents is the sum of the input PCollection's elements, or 0 if there are no elements.
longsPerKey() - Static method in class org.apache.beam.sdk.transforms.Max
Returns a PTransform that takes an input PCollection<KV<K, Long>> and returns a PCollection<KV<K, Long>> that contains an output element mapping each distinct key in the input PCollection to the maximum of the values associated with that key in the input PCollection.
longsPerKey() - Static method in class org.apache.beam.sdk.transforms.Min
Returns a PTransform that takes an input PCollection<KV<K, Long>> and returns a PCollection<KV<K, Long>> that contains an output element mapping each distinct key in the input PCollection to the minimum of the values associated with that key in the input PCollection.
longsPerKey() - Static method in class org.apache.beam.sdk.transforms.Sum
Returns a PTransform that takes an input PCollection<KV<K, Long>> and returns a PCollection<KV<K, Long>> that contains an output element mapping each distinct key in the input PCollection to the sum of the values associated with that key in the input PCollection.
LzoCompression - Class in org.apache.beam.sdk.util
 
LzoCompression() - Constructor for class org.apache.beam.sdk.util.LzoCompression
 

M

Manual(Instant) - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.Manual
 
ManualDockerEnvironmentOptions - Interface in org.apache.beam.sdk.options
Pipeline options to tune DockerEnvironment.
ManualDockerEnvironmentOptions.Options - Class in org.apache.beam.sdk.options
ManualWatermarkEstimator<WatermarkEstimatorStateT> - Interface in org.apache.beam.sdk.transforms.splittabledofn
A WatermarkEstimator which is controlled manually from within a DoFn.
map(Schema.FieldType, Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
Create a map type for the given key and value types.
map(Schema.FieldType, Schema.FieldType, boolean) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
Deprecated.
Set the nullability on the valueType instead
map() - Static method in class org.apache.beam.sdk.state.StateSpecs
Create a StateSpec for a SetState, optimized for key lookups and writes.
map(Coder<K>, Coder<V>) - Static method in class org.apache.beam.sdk.state.StateSpecs
Identical to StateSpecs.map(), but with key and value coders explicitly supplied.
MAP_TYPES - Static variable in enum org.apache.beam.sdk.schemas.Schema.TypeName
 
MapCoder<K,V> - Class in org.apache.beam.sdk.coders
A Coder for Maps that encodes them according to provided coders for keys and values.
MapElements<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
PTransforms for mapping a simple function over the elements of a PCollection.
MapElements.MapWithFailures<InputT,OutputT,FailureT> - Class in org.apache.beam.sdk.transforms
A PTransform that adds exception handling to MapElements.
mapOutputs(Map<TupleTag<?>, PCollection<?>>, OutputT) - Method in interface org.apache.beam.sdk.runners.PTransformOverrideFactory
Returns a Map from the expanded values in newOutput to the values produced by the original transform.
mapQualifier() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
mapQualifier() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierListContext
 
MapQualifierContext(ParserRuleContext, int) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierContext
 
MapQualifierListContext(FieldSpecifierNotationParser.QualifierListContext) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierListContext
 
maps(TypeDescriptor<K>, TypeDescriptor<V>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for Map.
MapState<K,V> - Interface in org.apache.beam.sdk.state
A ReadableState cell mapping keys to values.
mapView(PCollection<KV<K, V>>, PCollectionViews.TypeDescriptorSupplier<K>, PCollectionViews.TypeDescriptorSupplier<V>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
Returns a PCollectionView<Map<K, V>> capable of processing elements windowed using the provided WindowingStrategy.
MapViewFn(PCollectionViews.TypeDescriptorSupplier<K>, PCollectionViews.TypeDescriptorSupplier<V>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.MapViewFn
Deprecated.
 
mapViewUsingVoidKey(PCollection<KV<Void, KV<K, V>>>, PCollectionViews.TypeDescriptorSupplier<K>, PCollectionViews.TypeDescriptorSupplier<V>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
mark(int) - Method in class org.apache.beam.sdk.util.UnownedInputStream
 
markDone() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
Marks this range tracker as being done.
markDone() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
Marks this range tracker as being done.
markElementStart() - Method in class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
Marks that a new element is being output.
markSupported() - Method in class org.apache.beam.sdk.util.UnownedInputStream
 
match(List<String>) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
 
match() - Static method in class org.apache.beam.sdk.io.FileIO
Matches a filepattern using FileSystems.match(java.util.List<java.lang.String>) and produces a collection of matched resources (both files and directories) as MatchResult.Metadata.
Match() - Constructor for class org.apache.beam.sdk.io.FileIO.Match
 
match(List<String>) - Method in class org.apache.beam.sdk.io.FileSystem
This is the entry point to convert user-provided specs to ResourceIds.
match(List<String>) - Static method in class org.apache.beam.sdk.io.FileSystems
This is the entry point to convert user-provided specs to ResourceIds.
match(List<String>, EmptyMatchTreatment) - Static method in class org.apache.beam.sdk.io.FileSystems
Like FileSystems.match(List), but with a configurable EmptyMatchTreatment.
match(String) - Static method in class org.apache.beam.sdk.io.FileSystems
Like FileSystems.match(List), but for a single resource specification.
match(String, EmptyMatchTreatment) - Static method in class org.apache.beam.sdk.io.FileSystems
Like FileSystems.match(String), but with a configurable EmptyMatchTreatment.
match(StateSpec.Cases<ResultT>) - Method in interface org.apache.beam.sdk.state.StateSpec
For internal use only; no backwards-compatibility guarantees.
match(DoFnSignature.Parameter.Cases<ResultT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
matchAll() - Static method in class org.apache.beam.sdk.io.FileIO
Like FileIO.match(), but matches each filepattern in a collection of filepatterns.
MatchAll() - Constructor for class org.apache.beam.sdk.io.FileIO.MatchAll
 
MatchConfiguration() - Constructor for class org.apache.beam.sdk.io.FileIO.MatchConfiguration
 
MatcherCheckerFn(SerializableMatcher<T>) - Constructor for class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert.MatcherCheckerFn
 
matches(String) - Method in enum org.apache.beam.sdk.io.CompressedSource.CompressionMode
Deprecated.
Returns true if the given file name implies that the contents are compressed according to the compression embodied by this factory.
matches(String) - Method in enum org.apache.beam.sdk.io.Compression
 
matches(String) - Method in enum org.apache.beam.sdk.io.TextIO.CompressionType
Deprecated.
 
matches(String) - Method in enum org.apache.beam.sdk.io.TFRecordIO.CompressionType
Deprecated.
 
matches(MetricsFilter, MetricKey) - Static method in class org.apache.beam.sdk.metrics.MetricFiltering
Matching logic is implemented here rather than in MetricsFilter because we would like MetricsFilter to act as a "dumb" value-object, with the possibility of replacing it with a Proto/JSON/etc.
matches(AppliedPTransform<?, ?, ?>) - Method in interface org.apache.beam.sdk.runners.PTransformMatcher
 
matches(Object) - Method in class org.apache.beam.sdk.testing.RegexMatcher
 
matches(String) - Static method in class org.apache.beam.sdk.testing.RegexMatcher
 
matches(Object) - Method in class org.apache.beam.sdk.testing.TestPipelineOptions.AlwaysPassMatcher
 
matches(String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.Matches PTransform that checks if the entire line matches the Regex.
matches(Pattern) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.Matches PTransform that checks if the entire line matches the Regex.
matches(String, int) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.Matches PTransform that checks if the entire line matches the Regex.
matches(Pattern, int) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.Matches PTransform that checks if the entire line matches the Regex.
matches(String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.MatchesName PTransform that checks if the entire line matches the Regex.
matches(Pattern, String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.MatchesName PTransform that checks if the entire line matches the Regex.
Matches(Pattern, int) - Constructor for class org.apache.beam.sdk.transforms.Regex.Matches
 
matchesDuringValidation(AppliedPTransform<?, ?, ?>) - Method in interface org.apache.beam.sdk.runners.PTransformMatcher
An AppliedPTransform matched by a PTransformMatcher will be replaced during pipeline surgery, and is often expected to be gone in the new pipeline.
matchesKV(String, int, int) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.MatchesKV PTransform that checks if the entire line matches the Regex.
matchesKV(Pattern, int, int) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.MatchesKV PTransform that checks if the entire line matches the Regex.
matchesKV(String, String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.MatchesNameKV PTransform that checks if the entire line matches the Regex.
matchesKV(Pattern, String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.MatchesNameKV PTransform that checks if the entire line matches the Regex.
MatchesKV(Pattern, int, int) - Constructor for class org.apache.beam.sdk.transforms.Regex.MatchesKV
 
MatchesName(Pattern, String) - Constructor for class org.apache.beam.sdk.transforms.Regex.MatchesName
 
MatchesNameKV(Pattern, String, String) - Constructor for class org.apache.beam.sdk.transforms.Regex.MatchesNameKV
 
matchesSafely(ShardedFile) - Method in class org.apache.beam.sdk.testing.FileChecksumMatcher
 
matchesSafely(T) - Method in class org.apache.beam.sdk.testing.JsonMatcher
 
matchesScope(String, Set<String>) - Static method in class org.apache.beam.sdk.metrics.MetricFiltering
matchesScope(actualScope, scopes) returns true if the scope of a metric is matched by any of the filters in scopes.
matchNewResource(String, boolean) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
 
matchNewResource(String, boolean) - Method in class org.apache.beam.sdk.io.FileSystem
Returns a new ResourceId for this filesystem that represents the named resource.
matchNewResource(String, boolean) - Static method in class org.apache.beam.sdk.io.FileSystems
Returns a new ResourceId that represents the named resource of a type corresponding to the resource type.
matchResources(List<ResourceId>) - Static method in class org.apache.beam.sdk.io.FileSystems
Returns MatchResults for the given resourceIds.
MatchResult - Class in org.apache.beam.sdk.io.fs
MatchResult.Metadata - Class in org.apache.beam.sdk.io.fs
MatchResult.Metadata of a matched file.
MatchResult.Metadata.Builder - Class in org.apache.beam.sdk.io.fs
Builder class for MatchResult.Metadata.
MatchResult.Status - Enum in org.apache.beam.sdk.io.fs
Status of a MatchResult.
matchSingleFileSpec(String) - Static method in class org.apache.beam.sdk.io.FileSystems
Returns the MatchResult.Metadata for a single file resource.
Materialization<T> - Interface in org.apache.beam.sdk.transforms
For internal use only; no backwards-compatibility guarantees.
Materializations - Class in org.apache.beam.sdk.transforms
For internal use only; no backwards-compatibility guarantees.
Materializations() - Constructor for class org.apache.beam.sdk.transforms.Materializations
 
Materializations.IterableView<V> - Interface in org.apache.beam.sdk.transforms
Represents the PrimitiveViewT supplied to the ViewFn when it declares to use the iterable materialization.
Materializations.MultimapView<K,V> - Interface in org.apache.beam.sdk.transforms
Represents the PrimitiveViewT supplied to the ViewFn when it declares to use the multimap materialization.
Max - Class in org.apache.beam.sdk.transforms
PTransforms for computing the maximum of the elements in a PCollection, or the maximum of the values associated with each key in a PCollection of KVs.
maximumLookback() - Method in class org.apache.beam.sdk.transforms.windowing.WindowMappingFn
The maximum distance between the end of any main input window mainWindow and the end of the side input window returned by WindowMappingFn.getSideInputWindow(BoundedWindow)
maxTimestamp() - Method in class org.apache.beam.sdk.transforms.windowing.BoundedWindow
Returns the inclusive upper bound of timestamps for values in this window.
maxTimestamp() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindow
 
maxTimestamp() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
Returns the largest timestamp that can be included in this window.
mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.AfterEach
 
mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
 
mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
 
mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
 
mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
 
mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.ReshuffleTrigger
Deprecated.
 
mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
For internal use only; no backwards-compatibility guarantees.
mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger.OnceTrigger
 
Mean - Class in org.apache.beam.sdk.transforms
PTransforms for computing the arithmetic mean (a.k.a.
merge(BoundedWindow, Iterable<? extends Instant>) - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
Merges the given timestamps, which may have originated in separate windows, into the context of the result window.
merge(BoundedWindow, Instant...) - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
merge(Collection<W>, W) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn.MergeContext
Signals to the framework that the windows in toBeMerged should be merged together to form mergeResult.
mergeAccumulator(AccumT) - Method in interface org.apache.beam.sdk.transforms.Combine.AccumulatingCombineFn.Accumulator
Adds the input values represented by the given accumulator into this accumulator.
mergeAccumulators(Iterable<AccumT>) - Method in interface org.apache.beam.sdk.state.CombiningState
Merge the given accumulators according to the underlying Combine.CombineFn.
mergeAccumulators(Iterable<ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique>) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
Deprecated.
 
mergeAccumulators(Iterable<AccumT>) - Method in class org.apache.beam.sdk.transforms.Combine.AccumulatingCombineFn
 
mergeAccumulators(Iterable<double[]>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
 
mergeAccumulators(Iterable<Combine.Holder<V>>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
 
mergeAccumulators(Iterable<int[]>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
 
mergeAccumulators(Iterable<long[]>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
 
mergeAccumulators(Iterable<AccumT>) - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
Returns an accumulator representing the accumulation of all the input values accumulated in the merging accumulators.
mergeAccumulators(Iterable<List<V>>) - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
 
mergeAccumulators(Iterable<Object[]>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
 
mergeAccumulators(Iterable<Object[]>, CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
 
mergeAccumulators(Iterable<AccumT>, CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
Returns an accumulator representing the accumulation of all the input values accumulated in the merging accumulators.
mergeAccumulators(Iterable<Top.BoundedHeap<KV<Integer, T>, SerializableComparator<KV<Integer, T>>>>) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
 
MergeContext() - Constructor for class org.apache.beam.sdk.transforms.windowing.WindowFn.MergeContext
 
MergeOverlappingIntervalWindows - Class in org.apache.beam.sdk.transforms.windowing
For internal use only; no backwards compatibility guarantees.
MergeOverlappingIntervalWindows() - Constructor for class org.apache.beam.sdk.transforms.windowing.MergeOverlappingIntervalWindows
 
mergeWideningNullable(Schema, Schema) - Static method in class org.apache.beam.sdk.schemas.SchemaUtils
Given two schema that have matching types, return a nullable-widened schema.
mergeWindows(WindowFn<?, IntervalWindow>.MergeContext) - Static method in class org.apache.beam.sdk.transforms.windowing.MergeOverlappingIntervalWindows
Merge overlapping IntervalWindows.
mergeWindows(WindowFn<T, W>.MergeContext) - Method in class org.apache.beam.sdk.transforms.windowing.NonMergingWindowFn
 
mergeWindows(WindowFn<Object, IntervalWindow>.MergeContext) - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
 
mergeWindows(WindowFn<T, W>.MergeContext) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
Does whatever merging of windows is necessary.
message() - Method in class org.apache.beam.sdk.schemas.transforms.Cast.CompatibilityError
 
metadata() - Method in class org.apache.beam.sdk.io.fs.MatchResult
MatchResult.Metadata of matched files.
Metadata() - Constructor for class org.apache.beam.sdk.io.fs.MatchResult.Metadata
 
MetadataCoder - Class in org.apache.beam.sdk.io.fs
MetadataCoderV2 - Class in org.apache.beam.sdk.io.fs
Metric - Interface in org.apache.beam.sdk.metrics
Marker interface for all user-facing metrics.
MetricFiltering - Class in org.apache.beam.sdk.metrics
Implements matching for metrics filters.
MetricKey - Class in org.apache.beam.sdk.metrics
Metrics are keyed by the step name they are associated with and the name of the metric.
MetricKey() - Constructor for class org.apache.beam.sdk.metrics.MetricKey
 
metricName() - Method in class org.apache.beam.sdk.metrics.MetricKey
The name of the metric.
MetricName - Class in org.apache.beam.sdk.metrics
The name of a metric consists of a MetricName.getNamespace() and a MetricName.getName().
MetricName() - Constructor for class org.apache.beam.sdk.metrics.MetricName
 
MetricNameFilter - Class in org.apache.beam.sdk.metrics
The name of a metric.
MetricNameFilter() - Constructor for class org.apache.beam.sdk.metrics.MetricNameFilter
 
MetricQueryResults - Class in org.apache.beam.sdk.metrics
The results of a query for metrics.
MetricQueryResults() - Constructor for class org.apache.beam.sdk.metrics.MetricQueryResults
 
MetricResult<T> - Class in org.apache.beam.sdk.metrics
The results of a single current metric.
MetricResult() - Constructor for class org.apache.beam.sdk.metrics.MetricResult
 
MetricResults - Class in org.apache.beam.sdk.metrics
Methods for interacting with the metrics of a pipeline that has been executed.
MetricResults() - Constructor for class org.apache.beam.sdk.metrics.MetricResults
 
Metrics - Class in org.apache.beam.sdk.metrics
The Metrics is a utility class for producing various kinds of metrics for reporting properties of an executing pipeline.
metrics() - Method in interface org.apache.beam.sdk.PipelineResult
Returns the object to access metrics from the pipeline.
MetricsContainer - Interface in org.apache.beam.sdk.metrics
Holds the metrics for a single step.
MetricsEnvironment - Class in org.apache.beam.sdk.metrics
Manages and provides the metrics container associated with each thread.
MetricsEnvironment() - Constructor for class org.apache.beam.sdk.metrics.MetricsEnvironment
 
MetricsFilter - Class in org.apache.beam.sdk.metrics
Simple POJO representing a filter for querying metrics.
MetricsFilter() - Constructor for class org.apache.beam.sdk.metrics.MetricsFilter
 
MetricsFilter.Builder - Class in org.apache.beam.sdk.metrics
Builder for creating a MetricsFilter.
MetricsLogger - Interface in org.apache.beam.sdk.metrics
 
MetricsOptions - Interface in org.apache.beam.sdk.metrics
Extension of PipelineOptions that defines MetricsSink specific options.
MetricsOptions.NoOpMetricsSink - Class in org.apache.beam.sdk.metrics
A DefaultValueFactory that obtains the class of the NoOpMetricsSink if it exists on the classpath, and throws an exception otherwise.
MetricsSink - Interface in org.apache.beam.sdk.metrics
Interface for all metric sinks.
MicrosInstant - Class in org.apache.beam.sdk.schemas.logicaltypes
A timestamp represented as microseconds since the epoch.
MicrosInstant() - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
 
mimeType() - Method in class org.apache.beam.sdk.io.fs.CreateOptions
The file-like resource mime type.
MimeTypes - Class in org.apache.beam.sdk.util
Constants representing various mime types.
MimeTypes() - Constructor for class org.apache.beam.sdk.util.MimeTypes
 
Min - Class in org.apache.beam.sdk.transforms
PTransforms for computing the minimum of the elements in a PCollection, or the minimum of the values associated with each key in a PCollection of KVs.
modeNames - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
MonotonicallyIncreasing(Instant) - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.MonotonicallyIncreasing
 
months(int) - Static method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows
Returns a WindowFn that windows elements into periods measured by months.
MoreFutures - Class in org.apache.beam.sdk.util
Utilities to do future programming with Java 8.
MoreFutures() - Constructor for class org.apache.beam.sdk.util.MoreFutures
 
MoreFutures.ExceptionOrResult<T> - Class in org.apache.beam.sdk.util
An object that represents either a result or an exceptional termination.
MoreFutures.ExceptionOrResult.IsException - Enum in org.apache.beam.sdk.util
Describes whether the result was an exception.
MoveOptions - Interface in org.apache.beam.sdk.io.fs
MoveOptions.StandardMoveOptions - Enum in org.apache.beam.sdk.io.fs
Defines the standard MoveOptions.
MovingFunction - Class in org.apache.beam.sdk.util
Keep track of the moving minimum/maximum/sum of sampled long values.
MovingFunction(long, long, int, int, Combine.BinaryCombineLongFn) - Constructor for class org.apache.beam.sdk.util.MovingFunction
 
multimap() - Static method in class org.apache.beam.sdk.transforms.Materializations
For internal use only; no backwards-compatibility guarantees.
MULTIMAP_MATERIALIZATION_URN - Static variable in class org.apache.beam.sdk.transforms.Materializations
The URN for a Materialization where the primitive view type is a multimap of fully specified windowed values.
multimapView(PCollection<KV<K, V>>, PCollectionViews.TypeDescriptorSupplier<K>, PCollectionViews.TypeDescriptorSupplier<V>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
Returns a PCollectionView<Map<K, Iterable<V>>> capable of processing elements windowed using the provided WindowingStrategy.
MultimapViewFn(PCollectionViews.TypeDescriptorSupplier<K>, PCollectionViews.TypeDescriptorSupplier<V>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn
Deprecated.
 
multimapViewUsingVoidKey(PCollection<KV<Void, KV<K, V>>>, PCollectionViews.TypeDescriptorSupplier<K>, PCollectionViews.TypeDescriptorSupplier<V>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
MutationDetector - Interface in org.apache.beam.sdk.util
An object for detecting illegal mutations.
MutationDetectors - Class in org.apache.beam.sdk.util
Static methods for creating and working with MutationDetector.

N

name() - Method in interface org.apache.beam.sdk.schemas.FieldValueGetter
 
name() - Method in interface org.apache.beam.sdk.schemas.FieldValueSetter
Returns the name of the field.
name(TypeDescription) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.InjectPackageStrategy
 
name - Variable in class org.apache.beam.sdk.transforms.PTransform
The base name of this PTransform, e.g., from defaults, or null if not yet assigned.
named(String, String) - Static method in class org.apache.beam.sdk.metrics.MetricName
 
named(Class<?>, String) - Static method in class org.apache.beam.sdk.metrics.MetricName
 
named(String, String) - Static method in class org.apache.beam.sdk.metrics.MetricNameFilter
 
named(Class<?>, String) - Static method in class org.apache.beam.sdk.metrics.MetricNameFilter
 
nameOf(int) - Method in class org.apache.beam.sdk.schemas.Schema
Return the name of field by index.
names() - Method in class org.apache.beam.sdk.metrics.MetricsFilter
 
NameUtils - Class in org.apache.beam.sdk.util
Helpers for extracting the name of objects and classes.
NameUtils() - Constructor for class org.apache.beam.sdk.util.NameUtils
 
NameUtils.NameOverride - Interface in org.apache.beam.sdk.util
Classes may implement this interface to change how names are generated for their instances.
NanosDuration - Class in org.apache.beam.sdk.schemas.logicaltypes
A duration represented in nanoseconds.
NanosDuration() - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.NanosDuration
 
NanosInstant - Class in org.apache.beam.sdk.schemas.logicaltypes
A timestamp represented as nanoseconds since the epoch.
NanosInstant() - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.NanosInstant
 
narrowing(Schema) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
 
Narrowing() - Constructor for class org.apache.beam.sdk.schemas.transforms.Cast.Narrowing
 
Natural() - Constructor for class org.apache.beam.sdk.transforms.Top.Natural
 
naturalOrder(T) - Static method in class org.apache.beam.sdk.transforms.Max
 
naturalOrder() - Static method in class org.apache.beam.sdk.transforms.Max
 
naturalOrder(T) - Static method in class org.apache.beam.sdk.transforms.Min
 
naturalOrder() - Static method in class org.apache.beam.sdk.transforms.Min
 
needsMerge() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
NeedsRunner - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize TestPipeline for execution and expect to be executed by a PipelineRunner.
NESTED - Static variable in class org.apache.beam.sdk.coders.Coder.Context
Deprecated.
The nested context: the value being encoded or decoded is (potentially) a part of a larger record/stream contents, and may have other parts encoded or decoded after it.
nested() - Method in class org.apache.beam.sdk.coders.Coder.Context
Deprecated.
 
nestedFieldsById() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return the nested fields keyed by field ids.
nestedFieldsByName() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return the nested fields keyed by field name.
never() - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
Returns a Watch.Growth.TerminationCondition that never holds (i.e., poll each input until its output is complete).
Never - Class in org.apache.beam.sdk.transforms.windowing
A Trigger which never fires.
Never() - Constructor for class org.apache.beam.sdk.transforms.windowing.Never
 
Never.NeverTrigger - Class in org.apache.beam.sdk.transforms.windowing
The actual trigger class for Never triggers.
newBuilder() - Static method in class org.apache.beam.sdk.schemas.io.Failure
 
newCondition() - Method in class org.apache.beam.sdk.util.NoopLock
 
newDlqTransform(String) - Method in interface org.apache.beam.sdk.schemas.io.GenericDlqProvider
Generate a DLQ output from the provided config value.
newObjectMapperWith(RowJson.RowJsonDeserializer) - Static method in class org.apache.beam.sdk.util.RowJsonUtils
 
newObjectMapperWith(RowJson.RowJsonSerializer) - Static method in class org.apache.beam.sdk.util.RowJsonUtils
 
newProvider(T) - Method in class org.apache.beam.sdk.testing.TestPipeline
Returns a new ValueProvider that is inaccessible before TestPipeline.run(), but will be accessible while the pipeline runs.
newTracker() - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
 
newTracker() - Method in class org.apache.beam.sdk.io.range.OffsetRange
 
newTracker() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.NewTracker method.
newTracker() - Method in interface org.apache.beam.sdk.transforms.splittabledofn.HasDefaultTracker
Creates a new tracker for this.
NewTrackerMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewTrackerMethod
 
newWatermarkEstimator() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.NewWatermarkEstimator method.
newWatermarkEstimator() - Method in interface org.apache.beam.sdk.transforms.splittabledofn.HasDefaultWatermarkEstimator
Creates a new watermark estimator for this.
NewWatermarkEstimatorMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewWatermarkEstimatorMethod
 
next(Sleeper, BackOff) - Static method in class org.apache.beam.sdk.util.BackOffUtils
Runs the next iteration of the back-off policy, and returns whether to continue to retry the operation.
nextBackOffMillis() - Method in interface org.apache.beam.sdk.util.BackOff
Gets the number of milliseconds to wait before retrying the operation or BackOff.STOP to indicate that no retries should be made.
nextFieldId() - Method in class org.apache.beam.sdk.values.Row.Builder
 
NO_FIRING - Static variable in class org.apache.beam.sdk.transforms.windowing.PaneInfo
PaneInfo to use for elements on (and before) initial window assignment (including elements read from sources) before they have passed through a GroupByKey and are associated with a particular trigger firing.
NonDeterministicException(Coder<?>, String, Coder.NonDeterministicException) - Constructor for exception org.apache.beam.sdk.coders.Coder.NonDeterministicException
 
NonDeterministicException(Coder<?>, String) - Constructor for exception org.apache.beam.sdk.coders.Coder.NonDeterministicException
 
NonDeterministicException(Coder<?>, List<String>) - Constructor for exception org.apache.beam.sdk.coders.Coder.NonDeterministicException
 
NonDeterministicException(Coder<?>, List<String>, Coder.NonDeterministicException) - Constructor for exception org.apache.beam.sdk.coders.Coder.NonDeterministicException
 
none() - Static method in class org.apache.beam.sdk.schemas.Schema.Options
 
none() - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
Default empty DisplayData instance.
NonMergingWindowFn<T,W extends BoundedWindow> - Class in org.apache.beam.sdk.transforms.windowing
Abstract base class for WindowFns that do not merge windows.
NonMergingWindowFn() - Constructor for class org.apache.beam.sdk.transforms.windowing.NonMergingWindowFn
 
NOOP_CHECKPOINT_MARK - Static variable in interface org.apache.beam.sdk.io.UnboundedSource.CheckpointMark
 
NoopCheckpointMark() - Constructor for class org.apache.beam.sdk.io.UnboundedSource.CheckpointMark.NoopCheckpointMark
 
NoopLock - Class in org.apache.beam.sdk.util
A lock which can always be acquired.
NoOpMetricsSink() - Constructor for class org.apache.beam.sdk.metrics.MetricsOptions.NoOpMetricsSink
 
noopMutationDetector() - Static method in class org.apache.beam.sdk.util.MutationDetectors
Creates a new MutationDetector that always succeeds.
NoSuchSchemaException - Exception in org.apache.beam.sdk.schemas
Indicates that we are missing a schema for a type.
NoSuchSchemaException() - Constructor for exception org.apache.beam.sdk.schemas.NoSuchSchemaException
 
not(SerializableMatcher<T>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.not(org.hamcrest.Matcher<T>).
notEqualTo(T) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
Asserts that the value in question is not equal to the provided value, according to Object.equals(java.lang.Object).
notifyValueReturned(long) - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObservableIterator
 
nullable(String, Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.Schema.Field
Return's a nullable field with the give name and type.
NullableCoder<T> - Class in org.apache.beam.sdk.coders
A NullableCoder encodes nullable values of type T using a nested Coder<T> that does not tolerate null values.
nullContext() - Static method in class org.apache.beam.sdk.state.StateContexts
Returns a fake StateContext.
nullContext() - Static method in class org.apache.beam.sdk.util.CombineContextFactory
Returns a fake Combine.Context for tests.
nullRow(Schema) - Static method in class org.apache.beam.sdk.values.Row
Creates a new record filled with nulls.
nulls() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for nulls/Void.
nullValue() - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.nullValue().
NumberedShardedFile - Class in org.apache.beam.sdk.util
Utility methods for working with sharded files.
NumberedShardedFile(String) - Constructor for class org.apache.beam.sdk.util.NumberedShardedFile
Constructor that uses default shard template.
NumberedShardedFile(String, Pattern) - Constructor for class org.apache.beam.sdk.util.NumberedShardedFile
Constructor.
NUMERIC_TYPES - Static variable in enum org.apache.beam.sdk.schemas.Schema.TypeName
 

O

ObjectsClassComparator() - Constructor for class org.apache.beam.sdk.util.common.ReflectHelpers.ObjectsClassComparator
 
observesWindow() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.MethodWithExtraParameters
Whether this method observes - directly or indirectly - the window that an element resides in.
observeTimestamp(Instant) - Method in interface org.apache.beam.sdk.transforms.splittabledofn.TimestampObservingWatermarkEstimator
Update watermark estimate with latest output timestamp.
observeTimestamp(Instant) - Method in class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.MonotonicallyIncreasing
 
of(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.coders.AvroCoder
Returns an AvroCoder instance for the provided element type.
of(Class<T>) - Static method in class org.apache.beam.sdk.coders.AvroCoder
Returns an AvroCoder instance for the provided element class.
of(Schema) - Static method in class org.apache.beam.sdk.coders.AvroCoder
Returns an AvroGenericCoder instance for the Avro schema.
of(Class<T>, Schema) - Static method in class org.apache.beam.sdk.coders.AvroCoder
Returns an AvroCoder instance for the provided element type using the provided Avro schema.
of(Schema) - Static method in class org.apache.beam.sdk.coders.AvroGenericCoder
 
of() - Static method in class org.apache.beam.sdk.coders.BigDecimalCoder
 
of() - Static method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
 
of() - Static method in class org.apache.beam.sdk.coders.BigEndianLongCoder
 
of() - Static method in class org.apache.beam.sdk.coders.BigEndianShortCoder
 
of() - Static method in class org.apache.beam.sdk.coders.BigIntegerCoder
 
of() - Static method in class org.apache.beam.sdk.coders.BitSetCoder
 
of() - Static method in class org.apache.beam.sdk.coders.BooleanCoder
Returns the singleton instance of BooleanCoder.
of() - Static method in class org.apache.beam.sdk.coders.ByteArrayCoder
 
of() - Static method in class org.apache.beam.sdk.coders.ByteCoder
 
of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.CollectionCoder
 
of(Coder<IntermediateT>, DelegateCoder.CodingFunction<T, IntermediateT>, DelegateCoder.CodingFunction<IntermediateT, T>) - Static method in class org.apache.beam.sdk.coders.DelegateCoder
 
of(Coder<IntermediateT>, DelegateCoder.CodingFunction<T, IntermediateT>, DelegateCoder.CodingFunction<IntermediateT, T>, TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.coders.DelegateCoder
 
of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.DequeCoder
 
of() - Static method in class org.apache.beam.sdk.coders.DoubleCoder
 
of() - Static method in class org.apache.beam.sdk.coders.DurationCoder
 
of() - Static method in class org.apache.beam.sdk.coders.FloatCoder
 
of() - Static method in class org.apache.beam.sdk.coders.InstantCoder
 
of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.IterableCoder
 
of(Coder<K>, Coder<V>) - Static method in class org.apache.beam.sdk.coders.KvCoder
 
of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.LengthPrefixCoder
 
of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.ListCoder
 
of(Coder<K>, Coder<V>) - Static method in class org.apache.beam.sdk.coders.MapCoder
Produces a MapCoder with the given keyCoder and valueCoder.
of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.NullableCoder
 
of(Schema) - Static method in class org.apache.beam.sdk.coders.RowCoder
 
of(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.coders.SerializableCoder
Returns a SerializableCoder instance for the provided element type.
of(Class<T>) - Static method in class org.apache.beam.sdk.coders.SerializableCoder
Returns a SerializableCoder instance for the provided element class.
of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.SetCoder
Produces a SetCoder with the given elementCoder.
of(Coder<KeyT>) - Static method in class org.apache.beam.sdk.coders.ShardedKeyCoder
 
of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.SnappyCoder
Wraps the given coder into a SnappyCoder.
of(Class<T>) - Static method in class org.apache.beam.sdk.coders.StringDelegateCoder
 
of(Class<T>, TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.coders.StringDelegateCoder
 
of() - Static method in class org.apache.beam.sdk.coders.StringUtf8Coder
 
of() - Static method in class org.apache.beam.sdk.coders.TextualIntegerCoder
 
of() - Static method in class org.apache.beam.sdk.coders.VarIntCoder
 
of() - Static method in class org.apache.beam.sdk.coders.VarLongCoder
 
of() - Static method in class org.apache.beam.sdk.coders.VoidCoder
 
of() - Static method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.ParamsCoder
 
of(Coder<BoundedWindow>, Coder<DestinationT>) - Static method in class org.apache.beam.sdk.io.FileBasedSink.FileResultCoder
 
of() - Static method in class org.apache.beam.sdk.io.fs.MetadataCoder
Returns the singleton MetadataCoder instance.
of() - Static method in class org.apache.beam.sdk.io.fs.MetadataCoderV2
Returns the singleton MetadataCoderV2 instance.
of() - Static method in class org.apache.beam.sdk.io.fs.ResourceIdCoder
Creates a ResourceIdCoder.
of(int...) - Static method in class org.apache.beam.sdk.io.range.ByteKey
Creates a new ByteKey backed by a copy of the specified int[].
of(ByteKey, ByteKey) - Static method in class org.apache.beam.sdk.io.range.ByteKeyRange
Creates a new ByteKeyRange with the given start and end keys.
of(ByteKeyRange) - Static method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
Instantiates a new ByteKeyRangeTracker with the specified range.
of() - Static method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
 
of() - Static method in class org.apache.beam.sdk.io.ReadableFileCoder
Returns the instance of ReadableFileCoder.
of(ValueProvider<X>, SerializableFunction<X, T>) - Static method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
Creates a ValueProvider.NestedValueProvider that wraps the provided value.
of(T) - Static method in class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
Creates a ValueProvider.StaticValueProvider that wraps the provided value.
of(String, Map<TupleTag<?>, PCollection<?>>, Map<TupleTag<?>, PCollection<?>>, TransformT, Pipeline) - Static method in class org.apache.beam.sdk.runners.AppliedPTransform
 
of(PTransformMatcher, PTransformOverrideFactory) - Static method in class org.apache.beam.sdk.runners.PTransformOverride
 
of(InputT, PTransform<InputT, OutputT>) - Static method in class org.apache.beam.sdk.runners.PTransformOverrideFactory.PTransformReplacement
 
of(TaggedPValue, TaggedPValue) - Static method in class org.apache.beam.sdk.runners.PTransformOverrideFactory.ReplacementOutput
 
of(FieldAccessDescriptor.FieldDescriptor.ListQualifier) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
 
of(FieldAccessDescriptor.FieldDescriptor.MapQualifier) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
 
of(SerializableFunction<Row, byte[]>, SerializableFunction<byte[], Row>) - Static method in interface org.apache.beam.sdk.schemas.io.payloads.PayloadSerializer
 
of(int) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
 
of(String, Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.Schema.Field
Return's a field with the give name and type.
of(Schema.TypeName) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
Create a Schema.FieldType for the given type.
of(Schema.Field...) - Static method in class org.apache.beam.sdk.schemas.Schema
 
of(Schema, TypeDescriptor<T>, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Static method in class org.apache.beam.sdk.schemas.SchemaCoder
Returns a SchemaCoder for the specified class.
of(Schema) - Static method in class org.apache.beam.sdk.schemas.SchemaCoder
Returns a SchemaCoder for Row instances with the given schema.
of() - Static method in class org.apache.beam.sdk.schemas.transforms.Cast.Narrowing
 
of(Schema, Cast.Validator) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
 
of() - Static method in class org.apache.beam.sdk.schemas.transforms.Cast.Widening
 
of(Coder<T>) - Static method in class org.apache.beam.sdk.testing.TestStream.TestStreamCoder
 
of(SerializableBiFunction<V, V, V>) - Static method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
Returns a CombineFn that uses the given SerializableBiFunction to combine values.
of(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
Returns a CombineFn that uses the given SerializableFunction to combine values.
of(SerializableFunction<Iterable<V>, V>, int) - Static method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
Returns a CombineFn that uses the given SerializableFunction to combine values, attempting to buffer at least bufferSize values between invocations.
of(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine.SimpleCombineFn
Deprecated.
Returns a CombineFn that uses the given SerializableFunction to combine values.
of(ClosureT, Requirements) - Static method in class org.apache.beam.sdk.transforms.Contextful
Constructs a pair of the given closure and its requirements.
of(Iterable<T>) - Static method in class org.apache.beam.sdk.transforms.Create
Returns a new Create.Values transform that produces a PCollection containing elements of the provided Iterable.
of(T, T...) - Static method in class org.apache.beam.sdk.transforms.Create
Returns a new Create.Values transform that produces a PCollection containing the specified elements.
of(Map<K, V>) - Static method in class org.apache.beam.sdk.transforms.Create
Returns a new Create.Values transform that produces a PCollection of KVs corresponding to the keys and values of the specified Map.
of(DisplayData.Path, Class<?>, String) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
 
of(DoFn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
of(CoGbkResultSchema, UnionCoder) - Static method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
Returns a CoGbkResult.CoGbkResultCoder for the given schema and UnionCoder.
of(TupleTag<V>, List<V>) - Static method in class org.apache.beam.sdk.transforms.join.CoGbkResult
Returns a new CoGbkResult that contains just the given tag and given data.
of(List<TupleTag<?>>) - Static method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
 
of(TupleTag<InputT>, PCollection<KV<K, InputT>>) - Static method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
Returns a new KeyedPCollectionTuple<K> with the given tag and initial PCollection.
of(String, PCollection<KV<K, InputT>>) - Static method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
A version of KeyedPCollectionTuple.of(TupleTag, PCollection) that takes in a string instead of a TupleTag.
of(List<Coder<?>>) - Static method in class org.apache.beam.sdk.transforms.join.UnionCoder
Builds a union coder with the given list of element coders.
of(T, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Max
A CombineFn that computes the maximum of a collection of elements of type T using an arbitrary Comparator and identity, useful as an argument to Combine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>) or Combine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>).
of(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Max
A CombineFn that computes the maximum of a collection of elements of type T using an arbitrary Comparator, useful as an argument to Combine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>) or Combine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>).
of() - Static method in class org.apache.beam.sdk.transforms.Mean
A Combine.CombineFn that computes the arithmetic mean (a.k.a.
of(T, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Min
A CombineFn that computes the minimum of a collection of elements of type T using an arbitrary Comparator and an identity, useful as an argument to Combine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>) or Combine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>).
of(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Min
A CombineFn that computes the minimum of a collection of elements of type T using an arbitrary Comparator, useful as an argument to Combine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>) or Combine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>).
of(DoFn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.ParDo
Creates a ParDo PTransform that will invoke the given DoFn function.
of(int, Partition.PartitionWithSideInputsFn<? super T>, Requirements) - Static method in class org.apache.beam.sdk.transforms.Partition
Returns a new Partition PTransform that divides its input PCollection into the given number of partitions, using the given partitioning function.
of(int, Partition.PartitionFn<? super T>) - Static method in class org.apache.beam.sdk.transforms.Partition
Returns a new Partition PTransform that divides its input PCollection into the given number of partitions, using the given partitioning function.
of() - Static method in class org.apache.beam.sdk.transforms.Reshuffle
Deprecated.
 
of(ByteKeyRange) - Static method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
 
of(RestrictionT) - Static method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.TruncateResult
Returns a RestrictionTracker.TruncateResult for the given restriction.
of(RestrictionT, RestrictionT) - Static method in class org.apache.beam.sdk.transforms.splittabledofn.SplitResult
Returns a SplitResult for the specified primary and residual restrictions.
of() - Static method in class org.apache.beam.sdk.transforms.ToJson
 
of(int, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Top
Returns a PTransform that takes an input PCollection<T> and returns a PCollection<List<T>> with a single element containing the largest count elements of the input PCollection<T>, in decreasing order, sorted using the given Comparator<T>.
of(PCollectionView<ViewT>) - Static method in class org.apache.beam.sdk.transforms.View.CreatePCollectionView
 
of(Trigger.OnceTrigger...) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterAll
Returns an AfterAll Trigger with the given subtriggers.
of(List<Trigger>) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterAll
Returns an AfterAll Trigger with the given subtriggers.
of(Trigger.OnceTrigger...) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterFirst
Returns an AfterFirst Trigger with the given subtriggers.
of(List<Trigger>) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterFirst
Returns an AfterFirst Trigger with the given subtriggers.
of() - Static method in class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
Returns the default trigger.
of(Duration) - Static method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
Partitions the timestamp space into half-open intervals of the form [N * size, (N + 1) * size), where 0 is the epoch.
of() - Static method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
 
of() - Static method in class org.apache.beam.sdk.transforms.windowing.PaneInfo.PaneInfoCoder
 
of(Duration) - Static method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
Assigns timestamps into half-open intervals of the form [N * period, N * period + size), where 0 is the epoch.
of(T, Exception) - Static method in class org.apache.beam.sdk.transforms.WithFailures.ExceptionElement
 
of(OutputT, PCollection<FailureElementT>) - Static method in class org.apache.beam.sdk.transforms.WithFailures.Result
 
of(PCollection<OutputElementT>, PCollection<FailureElementT>) - Static method in class org.apache.beam.sdk.transforms.WithFailures.Result
 
of(PCollectionTuple, TupleTag<OutputElementT>, TupleTag<FailureElementT>) - Static method in class org.apache.beam.sdk.transforms.WithFailures.Result
 
of(SerializableFunction<V, K>) - Static method in class org.apache.beam.sdk.transforms.WithKeys
Returns a PTransform that takes a PCollection<V> and returns a PCollection<KV<K, V>>, where each of the values in the input PCollection has been paired with a key computed from the value by invoking the given SerializableFunction.
of(K) - Static method in class org.apache.beam.sdk.transforms.WithKeys
Returns a PTransform that takes a PCollection<V> and returns a PCollection<KV<K, V>>, where each of the values in the input PCollection has been paired with the given key.
of(SerializableFunction<T, Instant>) - Static method in class org.apache.beam.sdk.transforms.WithTimestamps
For a SerializableFunction fn from T to Instant, outputs a PTransform that takes an input PCollection<T> and outputs a PCollection<T> containing every element v in the input where each element is output with a timestamp obtained as the result of fn.apply(v).
of() - Static method in class org.apache.beam.sdk.util.BitSetCoder
Deprecated.
 
of(DoFn<?, ?>, TupleTag<?>, Map<String, PCollectionView<?>>, DoFnSchemaInformation) - Static method in class org.apache.beam.sdk.util.DoFnWithExecutionInformation
 
of(double, double, int) - Static method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
 
of(Coder<K>) - Static method in class org.apache.beam.sdk.util.ShardedKey.Coder
 
of(K, byte[]) - Static method in class org.apache.beam.sdk.util.ShardedKey
Creates a ShardedKey with given key and shard id.
of(T, long) - Static method in class org.apache.beam.sdk.util.WeightedValue
 
of(Coder<T>, Coder<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.util.WindowedValue.FullWindowedValueCoder
 
of(T, Instant, Collection<? extends BoundedWindow>, PaneInfo) - Static method in class org.apache.beam.sdk.util.WindowedValue
Returns a WindowedValue with the given value, timestamp, and windows.
of(T, Instant, BoundedWindow, PaneInfo) - Static method in class org.apache.beam.sdk.util.WindowedValue
Returns a WindowedValue with the given value, timestamp, and window.
of(Coder<T>, Coder<? extends BoundedWindow>, Instant, Collection<? extends BoundedWindow>, PaneInfo) - Static method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
Returns the WindowedValue.ParamWindowedValueCoder for the given valueCoder and windowCoder using the supplied parameterized timestamp, windows and pane info for WindowedValue.
of(Coder<T>, Coder<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
Returns the WindowedValue.ParamWindowedValueCoder for the given valueCoder and windowCoder using BoundedWindow.TIMESTAMP_MIN_VALUE as the timestamp, WindowedValue.GLOBAL_WINDOWS as the window and PaneInfo.NO_FIRING as the pane info for parameters.
of(Coder<T>) - Static method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
Returns the WindowedValue.ParamWindowedValueCoder for the given valueCoder and GlobalWindow.Coder#INSTANCE using BoundedWindow.TIMESTAMP_MIN_VALUE as the timestamp, WindowedValue.GLOBAL_WINDOWS as the window and PaneInfo.NO_FIRING as the pane info for parameters.
of(Coder<T>) - Static method in class org.apache.beam.sdk.util.WindowedValue.ValueOnlyWindowedValueCoder
Deprecated.
 
of(Coder<T>, Coder<ErrorT>, Coder<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow.Coder
 
of(T, Instant, BoundedWindow, PaneInfo, ErrorT) - Static method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow
 
of(K, V) - Static method in class org.apache.beam.sdk.values.KV
Returns a KV with the given key and value.
of(PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionList
Returns a singleton PCollectionList containing the given PCollection.
of(Iterable<PCollection<T>>) - Static method in class org.apache.beam.sdk.values.PCollectionList
Returns a PCollectionList containing the given PCollections, in order.
of(TupleTag<T>, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
Returns a singleton PCollectionTuple containing the given PCollection keyed by the given TupleTag.
of(String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
A version of PCollectionTuple.of(TupleTag, PCollection) that takes in a String instead of a TupleTag.
of(String, PCollection<T>, String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
A version of PCollectionTuple.of(String, PCollection) that takes in two PCollections of the same type.
of(String, PCollection<T>, String, PCollection<T>, String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
A version of PCollectionTuple.of(String, PCollection) that takes in three PCollections of the same type.
of(String, PCollection<T>, String, PCollection<T>, String, PCollection<T>, String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
A version of PCollectionTuple.of(String, PCollection) that takes in four PCollections of the same type.
of(String, PCollection<T>, String, PCollection<T>, String, PCollection<T>, String, PCollection<T>, String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
A version of PCollectionTuple.of(String, PCollection) that takes in five PCollections of the same type.
of(K, int) - Static method in class org.apache.beam.sdk.values.ShardedKey
 
of(TupleTag<?>, PCollection<?>) - Static method in class org.apache.beam.sdk.values.TaggedPValue
 
of(V, Instant) - Static method in class org.apache.beam.sdk.values.TimestampedValue
Returns a new TimestampedValue with the given value and timestamp.
of(Coder<T>) - Static method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
 
of(TupleTag<?>) - Static method in class org.apache.beam.sdk.values.TupleTagList
Returns a singleton TupleTagList containing the given TupleTag.
of(List<TupleTag<?>>) - Static method in class org.apache.beam.sdk.values.TupleTagList
Returns a TupleTagList containing the given TupleTags, in order.
of(Class<T>) - Static method in class org.apache.beam.sdk.values.TypeDescriptor
Returns a TypeDescriptor representing the given type.
of(Type) - Static method in class org.apache.beam.sdk.values.TypeDescriptor
Returns a TypeDescriptor representing the given type.
of(Coder<T>, Coder<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
 
of(T, Instant, BoundedWindow, PaneInfo) - Static method in class org.apache.beam.sdk.values.ValueInSingleWindow
 
of(Coder<ValueT>) - Static method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
 
of(WindowFn<T, W>) - Static method in class org.apache.beam.sdk.values.WindowingStrategy
 
ofClass(Class<?>) - Static method in class org.apache.beam.sdk.util.ApiSurface
Returns an ApiSurface object representing just the surface of the given class.
ofDoubles() - Static method in class org.apache.beam.sdk.transforms.Max
ofDoubles() - Static method in class org.apache.beam.sdk.transforms.Min
ofDoubles() - Static method in class org.apache.beam.sdk.transforms.Sum
ofExpandedValue(PCollection<?>) - Static method in class org.apache.beam.sdk.values.TaggedPValue
 
offerCoders(Coder[]) - Method in interface org.apache.beam.sdk.state.StateSpec
For internal use only; no backwards-compatibility guarantees.
ofFirstElement() - Static method in class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
 
offset(Duration) - Method in interface org.apache.beam.sdk.state.Timer
Offsets the target timestamp used by Timer.setRelative() by the given duration.
OFFSET_INFINITY - Static variable in class org.apache.beam.sdk.io.range.OffsetRangeTracker
Offset corresponding to infinity.
OffsetBasedReader(OffsetBasedSource<T>) - Constructor for class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
 
OffsetBasedSource<T> - Class in org.apache.beam.sdk.io
A BoundedSource that uses offsets to define starting and ending positions.
OffsetBasedSource(long, long, long) - Constructor for class org.apache.beam.sdk.io.OffsetBasedSource
 
OffsetBasedSource.OffsetBasedReader<T> - Class in org.apache.beam.sdk.io
A Source.Reader that implements code common to readers of all OffsetBasedSources.
OffsetRange - Class in org.apache.beam.sdk.io.range
A restriction represented by a range of integers [from, to).
OffsetRange(long, long) - Constructor for class org.apache.beam.sdk.io.range.OffsetRange
 
OffsetRange.Coder - Class in org.apache.beam.sdk.io.range
A coder for OffsetRanges.
OffsetRangeTracker - Class in org.apache.beam.sdk.io.range
A RangeTracker for non-negative positions of type long.
OffsetRangeTracker(long, long) - Constructor for class org.apache.beam.sdk.io.range.OffsetRangeTracker
Creates an OffsetRangeTracker for the specified range.
OffsetRangeTracker - Class in org.apache.beam.sdk.transforms.splittabledofn
A RestrictionTracker for claiming offsets in an OffsetRange in a monotonically increasing fashion.
OffsetRangeTracker(OffsetRange) - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
 
ofIntegers() - Static method in class org.apache.beam.sdk.transforms.Max
ofIntegers() - Static method in class org.apache.beam.sdk.transforms.Min
ofIntegers() - Static method in class org.apache.beam.sdk.transforms.Sum
ofLongs() - Static method in class org.apache.beam.sdk.transforms.Max
ofLongs() - Static method in class org.apache.beam.sdk.transforms.Min
ofLongs() - Static method in class org.apache.beam.sdk.transforms.Sum
ofPackage(String, ClassLoader) - Static method in class org.apache.beam.sdk.util.ApiSurface
Returns an ApiSurface object representing the given package and all subpackages.
ofPackage(Package, ClassLoader) - Static method in class org.apache.beam.sdk.util.ApiSurface
Returns an ApiSurface object representing the given package and all subpackages.
ofPrimitiveOutputsInternal(Pipeline, TupleTagList, Map<TupleTag<?>, Coder<?>>, WindowingStrategy<?, ?>, PCollection.IsBounded) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
For internal use only; no backwards-compatibility guarantees.
ofProvider(ValueProvider<T>, Coder<T>) - Static method in class org.apache.beam.sdk.transforms.Create
Returns an Create.OfValueProvider transform that produces a PCollection of a single element provided by the given ValueProvider.
ofSize(long) - Static method in class org.apache.beam.sdk.transforms.GroupIntoBatches
 
ofType(Class<T>) - Static method in class org.apache.beam.sdk.util.InstanceBuilder
Create an InstanceBuilder for the given type.
ofType(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.util.InstanceBuilder
Create an InstanceBuilder for the given type.
on(Join.FieldsEqual.Impl) - Method in class org.apache.beam.sdk.schemas.transforms.Join.Impl
Join the PCollections using the provided predicate.
on(PCollection<?>...) - Static method in class org.apache.beam.sdk.transforms.Wait
Waits on the given signal collections.
on(List<PCollection<?>>) - Static method in class org.apache.beam.sdk.transforms.Wait
Waits on the given signal collections.
ON_TIME_AND_ONLY_FIRING - Static variable in class org.apache.beam.sdk.transforms.windowing.PaneInfo
PaneInfo to use when there will be exactly one firing and it is on time.
onBundleSuccess() - Method in interface org.apache.beam.sdk.transforms.DoFn.BundleFinalizer.Callback
 
OnceTrigger(List<Trigger>) - Constructor for class org.apache.beam.sdk.transforms.windowing.Trigger.OnceTrigger
 
OneOfType - Class in org.apache.beam.sdk.schemas.logicaltypes
A logical type representing a union of fields.
OneOfType.Value - Class in org.apache.beam.sdk.schemas.logicaltypes
Represents a single OneOf value.
onSeenNewOutput(Instant, StateT) - Method in interface org.apache.beam.sdk.transforms.Watch.Growth.TerminationCondition
Called by the Watch transform to compute a new termination state, in case after calling the Watch.Growth.PollFn for the current input, the Watch.Growth.PollResult included a previously unseen OutputT.
onStartup() - Method in interface org.apache.beam.sdk.harness.JvmInitializer
Implement onStartup to run some custom initialization immediately after the JVM is launched for pipeline execution.
OnTimerContext() - Constructor for class org.apache.beam.sdk.transforms.DoFn.OnTimerContext
 
onTimerContext(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provide a DoFn.OnTimerContext to use with the given DoFn.
onTimerContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
onTimerContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
onTimerContext() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
OnTimerFamilyMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerFamilyMethod
 
onTimerFamilyMethods() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.OnTimerFamily methods.
OnTimerInvoker<InputT,OutputT> - Interface in org.apache.beam.sdk.transforms.reflect
Interface for invoking the DoFn.OnTimer method for a particular timer.
OnTimerMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerMethod
 
onTimerMethods() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.OnTimer methods.
onWindowExpiration() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.OnWindowExpiration method.
OnWindowExpirationContext() - Constructor for class org.apache.beam.sdk.transforms.DoFn.OnWindowExpirationContext
 
onWindowExpirationContext() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
OnWindowExpirationMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnWindowExpirationMethod
 
open(WritableByteChannel) - Method in class org.apache.beam.sdk.io.AvroIO.Sink
 
open(ClassLoaderFileSystem.ClassLoaderResourceId) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
 
open(String) - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
Opens a uniquely named temporary file and initializes the writer using FileBasedSink.Writer.prepareWrite(java.nio.channels.WritableByteChannel).
open() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
Returns a ReadableByteChannel reading the data from this file, potentially decompressing it using FileIO.ReadableFile.getCompression().
open(WritableByteChannel) - Method in interface org.apache.beam.sdk.io.FileIO.Sink
Initializes writing to the given channel.
open(ResourceIdT) - Method in class org.apache.beam.sdk.io.FileSystem
Returns a read channel for the given ResourceIdT.
open(ResourceId) - Static method in class org.apache.beam.sdk.io.FileSystems
Returns a read channel for the given ResourceId.
open(WritableByteChannel) - Method in class org.apache.beam.sdk.io.TextIO.Sink
 
open(WritableByteChannel) - Method in class org.apache.beam.sdk.io.TFRecordIO.Sink
 
openSeekable() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
Returns a SeekableByteChannel equivalent to FileIO.ReadableFile.open(), but fails if this file is not seekable.
Options() - Constructor for class org.apache.beam.sdk.options.ManualDockerEnvironmentOptions.Options
 
Options() - Constructor for class org.apache.beam.sdk.options.RemoteEnvironmentOptions.Options
 
or(PTransformMatcher) - Method in interface org.apache.beam.sdk.runners.PTransformMatcher
 
OrderByKey() - Constructor for class org.apache.beam.sdk.values.KV.OrderByKey
 
OrderByValue() - Constructor for class org.apache.beam.sdk.values.KV.OrderByValue
 
orderedList(Coder<T>) - Static method in class org.apache.beam.sdk.state.StateSpecs
 
OrderedListState<T> - Interface in org.apache.beam.sdk.state
A ReadableState cell containing a list of values sorted by timestamp.
orFinally(Trigger.OnceTrigger) - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
Specify an ending condition for this trigger.
OrFinallyTrigger - Class in org.apache.beam.sdk.transforms.windowing
A Trigger that executes according to its main trigger until its "finally" trigger fires.
org.apache.beam.sdk - package org.apache.beam.sdk
Provides a simple, powerful model for building both batch and streaming parallel data processing Pipelines.
org.apache.beam.sdk.annotations - package org.apache.beam.sdk.annotations
Defines annotations used across the SDK.
org.apache.beam.sdk.coders - package org.apache.beam.sdk.coders
Defines Coders to specify how data is encoded to and decoded from byte strings.
org.apache.beam.sdk.expansion - package org.apache.beam.sdk.expansion
Contains classes needed to expose transforms to other SDKs.
org.apache.beam.sdk.function - package org.apache.beam.sdk.function
Java 8 functional interface extensions.
org.apache.beam.sdk.harness - package org.apache.beam.sdk.harness
Utilities for configuring worker environment.
org.apache.beam.sdk.io - package org.apache.beam.sdk.io
Defines transforms for reading and writing common storage formats, including AvroIO, and TextIO.
org.apache.beam.sdk.io.fs - package org.apache.beam.sdk.io.fs
Apache Beam FileSystem interfaces and their default implementations.
org.apache.beam.sdk.io.range - package org.apache.beam.sdk.io.range
Provides thread-safe helpers for implementing dynamic work rebalancing in position-based bounded sources.
org.apache.beam.sdk.metrics - package org.apache.beam.sdk.metrics
Metrics allow exporting information about the execution of a pipeline.
org.apache.beam.sdk.options - package org.apache.beam.sdk.options
Defines PipelineOptions for configuring pipeline execution.
org.apache.beam.sdk.runners - package org.apache.beam.sdk.runners
For internal use only; no backwards compatibility guarantees.
org.apache.beam.sdk.schemas - package org.apache.beam.sdk.schemas
Defines Schema and other classes for representing schema'd data in a Pipeline.
org.apache.beam.sdk.schemas.annotations - package org.apache.beam.sdk.schemas.annotations
Defines Schema and other classes for representing schema'd data in a Pipeline.
org.apache.beam.sdk.schemas.io - package org.apache.beam.sdk.schemas.io
Provides abstractions for schema-aware IOs.
org.apache.beam.sdk.schemas.io.payloads - package org.apache.beam.sdk.schemas.io.payloads
Provides abstractions for schema-aware IOs.
org.apache.beam.sdk.schemas.logicaltypes - package org.apache.beam.sdk.schemas.logicaltypes
A set of common LogicalTypes for use with schemas.
org.apache.beam.sdk.schemas.parser - package org.apache.beam.sdk.schemas.parser
Defines utilities for deailing with schemas.
org.apache.beam.sdk.schemas.parser.generated - package org.apache.beam.sdk.schemas.parser.generated
Defines utilities for deailing with schemas.
org.apache.beam.sdk.schemas.transforms - package org.apache.beam.sdk.schemas.transforms
Defines transforms that work on PCollections with schemas..
org.apache.beam.sdk.schemas.utils - package org.apache.beam.sdk.schemas.utils
Defines utilities for deailing with schemas.
org.apache.beam.sdk.state - package org.apache.beam.sdk.state
Classes and interfaces for interacting with state.
org.apache.beam.sdk.testing - package org.apache.beam.sdk.testing
Defines utilities for unit testing Apache Beam pipelines.
org.apache.beam.sdk.transforms - package org.apache.beam.sdk.transforms
Defines PTransforms for transforming data in a pipeline.
org.apache.beam.sdk.transforms.display - package org.apache.beam.sdk.transforms.display
Defines HasDisplayData for annotating components which provide display data used within UIs and diagnostic tools.
org.apache.beam.sdk.transforms.join - package org.apache.beam.sdk.transforms.join
Defines the CoGroupByKey transform for joining multiple PCollections.
org.apache.beam.sdk.transforms.reflect - package org.apache.beam.sdk.transforms.reflect
For internal use only; no backwards-compatibility guarantees.
org.apache.beam.sdk.transforms.splittabledofn - package org.apache.beam.sdk.transforms.splittabledofn
Defines utilities related to splittable DoFn.
org.apache.beam.sdk.transforms.windowing - package org.apache.beam.sdk.transforms.windowing
Defines the Window transform for dividing the elements in a PCollection into windows, and the Trigger for controlling when those elements are output.
org.apache.beam.sdk.util - package org.apache.beam.sdk.util
For internal use only; no backwards compatibility guarantees.
org.apache.beam.sdk.util.common - package org.apache.beam.sdk.util.common
Defines utilities shared by multiple PipelineRunner implementations.
org.apache.beam.sdk.values - package org.apache.beam.sdk.values
Defines PCollection and other classes for representing data in a Pipeline.
OUTER - Static variable in class org.apache.beam.sdk.coders.Coder.Context
Deprecated.
The outer context: the value being encoded or decoded takes up the remainder of the record/stream contents.
output(OutputT, Instant, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFn.FinishBundleContext
Adds the given element to the main output PCollection at the given timestamp in the given window.
output(TupleTag<T>, T, Instant, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFn.FinishBundleContext
Adds the given element to the output PCollection with the given tag at the given timestamp in the given window.
output(T) - Method in interface org.apache.beam.sdk.transforms.DoFn.OutputReceiver
 
output(OutputT) - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
Adds the given element to the main output PCollection.
output(TupleTag<T>, T) - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
Adds the given element to the output PCollection with the given tag.
output() - Method in class org.apache.beam.sdk.transforms.WithFailures.Result
 
outputOf(ProcessFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
Returns a type descriptor for the output of the given ProcessFunction, subject to Java type erasure: may contain unresolved type variables if the type was erased.
outputOf(SerializableFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
Binary compatibility adapter for TypeDescriptors.outputOf(ProcessFunction).
outputOf(Contextful.Fn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
Like TypeDescriptors.outputOf(ProcessFunction) but for Contextful.Fn.
OutputRangeTracker(OffsetRange) - Constructor for class org.apache.beam.sdk.transforms.PeriodicSequence.OutputRangeTracker
 
outputReceiver(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provide a DoFn.OutputReceiver for outputting to the default output.
outputReceiver(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
outputReceiver(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
outputReceiverParameter(boolean) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
 
outputRowReceiver(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provide a DoFn.OutputReceiver for outputting rows to the default output.
outputRowReceiver(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
outputRowReceiver(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
outputRuntimeOptions() - Method in interface org.apache.beam.sdk.options.PipelineOptions
Returns a map of properties which correspond to ValueProvider.RuntimeValueProvider, keyed by the property name.
outputSchema() - Method in class org.apache.beam.sdk.schemas.transforms.Cast
 
outputSchemaCoder - Variable in class org.apache.beam.sdk.schemas.utils.ConvertHelpers.ConvertedSchemaInformation
 
outputWithTimestamp(T, Instant) - Method in interface org.apache.beam.sdk.transforms.DoFn.OutputReceiver
 
outputWithTimestamp(OutputT, Instant) - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
Adds the given element to the main output PCollection, with the given timestamp.
outputWithTimestamp(TupleTag<T>, T, Instant) - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
Adds the given element to the specified output PCollection, with the given timestamp.
overlaps(ByteKeyRange) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
Returns true if the specified ByteKeyRange overlaps this range.

P

p50() - Method in class org.apache.beam.sdk.util.HistogramData
 
p90() - Method in class org.apache.beam.sdk.util.HistogramData
 
p99() - Method in class org.apache.beam.sdk.util.HistogramData
 
pane() - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContext
Returns information about the pane within this window into which the input element has been assigned.
paneInfo(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provides a PaneInfo.
paneInfo(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
paneInfo(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
PaneInfo - Class in org.apache.beam.sdk.transforms.windowing
Provides information about the pane an element belongs to.
PaneInfo.PaneInfoCoder - Class in org.apache.beam.sdk.transforms.windowing
A Coder for encoding PaneInfo instances.
PaneInfo.Timing - Enum in org.apache.beam.sdk.transforms.windowing
Enumerates the possibilities for the timing of this pane firing related to the input and output watermarks for its computation.
paneInfoParameter() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
 
Params() - Constructor for class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
Construct a default Params object.
ParamsCoder() - Constructor for class org.apache.beam.sdk.io.DefaultFilenamePolicy.ParamsCoder
 
ParDo - Class in org.apache.beam.sdk.transforms
ParDo is the core element-wise transform in Apache Beam, invoking a user-specified function on each of the elements of the input PCollection to produce zero or more output elements, all of which are collected into the output PCollection.
ParDo() - Constructor for class org.apache.beam.sdk.transforms.ParDo
 
ParDo.MultiOutput<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
A PTransform that, when applied to a PCollection<InputT>, invokes a user-specified DoFn<InputT, OutputT> on all its elements, which can emit elements to any of the PTransform's output PCollections, which are bundled into a result PCollectionTuple.
ParDo.SingleOutput<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
A PTransform that, when applied to a PCollection<InputT>, invokes a user-specified DoFn<InputT, OutputT> on all its elements, with all its outputs collected into an output PCollection<OutputT>.
parent() - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
Type of parent node in a tree.
Parse() - Constructor for class org.apache.beam.sdk.io.AvroIO.Parse
 
parse(String) - Static method in class org.apache.beam.sdk.schemas.parser.FieldAccessDescriptorParser
 
parse(T) - Method in class org.apache.beam.sdk.testing.JsonMatcher
 
ParseAll() - Constructor for class org.apache.beam.sdk.io.AvroIO.ParseAll
Deprecated.
 
parseAllGenericRecords(SerializableFunction<GenericRecord, T>) - Static method in class org.apache.beam.sdk.io.AvroIO
Deprecated.
You can achieve The functionality of AvroIO.parseAllGenericRecords(SerializableFunction) using FileIO matching plus AvroIO.parseFilesGenericRecords(SerializableFunction) ()}. This is the preferred method to make composition explicit. AvroIO.ParseAll will not receive upgrades and will be removed in a future version of Beam.
ParseFiles() - Constructor for class org.apache.beam.sdk.io.AvroIO.ParseFiles
 
parseFilesGenericRecords(SerializableFunction<GenericRecord, T>) - Static method in class org.apache.beam.sdk.io.AvroIO
parseGenericRecords(SerializableFunction<GenericRecord, T>) - Static method in class org.apache.beam.sdk.io.AvroIO
Reads Avro file(s) containing records of an unspecified schema and converting each record to a custom type.
ParseResult() - Constructor for class org.apache.beam.sdk.transforms.JsonToRow.ParseResult
 
ParseWithError() - Constructor for class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError
 
Partition<T> - Class in org.apache.beam.sdk.transforms
Partition takes a PCollection<T> and a PartitionFn, uses the PartitionFn to split the elements of the input PCollection into N partitions, and returns a PCollectionList<T> that bundles N PCollection<T>s containing the split elements.
Partition.PartitionFn<T> - Interface in org.apache.beam.sdk.transforms
A function object that chooses an output partition for an element.
Partition.PartitionWithSideInputsFn<T> - Interface in org.apache.beam.sdk.transforms
A function object that chooses an output partition for an element.
partitionFor(T, int) - Method in interface org.apache.beam.sdk.transforms.Partition.PartitionFn
Chooses the partition into which to put the given element.
partitionFor(T, int, Contextful.Fn.Context) - Method in interface org.apache.beam.sdk.transforms.Partition.PartitionWithSideInputsFn
Chooses the partition into which to put the given element.
PartitioningWindowFn<T,W extends BoundedWindow> - Class in org.apache.beam.sdk.transforms.windowing
A WindowFn that places each value into exactly one window based on its timestamp and never merges windows.
PartitioningWindowFn() - Constructor for class org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn
 
PAssert - Class in org.apache.beam.sdk.testing
An assertion on the contents of a PCollection incorporated into the pipeline.
PAssert.DefaultConcludeTransform - Class in org.apache.beam.sdk.testing
Default transform to check that a PAssert was successful.
PAssert.GroupThenAssert<T> - Class in org.apache.beam.sdk.testing
A transform that applies an assertion-checking function over iterables of ActualT to the entirety of the contents of its input.
PAssert.GroupThenAssertForSingleton<T> - Class in org.apache.beam.sdk.testing
A transform that applies an assertion-checking function to the sole element of a PCollection.
PAssert.IterableAssert<T> - Interface in org.apache.beam.sdk.testing
Builder interface for assertions applicable to iterables and PCollection contents.
PAssert.OneSideInputAssert<ActualT> - Class in org.apache.beam.sdk.testing
An assertion checker that takes a single PCollectionView<ActualT> and an assertion over ActualT, and checks it within a Beam pipeline.
PAssert.PAssertionSite - Class in org.apache.beam.sdk.testing
Track the place where an assertion is defined.
PAssert.PCollectionContentsAssert<T> - Class in org.apache.beam.sdk.testing
An PAssert.IterableAssert about the contents of a PCollection.
PAssert.PCollectionContentsAssert.MatcherCheckerFn<T> - Class in org.apache.beam.sdk.testing
Check that the passed-in matchers match the existing data.
PAssert.SingletonAssert<T> - Interface in org.apache.beam.sdk.testing
Builder interface for assertions applicable to a single value.
PassThroughLogicalType<T> - Class in org.apache.beam.sdk.schemas.logicaltypes
A base class for LogicalTypes that use the same Java type as the underlying base type.
PassThroughLogicalType(String, Schema.FieldType, Object, Schema.FieldType) - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
 
pastEndOfWindow() - Static method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark
Creates a trigger that fires when the watermark passes the end of the window.
pastFirstElementInPane() - Static method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
Creates a trigger that fires when the current processing time passes the processing time at which this trigger saw the first element in a pane.
path() - Method in class org.apache.beam.sdk.schemas.transforms.Cast.CompatibilityError
 
path() - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
Field path from a root of a schema.
PayloadSerializer - Interface in org.apache.beam.sdk.schemas.io.payloads
 
PayloadSerializerProvider - Interface in org.apache.beam.sdk.schemas.io.payloads
 
PayloadSerializers - Class in org.apache.beam.sdk.schemas.io.payloads
 
PBegin - Class in org.apache.beam.sdk.values
PBegin is the "input" to a root PTransform, such as Read or Create.
PBegin(Pipeline) - Constructor for class org.apache.beam.sdk.values.PBegin
Constructs a PBegin in the given Pipeline.
PCollection<T> - Class in org.apache.beam.sdk.values
A PCollection<T> is an immutable collection of values of type T.
PCollection.IsBounded - Enum in org.apache.beam.sdk.values
The enumeration of cases for whether a PCollection is bounded.
PCollectionContentsAssert(PCollection<T>, PAssert.PAssertionSite) - Constructor for class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
 
PCollectionContentsAssert(PCollection<T>, PAssert.AssertionWindows, SimpleFunction<Iterable<ValueInSingleWindow<T>>, Iterable<T>>, PAssert.PAssertionSite) - Constructor for class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
 
PCollectionList<T> - Class in org.apache.beam.sdk.values
A PCollectionList<T> is an immutable list of homogeneously typed PCollection<T>s.
pCollections() - Static method in class org.apache.beam.sdk.transforms.Flatten
Returns a PTransform that flattens a PCollectionList into a PCollection containing all the elements of all the PCollections in its input.
PCollectionTuple - Class in org.apache.beam.sdk.values
A PCollectionTuple is an immutable tuple of heterogeneously-typed PCollections, "keyed" by TupleTags.
PCollectionView<T> - Interface in org.apache.beam.sdk.values
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.
PCollectionViews - Class in org.apache.beam.sdk.values
For internal use only; no backwards compatibility guarantees.
PCollectionViews() - Constructor for class org.apache.beam.sdk.values.PCollectionViews
 
PCollectionViews.IterableViewFn<T> - Class in org.apache.beam.sdk.values
Deprecated.
See IterableViewFn2.
PCollectionViews.ListViewFn<T> - Class in org.apache.beam.sdk.values
Deprecated.
See ListViewFn2.
PCollectionViews.MapViewFn<K,V> - Class in org.apache.beam.sdk.values
Deprecated.
See MapViewFn2.
PCollectionViews.MultimapViewFn<K,V> - Class in org.apache.beam.sdk.values
Deprecated.
See MultimapViewFn2.
PCollectionViews.SimplePCollectionView<ElemT,PrimitiveViewT,ViewT,W extends BoundedWindow> - Class in org.apache.beam.sdk.values
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> - Class in org.apache.beam.sdk.values
Deprecated.
See SingletonViewFn2.
PCollectionViews.TypeDescriptorSupplier<T> - Interface in org.apache.beam.sdk.values
 
PCollectionViews.ValueOrMetadata<T,MetaT> - Class in org.apache.beam.sdk.values
Stores values or metadata about values.
PCollectionViews.ValueOrMetadataCoder<T,MetaT> - Class in org.apache.beam.sdk.values
PDone - Class in org.apache.beam.sdk.values
PDone is the output of a PTransform that has a trivial result, such as a WriteFiles.
peekOutputElements() - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
peekOutputElements(TupleTag<T>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
peekOutputElementsInWindow(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
peekOutputElementsInWindow(TupleTag<OutputT>, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
peekOutputElementsWithTimestamp() - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
perElement() - Static method in class org.apache.beam.sdk.transforms.Count
Returns a PTransform that counts the number of occurrences of each element in its input PCollection.
PeriodicImpulse - Class in org.apache.beam.sdk.transforms
A PTransform which produces a sequence of elements at fixed runtime intervals.
PeriodicSequence - Class in org.apache.beam.sdk.transforms
A PTransform which generates a sequence of timestamped elements at given runtime intervals.
PeriodicSequence.OutputRangeTracker - Class in org.apache.beam.sdk.transforms
 
PeriodicSequence.SequenceDefinition - Class in org.apache.beam.sdk.transforms
 
perKey(int, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles
Returns a PTransform that takes a PCollection<KV<K, V>> and returns a PCollection<KV<K, List<V>>> that contains an output element mapping each distinct key in the input PCollection to a List of the approximate N-tiles of the values associated with that key in the input PCollection.
perKey(int) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles
Like ApproximateQuantiles.perKey(int, Comparator), but sorts values using the their natural ordering.
perKey(int) - Static method in class org.apache.beam.sdk.transforms.ApproximateUnique
Deprecated.
Returns a PTransform that takes a PCollection<KV<K, V>> and returns a PCollection<KV<K, Long>> that contains an output element mapping each distinct key in the input PCollection to an estimate of the number of distinct values associated with that key in the input PCollection.
perKey(double) - Static method in class org.apache.beam.sdk.transforms.ApproximateUnique
Deprecated.
Like ApproximateUnique.perKey(int), but specifies the desired maximum estimation error instead of the sample size.
PerKey(int) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.PerKey
Deprecated.
 
PerKey(double) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.PerKey
Deprecated.
 
perKey(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
Returns a Combine.PerKey PTransform that first groups its input PCollection of KVs by keys and windows, then invokes the given function on each of the values lists to produce a combined value, and then returns a PCollection of KVs mapping each distinct key to its combined value for each window.
perKey(SerializableBiFunction<V, V, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
Returns a Combine.PerKey PTransform that first groups its input PCollection of KVs by keys and windows, then invokes the given function on each of the values lists to produce a combined value, and then returns a PCollection of KVs mapping each distinct key to its combined value for each window.
perKey(CombineFnBase.GlobalCombineFn<? super InputT, ?, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Combine
Returns a Combine.PerKey PTransform that first groups its input PCollection of KVs by keys and windows, then invokes the given function on each of the values lists to produce a combined value, and then returns a PCollection of KVs mapping each distinct key to its combined value for each window.
perKey() - Static method in class org.apache.beam.sdk.transforms.Count
Returns a PTransform that counts the number of elements associated with each key of its input PCollection.
perKey() - Static method in class org.apache.beam.sdk.transforms.Latest
Returns a PTransform that takes as input a PCollection<KV<K, V>> and returns a PCollection<KV<K, V>> whose contents is the latest element per-key according to its event time.
perKey() - Static method in class org.apache.beam.sdk.transforms.Max
Returns a PTransform that takes an input PCollection<KV<K, T>> and returns a PCollection<KV<K, T>> that contains an output element mapping each distinct key in the input PCollection to the maximum according to the natural ordering of T of the values associated with that key in the input PCollection.
perKey(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Max
Returns a PTransform that takes an input PCollection<KV<K, T>> and returns a PCollection<KV<K, T>> that contains one output element per key mapping each to the maximum of the values associated with that key in the input PCollection.
perKey() - Static method in class org.apache.beam.sdk.transforms.Mean
Returns a PTransform that takes an input PCollection<KV<K, N>> and returns a PCollection<KV<K, Double>> that contains an output element mapping each distinct key in the input PCollection to the mean of the values associated with that key in the input PCollection.
perKey() - Static method in class org.apache.beam.sdk.transforms.Min
Returns a PTransform that takes an input PCollection<KV<K, T>> and returns a PCollection<KV<K, T>> that contains an output element mapping each distinct key in the input PCollection to the minimum according to the natural ordering of T of the values associated with that key in the input PCollection.
perKey(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Min
Returns a PTransform that takes an input PCollection<KV<K, T>> and returns a PCollection<KV<K, T>> that contains one output element per key mapping each to the minimum of the values associated with that key in the input PCollection.
perKey(int, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Top
Returns a PTransform that takes an input PCollection<KV<K, V>> and returns a PCollection<KV<K, List<V>>> that contains an output element mapping each distinct key in the input PCollection to the largest count values associated with that key in the input PCollection<KV<K, V>>, in decreasing order, sorted using the given Comparator<V>.
PInput - Interface in org.apache.beam.sdk.values
The interface for things that might be input to a PTransform.
Pipeline - Class in org.apache.beam.sdk
A Pipeline manages a directed acyclic graph of PTransforms, and the PCollections that the PTransforms consume and produce.
Pipeline(PipelineOptions) - Constructor for class org.apache.beam.sdk.Pipeline
 
Pipeline.PipelineExecutionException - Exception in org.apache.beam.sdk
Thrown during execution of a Pipeline, whenever user code within that Pipeline throws an exception.
Pipeline.PipelineVisitor - Interface in org.apache.beam.sdk
For internal use only; no backwards-compatibility guarantees.
Pipeline.PipelineVisitor.CompositeBehavior - Enum in org.apache.beam.sdk
Control enum for indicating whether or not a traversal should process the contents of a composite transform or not.
Pipeline.PipelineVisitor.Defaults - Class in org.apache.beam.sdk
Default no-op Pipeline.PipelineVisitor that enters all composite transforms.
PipelineExecutionException(Throwable) - Constructor for exception org.apache.beam.sdk.Pipeline.PipelineExecutionException
PipelineOptions - Interface in org.apache.beam.sdk.options
PipelineOptions are used to configure Pipelines.
pipelineOptions() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
pipelineOptions() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
pipelineOptions() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
pipelineOptions() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
PipelineOptions.AtomicLongFactory - Class in org.apache.beam.sdk.options
DefaultValueFactory which supplies an ID that is guaranteed to be unique within the given process.
PipelineOptions.CheckEnabled - Enum in org.apache.beam.sdk.options
Enumeration of the possible states for a given check.
PipelineOptions.DirectRunner - Class in org.apache.beam.sdk.options
A DefaultValueFactory that obtains the class of the DirectRunner if it exists on the classpath, and throws an exception otherwise.
PipelineOptions.JobNameFactory - Class in org.apache.beam.sdk.options
Returns a normalized job name constructed from ApplicationNameOptions.getAppName(), the local system user name (if available), the current time, and a random integer.
PipelineOptions.UserAgentFactory - Class in org.apache.beam.sdk.options
Returns a user agent string constructed from ReleaseInfo.getName() and ReleaseInfo.getVersion(), in the format [name]/[version].
PipelineOptionsFactory - Class in org.apache.beam.sdk.options
Constructs a PipelineOptions or any derived interface that is composable to any other derived interface of PipelineOptions via the PipelineOptions.as(java.lang.Class<T>) method.
PipelineOptionsFactory() - Constructor for class org.apache.beam.sdk.options.PipelineOptionsFactory
 
PipelineOptionsFactory.Builder - Class in org.apache.beam.sdk.options
A fluent PipelineOptions builder.
PipelineOptionsRegistrar - Interface in org.apache.beam.sdk.options
PipelineOptions creators have the ability to automatically have their PipelineOptions registered with this SDK by creating a ServiceLoader entry and a concrete implementation of this interface.
PipelineOptionsValidator - Class in org.apache.beam.sdk.options
Validates that the PipelineOptions conforms to all the Validation criteria.
PipelineOptionsValidator() - Constructor for class org.apache.beam.sdk.options.PipelineOptionsValidator
 
PipelineResult - Interface in org.apache.beam.sdk
Result of Pipeline.run().
PipelineResult.State - Enum in org.apache.beam.sdk
Possible job states, for both completed and ongoing jobs.
PipelineRunner<ResultT extends PipelineResult> - Class in org.apache.beam.sdk
PipelineRunner() - Constructor for class org.apache.beam.sdk.PipelineRunner
 
PipelineRunnerRegistrar - Interface in org.apache.beam.sdk.runners
For internal use only; no backwards-compatibility guarantees.
plusDelayOf(Duration) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
Adds some delay to the original target time.
POJOUtils - Class in org.apache.beam.sdk.schemas.utils
A set of utilities to generate getter and setter classes for POJOs.
POJOUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.POJOUtils
 
PollFn() - Constructor for class org.apache.beam.sdk.transforms.Watch.Growth.PollFn
 
popNode() - Method in class org.apache.beam.sdk.runners.TransformHierarchy
Pops the current node off the top of the stack, finishing it.
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.Parse
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.ParseAll
Deprecated.
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.ParseFiles
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.Read
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.ReadAll
Deprecated.
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.ReadFiles
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.Write
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.BoundedReadFromUnboundedSource
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.CompressedSource
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
Populates the display data.
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileBasedSink.FilenamePolicy
Populates the display data.
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileBasedSink
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileBasedSource
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileIO.Match
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileIO.MatchAll
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileIO.MatchConfiguration
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileIO.ReadMatches
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.GenerateSequence
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.OffsetBasedSource
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.Read.Bounded
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.Read.Unbounded
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.Source
Register display data for the given transform or component.
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.Read
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
Deprecated.
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.ReadFiles
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.Write
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.WriteFiles
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.Globally
Deprecated.
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.PerKey
Deprecated.
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.Globally
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.GloballyAsSingletonView
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.PerKeyWithHotKeyFanout
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
 
populateDisplayData(DisplayData.Builder) - Method in interface org.apache.beam.sdk.transforms.display.HasDisplayData
Register display data for the given transform or component.
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.DoFn
Register display data for the given transform or component.
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Filter
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.FlatMapElements.FlatMapWithFailures
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.GroupByKey
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.InferableFunction
Register display data for the given transform or component.
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.MapElements.MapWithFailures
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.MapElements
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
Register display data for the given transform or component.
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Partition
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.PTransform
Register display data for the given transform or component.
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Top.TopCombineFn
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.Window.Assign
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.Window
 
populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
Register display data for the given transform or component.
PortablePipelineOptions - Interface in org.apache.beam.sdk.options
Pipeline options common to all portable runners.
POutput - Interface in org.apache.beam.sdk.values
The interface for things that might be output from a PTransform.
Preconditions - Class in org.apache.beam.sdk.util
Beam-specific variants of Preconditions that throws more appropriate exception classes while being static analysis friendly.
Preconditions() - Constructor for class org.apache.beam.sdk.util.Preconditions
 
PREFIX - Static variable in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TimerDeclaration
 
PREFIX - Static variable in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TimerFamilyDeclaration
 
prepareForProcessing() - Method in class org.apache.beam.sdk.transforms.DoFn
Deprecated.
use DoFn.Setup or DoFn.StartBundle instead. This method will be removed in a future release.
prepareWrite(WritableByteChannel) - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
Called with the channel that a subclass will write its header, footer, and values to.
printHelp(PrintStream) - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
Outputs the set of registered options with the PipelineOptionsFactory with a description for each one if available to the output stream.
printHelp(PrintStream, Class<? extends PipelineOptions>) - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
Outputs the set of options available to be set for the passed in PipelineOptions interface.
processBundle(Iterable<? extends InputT>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
processBundle(InputT...) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
ProcessContext() - Constructor for class org.apache.beam.sdk.transforms.DoFn.ProcessContext
 
processContext(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provide a DoFn.ProcessContext to use with the given DoFn.
processContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
processContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
processContext() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
ProcessContinuation() - Constructor for class org.apache.beam.sdk.transforms.DoFn.ProcessContinuation
 
processElement(InputT) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
processElement(String, DoFn.MultiOutputReceiver) - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError
 
processElement() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.ProcessElement method.
processElement(DoFn<ValueWithRecordId<T>, T>.ProcessContext) - Method in class org.apache.beam.sdk.values.ValueWithRecordId.StripIdsDoFn
 
ProcessElementMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
 
ProcessFunction<InputT,OutputT> - Interface in org.apache.beam.sdk.transforms
A function that computes an output value of type OutputT from an input value of type InputT and is Serializable.
ProcessingTimeEvent() - Constructor for class org.apache.beam.sdk.testing.TestStream.ProcessingTimeEvent
 
processTimestampedElement(TimestampedValue<InputT>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
processWindowedElement(InputT, Instant, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
Progress() - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.Progress
 
PROPERTY_BEAM_TEST_PIPELINE_OPTIONS - Static variable in class org.apache.beam.sdk.testing.TestPipeline
System property used to set TestPipelineOptions.
propertyName() - Method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
Returns the property name associated with this provider.
propertyName() - Method in class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
Returns the property name that corresponds to this provider.
Providers - Class in org.apache.beam.sdk.schemas.io
Helpers for implementing the "Provider" pattern.
Providers.Identifyable - Interface in org.apache.beam.sdk.schemas.io
 
pruningClass(Class<?>) - Method in class org.apache.beam.sdk.util.ApiSurface
Returns an ApiSurface like this one, but pruning references from the provided class.
pruningClassName(String) - Method in class org.apache.beam.sdk.util.ApiSurface
Returns an ApiSurface like this one, but pruning references from the named class.
pruningPattern(Pattern) - Method in class org.apache.beam.sdk.util.ApiSurface
Returns an ApiSurface like this one, but pruning transitive references from classes whose full name (including package) begins with the provided prefix.
pruningPattern(String) - Method in class org.apache.beam.sdk.util.ApiSurface
pruningPrefix(String) - Method in class org.apache.beam.sdk.util.ApiSurface
Returns an ApiSurface like this one, but pruning transitive references from classes whose full name (including package) begins with the provided prefix.
PTransform<InputT extends PInput,OutputT extends POutput> - Class in org.apache.beam.sdk.transforms
A PTransform<InputT, OutputT> is an operation that takes an InputT (some subtype of PInput) and produces an OutputT (some subtype of POutput).
PTransform() - Constructor for class org.apache.beam.sdk.transforms.PTransform
 
PTransform(String) - Constructor for class org.apache.beam.sdk.transforms.PTransform
 
PTransformMatcher - Interface in org.apache.beam.sdk.runners
For internal use only; no backwards-compatibility guarantees.
PTransformOverride - Class in org.apache.beam.sdk.runners
For internal use only; no backwards-compatibility guarantees.
PTransformOverride() - Constructor for class org.apache.beam.sdk.runners.PTransformOverride
 
PTransformOverrideFactory<InputT extends PInput,OutputT extends POutput,TransformT extends PTransform<? super InputT,OutputT>> - Interface in org.apache.beam.sdk.runners
For internal use only; no backwards-compatibility guarantees.
PTransformOverrideFactory.PTransformReplacement<InputT extends PInput,OutputT extends POutput> - Class in org.apache.beam.sdk.runners
A PTransform that replaces an AppliedPTransform, and the input required to do so.
PTransformOverrideFactory.ReplacementOutput - Class in org.apache.beam.sdk.runners
A mapping between original TaggedPValue outputs and their replacements.
PTransformReplacement() - Constructor for class org.apache.beam.sdk.runners.PTransformOverrideFactory.PTransformReplacement
 
pushNode(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.runners.TransformHierarchy
Adds the named PTransform consuming the provided PInput as a node in this TransformHierarchy as a child of the current node, and sets it to be the current node.
put(K2, V2) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
put(K, V) - Method in interface org.apache.beam.sdk.state.MapState
Associates the specified value with the specified key in this state.
putAll(Map<? extends K2, ? extends V2>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
putIfAbsent(K, V) - Method in interface org.apache.beam.sdk.state.MapState
A deferred read-followed-by-write.
PValue - Interface in org.apache.beam.sdk.values
For internal use.
PValueBase - Class in org.apache.beam.sdk.values
For internal use.
PValueBase(Pipeline) - Constructor for class org.apache.beam.sdk.values.PValueBase
 
PValueBase() - Constructor for class org.apache.beam.sdk.values.PValueBase
No-arg constructor to allow subclasses to implement Serializable.
PValues - Class in org.apache.beam.sdk.values
For internal use.

Q

qualifiedComponent() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
qualifiedComponent() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifyComponentContext
 
QualifiedComponentContext(ParserRuleContext, int) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
 
Qualifier() - Constructor for class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
 
qualifierList() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierListContext
 
qualifierList(int) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierListContext
 
qualifierList() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierListContext
 
qualifierList(int) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierListContext
 
qualifierList() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
 
qualifierList() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
QualifierListContext(ParserRuleContext, int) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifierListContext
 
QualifierListContext() - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifierListContext
 
QualifyComponentContext(FieldSpecifierNotationParser.DotExpressionComponentContext) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifyComponentContext
 
queryMetrics(MetricsFilter) - Method in class org.apache.beam.sdk.metrics.MetricResults
Query for all metric values that match a given filter.

R

range - Variable in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
 
RangeTracker<PositionT> - Interface in org.apache.beam.sdk.io.range
A RangeTracker is a thread-safe helper object for implementing dynamic work rebalancing in position-based BoundedSource.BoundedReader subclasses.
RawUnionValue - Class in org.apache.beam.sdk.transforms.join
This corresponds to an integer union tag and value.
RawUnionValue(int, Object) - Constructor for class org.apache.beam.sdk.transforms.join.RawUnionValue
Constructs a partial union from the given union tag and value.
read(Class<T>) - Static method in class org.apache.beam.sdk.io.AvroIO
Reads records of the given type from an Avro file (or multiple Avro files matching a pattern).
Read() - Constructor for class org.apache.beam.sdk.io.AvroIO.Read
 
Read - Class in org.apache.beam.sdk.io
A PTransform for reading from a Source.
Read() - Constructor for class org.apache.beam.sdk.io.Read
 
read() - Static method in class org.apache.beam.sdk.io.TextIO
A PTransform that reads from one or more text files and returns a bounded PCollection containing one element for each line of the input files.
Read() - Constructor for class org.apache.beam.sdk.io.TextIO.Read
 
read() - Static method in class org.apache.beam.sdk.io.TFRecordIO
A PTransform that reads from a TFRecord file (or multiple TFRecord files matching a pattern) and returns a PCollection containing the decoding of each of the records of the TFRecord file(s) as a byte array.
Read() - Constructor for class org.apache.beam.sdk.io.TFRecordIO.Read
 
read() - Method in interface org.apache.beam.sdk.state.BagState
 
read() - Method in interface org.apache.beam.sdk.state.CombiningState
 
read() - Method in interface org.apache.beam.sdk.state.ReadableState
Read the current value, blocking until it is available.
Read.Bounded<T> - Class in org.apache.beam.sdk.io
PTransform that reads from a BoundedSource.
Read.Builder - Class in org.apache.beam.sdk.io
Helper class for building Read transforms.
Read.Unbounded<T> - Class in org.apache.beam.sdk.io
PTransform that reads from a UnboundedSource.
ReadableFileCoder - Class in org.apache.beam.sdk.io
ReadableFileCoder() - Constructor for class org.apache.beam.sdk.io.ReadableFileCoder
 
ReadableState<T> - Interface in org.apache.beam.sdk.state
A State that can be read via ReadableState.read().
ReadableStates - Class in org.apache.beam.sdk.state
For internal use only; no backwards-compatibility guarantees.
ReadableStates() - Constructor for class org.apache.beam.sdk.state.ReadableStates
 
readAll(Class<T>) - Static method in class org.apache.beam.sdk.io.AvroIO
Deprecated.
You can achieve The functionality of AvroIO.readAll(java.lang.Class<T>) using FileIO matching plus AvroIO.readFiles(Class). This is the preferred method to make composition explicit. AvroIO.ReadAll will not receive upgrades and will be removed in a future version of Beam.
ReadAll() - Constructor for class org.apache.beam.sdk.io.AvroIO.ReadAll
Deprecated.
 
readAll() - Static method in class org.apache.beam.sdk.io.TextIO
Deprecated.
You can achieve The functionality of TextIO.readAll() using FileIO matching plus TextIO.readFiles(). This is the preferred method to make composition explicit. TextIO.ReadAll will not receive upgrades and will be removed in a future version of Beam.
ReadAll() - Constructor for class org.apache.beam.sdk.io.TextIO.ReadAll
Deprecated.
 
readAll() - Method in class org.apache.beam.sdk.util.ExposedByteArrayInputStream
Read all remaining bytes.
readAllGenericRecords(Schema) - Static method in class org.apache.beam.sdk.io.AvroIO
Deprecated.
You can achieve The functionality of AvroIO.readAllGenericRecords(Schema) using FileIO matching plus AvroIO.readFilesGenericRecords(Schema). This is the preferred method to make composition explicit. AvroIO.ReadAll will not receive upgrades and will be removed in a future version of Beam.
readAllGenericRecords(String) - Static method in class org.apache.beam.sdk.io.AvroIO
Deprecated.
You can achieve The functionality of AvroIO.readAllGenericRecords(String) using FileIO matching plus AvroIO.readFilesGenericRecords(String). This is the preferred method to make composition explicit. AvroIO.ReadAll will not receive upgrades and will be removed in a future version of Beam.
ReadAllViaFileBasedSource<T> - Class in org.apache.beam.sdk.io
Reads each file in the input PCollection of FileIO.ReadableFile using given parameters for splitting files into offset ranges and for creating a FileBasedSource for a file.
ReadAllViaFileBasedSource(long, SerializableFunction<String, ? extends FileBasedSource<T>>, Coder<T>) - Constructor for class org.apache.beam.sdk.io.ReadAllViaFileBasedSource
 
readDecompressed(ReadableByteChannel) - Method in enum org.apache.beam.sdk.io.Compression
 
Reader() - Constructor for class org.apache.beam.sdk.io.Source.Reader
 
readFiles(Class<T>) - Static method in class org.apache.beam.sdk.io.AvroIO
ReadFiles() - Constructor for class org.apache.beam.sdk.io.AvroIO.ReadFiles
 
readFiles() - Static method in class org.apache.beam.sdk.io.TextIO
Like TextIO.read(), but reads each file in a PCollection of FileIO.ReadableFile, returned by FileIO.readMatches().
ReadFiles() - Constructor for class org.apache.beam.sdk.io.TextIO.ReadFiles
 
readFiles() - Static method in class org.apache.beam.sdk.io.TFRecordIO
Like TFRecordIO.read(), but reads each file in a PCollection of FileIO.ReadableFile, returned by FileIO.readMatches().
ReadFiles() - Constructor for class org.apache.beam.sdk.io.TFRecordIO.ReadFiles
 
readFilesGenericRecords(Schema) - Static method in class org.apache.beam.sdk.io.AvroIO
readFilesGenericRecords(String) - Static method in class org.apache.beam.sdk.io.AvroIO
readFilesWithRetries(Sleeper, BackOff) - Method in class org.apache.beam.sdk.util.ExplicitShardedFile
Discovers all shards of this file using the provided Sleeper and BackOff.
readFilesWithRetries() - Method in class org.apache.beam.sdk.util.ExplicitShardedFile
Discovers all shards of this file.
readFilesWithRetries(Sleeper, BackOff) - Method in class org.apache.beam.sdk.util.FilePatternMatchingShardedFile
Discovers all shards of this file using the provided Sleeper and BackOff.
readFilesWithRetries() - Method in class org.apache.beam.sdk.util.FilePatternMatchingShardedFile
Discovers all shards of this file.
readFilesWithRetries(Sleeper, BackOff) - Method in class org.apache.beam.sdk.util.NumberedShardedFile
Discovers all shards of this file using the provided Sleeper and BackOff.
readFilesWithRetries() - Method in class org.apache.beam.sdk.util.NumberedShardedFile
Discovers all shards of this file.
readFilesWithRetries(Sleeper, BackOff) - Method in interface org.apache.beam.sdk.util.ShardedFile
Reads the lines from all shards of this file using the provided Sleeper and BackOff.
readFromSource(BoundedSource<T>, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
Reads all elements from the given BoundedSource.
readFromSplitsOfSource(BoundedSource<T>, long, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
 
readFromStartedReader(Source.Reader<T>) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
Reads all elements from the given started Source.Reader.
readFromUnstartedReader(Source.Reader<T>) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
Reads all elements from the given unstarted Source.Reader.
readFullyAsBytes() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
Returns the full contents of the file as bytes.
readFullyAsUTF8String() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
Returns the full contents of the file as a String decoded as UTF-8.
readGenericRecords(Schema) - Static method in class org.apache.beam.sdk.io.AvroIO
Reads Avro file(s) containing records of the specified schema.
readGenericRecords(String) - Static method in class org.apache.beam.sdk.io.AvroIO
Reads Avro file(s) containing records of the specified schema.
readLater() - Method in interface org.apache.beam.sdk.state.BagState
 
readLater() - Method in interface org.apache.beam.sdk.state.CombiningState
 
readLater() - Method in interface org.apache.beam.sdk.state.GroupingState
 
readLater() - Method in interface org.apache.beam.sdk.state.ReadableState
Indicate that the value will be read later.
readLater() - Method in interface org.apache.beam.sdk.state.SetState
 
readLater() - Method in interface org.apache.beam.sdk.state.ValueState
 
readLater() - Method in interface org.apache.beam.sdk.state.WatermarkHoldState
 
readMatches() - Static method in class org.apache.beam.sdk.io.FileIO
Converts each result of FileIO.match() or FileIO.matchAll() to a FileIO.ReadableFile which can be used to read the contents of each file, optionally decompressing it.
ReadMatches() - Constructor for class org.apache.beam.sdk.io.FileIO.ReadMatches
 
readNextBlock() - Method in class org.apache.beam.sdk.io.AvroSource.AvroReader
 
readNextBlock() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
Read the next block from the input.
readNextRecord() - Method in class org.apache.beam.sdk.io.BlockBasedSource.Block
Reads the next record from the block and returns true iff one exists.
readNextRecord() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
Reads the next record from the current block if possible.
readNextRecord() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
Reads the next record via the delegate reader.
readNextRecord() - Method in class org.apache.beam.sdk.io.FileBasedSource.FileBasedReader
readNItemsFromStartedReader(Source.Reader<T>, int) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
Read elements from a Source.Reader that has already had Source.Reader#start called on it, until n elements are read.
readNItemsFromUnstartedReader(Source.Reader<T>, int) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
Read elements from a Source.Reader until n elements are read.
readRange(Instant, Instant) - Method in interface org.apache.beam.sdk.state.OrderedListState
Read a timestamp-limited subrange of the list.
readRangeLater(Instant, Instant) - Method in interface org.apache.beam.sdk.state.OrderedListState
Call to indicate that a specific range will be read from the list, allowing runners to batch multiple range reads.
readRemainingFromReader(Source.Reader<T>, boolean) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
Read all remaining elements from a Source.Reader.
readValue - Variable in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
 
readValue - Variable in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
 
record(double...) - Method in class org.apache.beam.sdk.util.HistogramData
 
record(double) - Method in class org.apache.beam.sdk.util.HistogramData
 
referencesSingleField() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Returns true if this descriptor references only a single, non-wildcard field.
referent() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.StateParameter
 
referent() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.TimerFamilyParameter
 
referent() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.TimerParameter
 
ReflectHelpers - Class in org.apache.beam.sdk.util.common
Utilities for working with with Classes and Methods.
ReflectHelpers() - Constructor for class org.apache.beam.sdk.util.common.ReflectHelpers
 
ReflectHelpers.ObjectsClassComparator - Class in org.apache.beam.sdk.util.common
A Comparator that uses the object's class' canonical name to compare them.
ReflectUtils - Class in org.apache.beam.sdk.schemas.utils
A set of reflection helper methods.
ReflectUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.ReflectUtils
 
ReflectUtils.ClassWithSchema - Class in org.apache.beam.sdk.schemas.utils
Represents a class and a schema.
Regex - Class in org.apache.beam.sdk.transforms
PTransorms to use Regular Expressions to process elements in a PCollection.
Regex.AllMatches - Class in org.apache.beam.sdk.transforms
Regex.MatchesName<String> takes a PCollection<String> and returns a PCollection<List<String>> representing the value extracted from all the Regex groups of the input PCollection to the number of times that element occurs in the input.
Regex.Find - Class in org.apache.beam.sdk.transforms
Regex.Find<String> takes a PCollection<String> and returns a PCollection<String> representing the value extracted from the Regex groups of the input PCollection to the number of times that element occurs in the input.
Regex.FindAll - Class in org.apache.beam.sdk.transforms
Regex.Find<String> takes a PCollection<String> and returns a PCollection<List<String>> representing the value extracted from the Regex groups of the input PCollection to the number of times that element occurs in the input.
Regex.FindKV - Class in org.apache.beam.sdk.transforms
Regex.MatchesKV<KV<String, String>> takes a PCollection<String> and returns a PCollection<KV<String, String>> representing the key and value extracted from the Regex groups of the input PCollection to the number of times that element occurs in the input.
Regex.FindName - Class in org.apache.beam.sdk.transforms
Regex.Find<String> takes a PCollection<String> and returns a PCollection<String> representing the value extracted from the Regex groups of the input PCollection to the number of times that element occurs in the input.
Regex.FindNameKV - Class in org.apache.beam.sdk.transforms
Regex.MatchesKV<KV<String, String>> takes a PCollection<String> and returns a PCollection<KV<String, String>> representing the key and value extracted from the Regex groups of the input PCollection to the number of times that element occurs in the input.
Regex.Matches - Class in org.apache.beam.sdk.transforms
Regex.Matches<String> takes a PCollection<String> and returns a PCollection<String> representing the value extracted from the Regex groups of the input PCollection to the number of times that element occurs in the input.
Regex.MatchesKV - Class in org.apache.beam.sdk.transforms
Regex.MatchesKV<KV<String, String>> takes a PCollection<String> and returns a PCollection<KV<String, String>> representing the key and value extracted from the Regex groups of the input PCollection to the number of times that element occurs in the input.
Regex.MatchesName - Class in org.apache.beam.sdk.transforms
Regex.MatchesName<String> takes a PCollection<String> and returns a PCollection<String> representing the value extracted from the Regex groups of the input PCollection to the number of times that element occurs in the input.
Regex.MatchesNameKV - Class in org.apache.beam.sdk.transforms
Regex.MatchesNameKV<KV<String, String>> takes a PCollection<String> and returns a PCollection<KV<String, String>> representing the key and value extracted from the Regex groups of the input PCollection to the number of times that element occurs in the input.
Regex.ReplaceAll - Class in org.apache.beam.sdk.transforms
Regex.ReplaceAll<String> takes a PCollection<String> and returns a PCollection<String> with all Strings that matched the Regex being replaced with the replacement string.
Regex.ReplaceFirst - Class in org.apache.beam.sdk.transforms
Regex.ReplaceFirst<String> takes a PCollection<String> and returns a PCollection<String> with the first Strings that matched the Regex being replaced with the replacement string.
Regex.Split - Class in org.apache.beam.sdk.transforms
Regex.Split<String> takes a PCollection<String> and returns a PCollection<String> with the input string split into individual items in a list.
RegexMatcher - Class in org.apache.beam.sdk.testing
Hamcrest matcher to assert a string matches a pattern.
RegexMatcher(String) - Constructor for class org.apache.beam.sdk.testing.RegexMatcher
 
register(Class<? extends PipelineOptions>) - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
This registers the interface with this factory.
registerByteSizeObserver(T, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.Coder
Notifies the ElementByteSizeObserver about the byte size of the encoded value using this Coder.
registerByteSizeObserver(ReadableDuration, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.DurationCoder
 
registerByteSizeObserver(IterableT, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
 
registerByteSizeObserver(KV<K, V>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.KvCoder
Notifies ElementByteSizeObserver about the byte size of the encoded value using this coder.
registerByteSizeObserver(Map<K, V>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.MapCoder
 
registerByteSizeObserver(T, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.NullableCoder
Overridden to short-circuit the default StructuredCoder behavior of encoding and counting the bytes.
registerByteSizeObserver(RawUnionValue, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
Notifies ElementByteSizeObserver about the byte size of the encoded value using this coder.
registerByteSizeObserver(ShardedKey<K>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
 
registerByteSizeObserver(WindowedValue<T>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.util.WindowedValue.FullWindowedValueCoder
 
registerByteSizeObserver(WindowedValue<T>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
 
registerByteSizeObserver(WindowedValue<T>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.util.WindowedValue.ValueOnlyWindowedValueCoder
Deprecated.
 
registerCoderForClass(Class<?>, Coder<?>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
Registers the provided Coder for the given class.
registerCoderForType(TypeDescriptor<?>, Coder<?>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
Registers the provided Coder for the given type.
registerCoderProvider(CoderProvider) - Method in class org.apache.beam.sdk.coders.CoderRegistry
Registers coderProvider as a potential CoderProvider which can produce Coder instances.
registerJavaBean(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Register a JavaBean type for automatic schema inference.
registerJavaBean(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Register a JavaBean type for automatic schema inference.
registerPOJO(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Register a POJO type for automatic schema inference.
registerPOJO(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Register a POJO type for automatic schema inference.
registerSchemaForClass(Class<T>, Schema, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Register a schema for a specific Class type.
registerSchemaForType(TypeDescriptor<T>, Schema, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Register a schema for a specific TypeDescriptor type.
registerSchemaProvider(SchemaProvider) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Register a SchemaProvider.
registerSchemaProvider(Class<T>, SchemaProvider) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Register a SchemaProvider to be used for a specific type.
registerSchemaProvider(TypeDescriptor<T>, SchemaProvider) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
Register a SchemaProvider to be used for a specific type.
Reify - Class in org.apache.beam.sdk.transforms
PTransforms for converting between explicit and implicit form of various Beam values.
Reiterable<T> - Interface in org.apache.beam.sdk.util.common
An Iterable that returns Reiterator iterators.
Reiterator<T> - Interface in org.apache.beam.sdk.util.common
An Iterator with the ability to copy its iteration state.
relativeFileNaming(ValueProvider<String>, FileIO.Write.FileNaming) - Static method in class org.apache.beam.sdk.io.FileIO.Write
 
ReleaseInfo - Class in org.apache.beam.sdk.util
Properties pertaining to this release of Apache Beam.
ReleaseInfo() - Constructor for class org.apache.beam.sdk.util.ReleaseInfo
 
remerge() - Static method in class org.apache.beam.sdk.transforms.windowing.Window
Creates a Window PTransform that does not change assigned windows, but will cause windows to be merged again as part of the next GroupByKey.
RemoteEnvironmentOptions - Interface in org.apache.beam.sdk.options
Options that are used to control configuration of the remote environment.
RemoteEnvironmentOptions.Options - Class in org.apache.beam.sdk.options
remove(Object) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
remove(K) - Method in interface org.apache.beam.sdk.state.MapState
Remove the mapping for a key from this map if it is present.
remove(T) - Method in interface org.apache.beam.sdk.state.SetState
Removes the specified element from this set if it is present.
remove(long) - Method in class org.apache.beam.sdk.util.BucketingFunction
Remove one sample (from bucket) at timeMsSinceEpoch.
removeTemporaryFiles(Collection<ResourceId>) - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
 
rename(List<ClassLoaderFileSystem.ClassLoaderResourceId>, List<ClassLoaderFileSystem.ClassLoaderResourceId>) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
 
rename(List<ResourceIdT>, List<ResourceIdT>) - Method in class org.apache.beam.sdk.io.FileSystem
Renames a List of file-like resources from one location to another.
rename(List<ResourceId>, List<ResourceId>, MoveOptions...) - Static method in class org.apache.beam.sdk.io.FileSystems
Renames a List of file-like resources from one location to another.
rename(String, String) - Method in class org.apache.beam.sdk.schemas.transforms.RenameFields.Inner
Rename a specific field.
rename(FieldAccessDescriptor, String) - Method in class org.apache.beam.sdk.schemas.transforms.RenameFields.Inner
Rename a specific field.
RenameFields - Class in org.apache.beam.sdk.schemas.transforms
A transform for renaming fields inside an existing schema.
RenameFields() - Constructor for class org.apache.beam.sdk.schemas.transforms.RenameFields
 
RenameFields.Inner<T> - Class in org.apache.beam.sdk.schemas.transforms
The class implementing the actual PTransform.
Repeatedly - Class in org.apache.beam.sdk.transforms.windowing
A Trigger that fires according to its subtrigger forever.
replaceAll(List<PTransformOverride>) - Method in class org.apache.beam.sdk.Pipeline
For internal use only; no backwards-compatibility guarantees.
replaceAll(String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.ReplaceAll PTransform that checks if a portion of the line matches the Regex and replaces all matches with the replacement String.
replaceAll(Pattern, String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.ReplaceAll PTransform that checks if a portion of the line matches the Regex and replaces all matches with the replacement String.
ReplaceAll(Pattern, String) - Constructor for class org.apache.beam.sdk.transforms.Regex.ReplaceAll
 
replaceChild(TransformHierarchy.Node, TransformHierarchy.Node) - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
Replace a sub-node of this transform node.
replaceFirst(String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.ReplaceAll PTransform that checks if a portion of the line matches the Regex and replaces the first match with the replacement String.
replaceFirst(Pattern, String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.ReplaceAll PTransform that checks if a portion of the line matches the Regex and replaces the first match with the replacement String.
ReplaceFirst(Pattern, String) - Constructor for class org.apache.beam.sdk.transforms.Regex.ReplaceFirst
 
ReplacementOutput() - Constructor for class org.apache.beam.sdk.runners.PTransformOverrideFactory.ReplacementOutput
 
replaceNode(TransformHierarchy.Node, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.runners.TransformHierarchy
 
replaceOutputs(Map<PCollection<?>, PTransformOverrideFactory.ReplacementOutput>) - Method in class org.apache.beam.sdk.runners.TransformHierarchy
Recursively replace the outputs of the current TransformHierarchy.Node with the original outputs of the node it is replacing.
reportElementSize(long) - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
 
reportElementSize(long) - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObserver
Called to report element byte size.
REPORTING_LOCK - Static variable in interface org.apache.beam.sdk.metrics.MetricsLogger
 
Requirements - Class in org.apache.beam.sdk.transforms
Describes the run-time requirements of a Contextful, such as access to side inputs.
requiresDataSchema() - Method in class org.apache.beam.sdk.io.AvroSchemaIOProvider
 
requiresDataSchema() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIOProvider
Indicates whether the dataSchema value is necessary.
requiresDeduping() - Method in class org.apache.beam.sdk.io.UnboundedSource
Returns whether this source requires explicit deduping.
requiresSideInputs(Collection<PCollectionView<?>>) - Static method in class org.apache.beam.sdk.transforms.Requirements
Describes the need for access to the given side inputs.
requiresSideInputs(PCollectionView<?>...) - Static method in class org.apache.beam.sdk.transforms.Requirements
requiresStableInput() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerFamilyMethod
Whether this method requires stable input, expressed via DoFn.RequiresStableInput.
requiresStableInput() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerMethod
Whether this method requires stable input, expressed via DoFn.RequiresStableInput.
requiresStableInput() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnWindowExpirationMethod
Whether this method requires stable input, expressed via DoFn.RequiresStableInput.
requiresStableInput() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
Whether this method requires stable input, expressed via DoFn.RequiresStableInput.
requiresTimeSortedInput() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
Whether this method requires time sorted input, expressed via DoFn.RequiresTimeSortedInput.
requiresTimeSortedInput(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
reset() - Method in interface org.apache.beam.sdk.metrics.MetricsLogger
 
reset() - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
 
reset() - Method in interface org.apache.beam.sdk.util.BackOff
Reset to initial state.
reset() - Method in class org.apache.beam.sdk.util.ExposedByteArrayOutputStream
 
reset() - Method in class org.apache.beam.sdk.util.UnownedInputStream
 
resetCache() - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
Resets the set of interfaces registered with this factory to the default state.
Reshuffle<K,V> - Class in org.apache.beam.sdk.transforms
Deprecated.
this transform's intended side effects are not portable; it will likely be removed
Reshuffle.ViaRandomKey<T> - Class in org.apache.beam.sdk.transforms
Deprecated.
Implementation of Reshuffle.viaRandomKey().
ReshuffleTrigger<W extends BoundedWindow> - Class in org.apache.beam.sdk.transforms.windowing
Deprecated.
The intended side effect of Reshuffle is not portable; it will likely be removed
ReshuffleTrigger() - Constructor for class org.apache.beam.sdk.transforms.windowing.ReshuffleTrigger
Deprecated.
 
resolve(String, ResolveOptions) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderResourceId
 
resolve(String, ResolveOptions) - Method in interface org.apache.beam.sdk.io.fs.ResourceId
Returns a child ResourceId under this.
resolve(Schema) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Resolve the FieldAccessDescriptor against a schema.
ResolveOptions - Interface in org.apache.beam.sdk.io.fs
ResolveOptions.StandardResolveOptions - Enum in org.apache.beam.sdk.io.fs
Defines the standard resolve options.
resolveType(Type) - Method in class org.apache.beam.sdk.values.TypeDescriptor
Returns a TypeDescriptor representing the given type, with type variables resolved according to the specialization in this type.
resourceId() - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata
 
ResourceId - Interface in org.apache.beam.sdk.io.fs
An identifier which represents a file-like resource.
ResourceIdCoder - Class in org.apache.beam.sdk.io.fs
ResourceIdCoder() - Constructor for class org.apache.beam.sdk.io.fs.ResourceIdCoder
 
ResourceIdTester - Class in org.apache.beam.sdk.io.fs
A utility to test ResourceId implementations.
restriction() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
If this is a splittable DoFn, returns the associated restriction with the current call.
restriction() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
restriction() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
restrictionParameter(TypeDescriptor<?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
restrictionT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialRestrictionMethod
Type of the returned restriction.
restrictionT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.RestrictionParameter
 
restrictionTracker() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
If this is a splittable DoFn, returns the associated RestrictionTracker with the current call.
restrictionTracker() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
restrictionTracker() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
restrictionTracker(TypeDescriptor<?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
RestrictionTracker<RestrictionT,PositionT> - Class in org.apache.beam.sdk.transforms.splittabledofn
Manages access to the restriction and keeps track of its claimed part for a splittable DoFn.
RestrictionTracker() - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker
 
RestrictionTracker.HasProgress - Interface in org.apache.beam.sdk.transforms.splittabledofn
All RestrictionTrackers SHOULD implement this interface to improve auto-scaling and splitting performance.
RestrictionTracker.IsBounded - Enum in org.apache.beam.sdk.transforms.splittabledofn
 
RestrictionTracker.Progress - Class in org.apache.beam.sdk.transforms.splittabledofn
A representation for the amount of known completed and remaining work.
RestrictionTracker.TruncateResult<RestrictionT> - Class in org.apache.beam.sdk.transforms.splittabledofn
A representation of the truncate result.
Result() - Constructor for class org.apache.beam.sdk.schemas.transforms.CoGroup.Result
 
Result() - Constructor for class org.apache.beam.sdk.transforms.WithFailures.Result
 
result(T) - Static method in class org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult
 
resultBuilder() - Static method in class org.apache.beam.sdk.transforms.JsonToRow.ParseResult
 
resume() - Static method in class org.apache.beam.sdk.transforms.DoFn.ProcessContinuation
Indicates that there is more work to be done for the current element.
resumeDelay() - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContinuation
A minimum duration that should elapse between the end of this DoFn.ProcessElement call and the DoFn.ProcessElement call continuing processing of the same element.
Reversed() - Constructor for class org.apache.beam.sdk.transforms.Top.Reversed
 
RHS_TAG - Static variable in class org.apache.beam.sdk.schemas.transforms.Join
 
right(String...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual.Impl
 
right(Integer...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual.Impl
 
right(FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual.Impl
 
right(String...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual
 
right(Integer...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual
 
right(FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual
 
rightOuterJoin(PCollection<RhsT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Join
Perform a right outer join.
root() - Static method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
Path for display data registered by a top-level component.
row(Schema) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
Create a map type for the given key and value types.
Row - Class in org.apache.beam.sdk.values
Row is an immutable tuple-like schema to represent one element in a PCollection.
Row.Builder - Class in org.apache.beam.sdk.values
Builder for Row.
Row.Equals - Class in org.apache.beam.sdk.values
 
Row.FieldValueBuilder - Class in org.apache.beam.sdk.values
Builder for Row that bases a row on another row.
rowBag(Schema) - Static method in class org.apache.beam.sdk.state.StateSpecs
Create a StateSpec for a BagState, optimized for adding values frequently and occasionally retrieving all the values that have been added.
RowCoder - Class in org.apache.beam.sdk.coders
A sub-class of SchemaCoder that can only encode Row instances.
RowCoderGenerator - Class in org.apache.beam.sdk.coders
A utility for automatically generating a Coder for Row objects corresponding to a specific schema.
RowCoderGenerator() - Constructor for class org.apache.beam.sdk.coders.RowCoderGenerator
 
rowFromProto(SchemaApi.Row, Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.SchemaTranslation
 
RowJson - Class in org.apache.beam.sdk.util
Jackson serializer and deserializer for Rows.
RowJson() - Constructor for class org.apache.beam.sdk.util.RowJson
 
RowJson.RowJsonDeserializer - Class in org.apache.beam.sdk.util
Jackson deserializer for parsing JSON into Rows.
RowJson.RowJsonDeserializer.NullBehavior - Enum in org.apache.beam.sdk.util
An enumeration type for specifying how RowJson.RowJsonDeserializer should expect null values to be represented.
RowJson.RowJsonSerializer - Class in org.apache.beam.sdk.util
Jackson serializer for converting Rows to JSON.
RowJson.UnsupportedRowJsonException - Exception in org.apache.beam.sdk.util
Gets thrown when Row parsing or serialization fails for any reason.
RowJsonUtils - Class in org.apache.beam.sdk.util
RowJsonUtils() - Constructor for class org.apache.beam.sdk.util.RowJsonUtils
 
rowMap(Schema, Schema) - Static method in class org.apache.beam.sdk.state.StateSpecs
Create a StateSpec for a SetState, optimized for key lookups and writes.
RowMessages - Class in org.apache.beam.sdk.schemas
 
rowOrderedList(Schema) - Static method in class org.apache.beam.sdk.state.StateSpecs
 
rowReceiver(DoFn<?, ?>.WindowedContext, TupleTag<T>, SchemaCoder<T>) - Static method in class org.apache.beam.sdk.transforms.DoFnOutputReceivers
Returns a DoFn.OutputReceiver that automatically converts a Row to the user's output type and delegates to WindowedContextOutputReceiver.
rows() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
RowSelector - Interface in org.apache.beam.sdk.schemas.utils
A selector interface for extracting fields from a row.
RowSelectorContainer(Schema, FieldAccessDescriptor, boolean) - Constructor for class org.apache.beam.sdk.schemas.utils.SelectHelpers.RowSelectorContainer
 
rowSet(Schema) - Static method in class org.apache.beam.sdk.state.StateSpecs
Create a StateSpec for a SetState, optimized for checking membership.
rowToBytesFn(SchemaProvider, TypeDescriptor<T>, ProcessFunction<? super T, byte[]>) - Static method in class org.apache.beam.sdk.schemas.RowMessages
 
rowToBytesFn(SchemaProvider, TypeDescriptor<T>, Coder<? super T>) - Static method in class org.apache.beam.sdk.schemas.RowMessages
 
rowToJson(ObjectMapper, Row) - Static method in class org.apache.beam.sdk.util.RowJsonUtils
 
rowToProto(Row) - Static method in class org.apache.beam.sdk.schemas.SchemaTranslation
 
rowValue(Schema) - Static method in class org.apache.beam.sdk.state.StateSpecs
Create a StateSpec for a row value with the specified schema.
RowWithGetters - Class in org.apache.beam.sdk.values
A Concrete subclass of Row that delegates to a set of provided FieldValueGetters.
RowWithStorage - Class in org.apache.beam.sdk.values
Concrete subclass of Row that explicitly stores all fields of the row.
RULE_arrayQualifier - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
RULE_dotExpression - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
RULE_dotExpressionComponent - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
RULE_fieldSpecifier - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
RULE_mapQualifier - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
RULE_qualifiedComponent - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
RULE_qualifierList - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
ruleNames - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
ruleNames - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
run() - Method in interface org.apache.beam.sdk.function.ThrowingRunnable
 
run() - Method in class org.apache.beam.sdk.Pipeline
Runs this Pipeline according to the PipelineOptions used to create the Pipeline via Pipeline.create(PipelineOptions).
run(PipelineOptions) - Method in class org.apache.beam.sdk.Pipeline
Runs this Pipeline using the given PipelineOptions, using the runner specified by the options.
run(Pipeline) - Method in class org.apache.beam.sdk.PipelineRunner
Processes the given Pipeline, potentially asynchronously, returning a runner-specific type of result.
run(PTransform<PBegin, ?>, PipelineOptions) - Method in class org.apache.beam.sdk.PipelineRunner
Creates a Pipeline out of a single PTransform step, and executes it.
run(PTransform<PBegin, ?>) - Method in class org.apache.beam.sdk.PipelineRunner
Overloaded PTransform runner that runs with the default app PipelineOptions.
run(Pipeline) - Method in class org.apache.beam.sdk.testing.CrashingRunner
 
run() - Method in class org.apache.beam.sdk.testing.TestPipeline
Runs this TestPipeline, unwrapping any AssertionError that is raised during testing.
run(PipelineOptions) - Method in class org.apache.beam.sdk.testing.TestPipeline
Like TestPipeline.run() but with the given potentially modified options.
run() - Method in interface org.apache.beam.sdk.util.ThrowingRunnable
 
runAsync(ThrowingRunnable, ExecutorService) - Static method in class org.apache.beam.sdk.util.MoreFutures
Like CompletableFuture.runAsync(java.lang.Runnable) but for ThrowingRunnable.
runAsync(ThrowingRunnable) - Static method in class org.apache.beam.sdk.util.MoreFutures
Shorthand for MoreFutures.runAsync(ThrowingRunnable, ExecutorService) using ForkJoinPool.commonPool().
runResourceIdBattery(ResourceId) - Static method in class org.apache.beam.sdk.io.fs.ResourceIdTester
Enforces that the ResourceId implementation of baseDirectory meets the ResourceId spec.
runWindowFn(WindowFn<T, W>, List<Long>) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
Runs the WindowFn over the provided input, returning a map of windows to the timestamps in those windows.
runWindowFnWithValue(WindowFn<T, W>, List<TimestampedValue<T>>) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
Runs the WindowFn over the provided input, returning a map of windows to the timestamps in those windows.
runWithAdditionalOptionArgs(List<String>) - Method in class org.apache.beam.sdk.testing.TestPipeline
Runs this TestPipeline with additional cmd pipeline option args.

S

Sample - Class in org.apache.beam.sdk.transforms
PTransforms for taking samples of the elements in a PCollection, or samples of the values associated with each key in a PCollection of KVs.
Sample() - Constructor for class org.apache.beam.sdk.transforms.Sample
 
Sample.FixedSizedSampleFn<T> - Class in org.apache.beam.sdk.transforms
CombineFn that computes a fixed-size sample of a collection of values.
SampleAllFiles() - Constructor for class org.apache.beam.sdk.io.TextRowCountEstimator.SampleAllFiles
 
satisfies(SerializableFunction<Iterable<T>, Void>) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
Applies the provided checking function (presumably containing assertions) to the iterable in question.
satisfies(SerializableFunction<Iterable<T>, Void>) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
 
satisfies(SerializableFunction<T, Void>) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
Applies the provided checking function (presumably containing assertions) to the value in question.
SCHEMA - Static variable in class org.apache.beam.sdk.io.ClassLoaderFileSystem
 
schema() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIO
Returns the schema of the data.
Schema - Class in org.apache.beam.sdk.schemas
Schema describes the fields in Row.
Schema(List<Schema.Field>) - Constructor for class org.apache.beam.sdk.schemas.Schema
 
Schema(List<Schema.Field>, Schema.Options) - Constructor for class org.apache.beam.sdk.schemas.Schema
 
schema - Variable in class org.apache.beam.sdk.schemas.SchemaCoder
 
Schema.Builder - Class in org.apache.beam.sdk.schemas
Builder class for building Schema objects.
Schema.EquivalenceNullablePolicy - Enum in org.apache.beam.sdk.schemas
Control whether nullable is included in equivalence check.
Schema.Field - Class in org.apache.beam.sdk.schemas
Field of a row.
Schema.Field.Builder - Class in org.apache.beam.sdk.schemas
Builder for Schema.Field.
Schema.FieldType - Class in org.apache.beam.sdk.schemas
A descriptor of a single field type.
Schema.LogicalType<InputT,BaseT> - Interface in org.apache.beam.sdk.schemas
A LogicalType allows users to define a custom schema type.
Schema.Options - Class in org.apache.beam.sdk.schemas
 
Schema.Options.Builder - Class in org.apache.beam.sdk.schemas
 
Schema.TypeName - Enum in org.apache.beam.sdk.schemas
An enumerated list of type constructors.
SchemaCaseFormat - Annotation Type in org.apache.beam.sdk.schemas.annotations
When used on a POJO, Java Bean, or AutoValue class the specified case format will be used for all the generated Schema fields.
SchemaCoder<T> - Class in org.apache.beam.sdk.schemas
SchemaCoder is used as the coder for types that have schemas registered.
SchemaCoder(Schema, TypeDescriptor<T>, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Constructor for class org.apache.beam.sdk.schemas.SchemaCoder
 
schemaCoder(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Returns an SchemaCoder instance for the provided element type.
schemaCoder(Class<T>) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Returns an SchemaCoder instance for the provided element class.
schemaCoder(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Returns an SchemaCoder instance for the Avro schema.
schemaCoder(Class<T>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Returns an SchemaCoder instance for the provided element type using the provided Avro schema.
schemaCoder(AvroCoder<T>) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Returns an SchemaCoder instance based on the provided AvroCoder for the element type.
SchemaCreate - Annotation Type in org.apache.beam.sdk.schemas.annotations
Can be put on a constructor or a static method, in which case that constructor or method will be used to created instance of the class by Beam's schema code.
schemaElement(int) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provide a reference to the selected schema field corresponding to the input argument specified by index.
schemaElement(int) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
schemaElement(int) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
schemaElementParameter(TypeDescriptor<?>, String, int) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
 
SchemaFieldName - Annotation Type in org.apache.beam.sdk.schemas.annotations
When used on a POJO field, a Java Bean getter, or an AutoValue getter, the specified name is used for the generated schema field.
schemaFor(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProvider
 
schemaFor(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.AutoValueSchema
 
schemaFor(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.AvroRecordSchema
 
schemaFor(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema
 
schemaFor(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.JavaFieldSchema
 
schemaFor(TypeDescriptor<T>) - Method in interface org.apache.beam.sdk.schemas.SchemaProvider
Lookup a schema for the given type.
schemaFromClass(Class<?>, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.StaticSchemaInference
Infer a schema from a Java class.
schemaFromJavaBeanClass(Class<?>, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
Create a Schema for a Java Bean class.
schemaFromPojoClass(Class<?>, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
 
schemaFromProto(SchemaApi.Schema) - Static method in class org.apache.beam.sdk.schemas.SchemaTranslation
 
SchemaIgnore - Annotation Type in org.apache.beam.sdk.schemas.annotations
When used on a POJO field or a JavaBean getter, that field or getter is ignored from the inferred schema.
SchemaIO - Interface in org.apache.beam.sdk.schemas.io
An abstraction to create schema capable and aware IOs.
SchemaIOProvider - Interface in org.apache.beam.sdk.schemas.io
Provider to create SchemaIO instances for use in Beam SQL and other SDKs.
SchemaProvider - Interface in org.apache.beam.sdk.schemas
Concrete implementations of this class allow creation of schema service objects that vend a Schema for a specific type.
SchemaProviderRegistrar - Interface in org.apache.beam.sdk.schemas
SchemaProvider creators have the ability to automatically have their schemaProvider registered with this SDK by creating a ServiceLoader entry and a concrete implementation of this interface.
SchemaRegistry - Class in org.apache.beam.sdk.schemas
A SchemaRegistry allows registering Schemas for a given Java Class or a TypeDescriptor.
schemaToProto(Schema, boolean) - Static method in class org.apache.beam.sdk.schemas.SchemaTranslation
 
SchemaTranslation - Class in org.apache.beam.sdk.schemas
Utility methods for translating schemas.
SchemaTranslation() - Constructor for class org.apache.beam.sdk.schemas.SchemaTranslation
 
schemaTypeCreator(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.AutoValueSchema
 
schemaTypeCreator(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.AvroRecordSchema
 
schemaTypeCreator(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
Implementing class should override to return a constructor.
schemaTypeCreator(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema
 
schemaTypeCreator(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.JavaFieldSchema
 
SchemaUserTypeCreator - Interface in org.apache.beam.sdk.schemas
A creator interface for user types that have schemas.
SchemaUtils - Class in org.apache.beam.sdk.schemas
A set of utility functions for schemas.
SchemaUtils() - Constructor for class org.apache.beam.sdk.schemas.SchemaUtils
 
SchemaVerification - Class in org.apache.beam.sdk.values
 
SchemaVerification() - Constructor for class org.apache.beam.sdk.values.SchemaVerification
 
SchemaZipFold<T> - Class in org.apache.beam.sdk.schemas.utils
Visitor that zips schemas, and accepts pairs of fields and their types.
SchemaZipFold() - Constructor for class org.apache.beam.sdk.schemas.utils.SchemaZipFold
 
SchemaZipFold.Context - Class in org.apache.beam.sdk.schemas.utils
Context referring to a current position in a schema.
scopedMetricsContainer(MetricsContainer) - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
Set the MetricsContainer for the current thread.
SdkHarnessLogLevelOverrides() - Constructor for class org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides
 
SdkHarnessOptions - Interface in org.apache.beam.sdk.options
Options that are used to control configuration of the SDK harness.
SdkHarnessOptions.LogLevel - Enum in org.apache.beam.sdk.options
The set of log levels that can be used in the SDK harness.
SdkHarnessOptions.SdkHarnessLogLevelOverrides - Class in org.apache.beam.sdk.options
Defines a log level override for a specific class, package, or name.
Select - Class in org.apache.beam.sdk.schemas.transforms
A PTransform for selecting a subset of fields from a schema type.
Select() - Constructor for class org.apache.beam.sdk.schemas.transforms.Select
 
select(Row) - Method in interface org.apache.beam.sdk.schemas.utils.RowSelector
 
select(Row) - Method in class org.apache.beam.sdk.schemas.utils.SelectHelpers.RowSelectorContainer
 
Select.Fields<T> - Class in org.apache.beam.sdk.schemas.transforms
 
Select.Flattened<T> - Class in org.apache.beam.sdk.schemas.transforms
A PTransform representing a flattened schema.
SelectHelpers - Class in org.apache.beam.sdk.schemas.utils
Helper methods to select subrows out of rows.
SelectHelpers() - Constructor for class org.apache.beam.sdk.schemas.utils.SelectHelpers
 
SelectHelpers.RowSelectorContainer - Class in org.apache.beam.sdk.schemas.utils
 
SequenceDefinition() - Constructor for class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
 
SequenceDefinition(Instant, Instant, Duration) - Constructor for class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
 
SerializableBiConsumer<FirstInputT,SecondInputT> - Interface in org.apache.beam.sdk.transforms
A union of the BiConsumer and Serializable interfaces.
SerializableBiFunction<FirstInputT,SecondInputT,OutputT> - Interface in org.apache.beam.sdk.transforms
A union of the BiFunction and Serializable interfaces.
SerializableCoder<T extends java.io.Serializable> - Class in org.apache.beam.sdk.coders
A Coder for Java classes that implement Serializable.
SerializableCoder(Class<T>, TypeDescriptor<T>) - Constructor for class org.apache.beam.sdk.coders.SerializableCoder
 
SerializableCoder.SerializableCoderProviderRegistrar - Class in org.apache.beam.sdk.coders
A CoderProviderRegistrar which registers a CoderProvider which can handle serializable types.
SerializableCoderProviderRegistrar() - Constructor for class org.apache.beam.sdk.coders.SerializableCoder.SerializableCoderProviderRegistrar
 
SerializableComparator<T> - Interface in org.apache.beam.sdk.transforms
A Comparator that is also Serializable.
SerializableFunction<InputT,OutputT> - Interface in org.apache.beam.sdk.transforms
A function that computes an output value of type OutputT from an input value of type InputT, is Serializable, and does not allow checked exceptions to be declared.
SerializableFunctions - Class in org.apache.beam.sdk.transforms
Useful SerializableFunction overrides.
SerializableFunctions() - Constructor for class org.apache.beam.sdk.transforms.SerializableFunctions
 
SerializableMatcher<T> - Interface in org.apache.beam.sdk.testing
A Matcher that is also Serializable.
SerializableMatchers - Class in org.apache.beam.sdk.testing
Static class for building and using SerializableMatcher instances.
SerializableMatchers.SerializableSupplier<T> - Interface in org.apache.beam.sdk.testing
Supplies values of type T, and is serializable.
SerializableThrowable - Class in org.apache.beam.sdk.util
A wrapper around Throwable that preserves the stack trace on serialization, unlike regular Throwable.
SerializableThrowable(Throwable) - Constructor for class org.apache.beam.sdk.util.SerializableThrowable
 
SerializableUtils - Class in org.apache.beam.sdk.util
Utilities for working with Serializables.
SerializableUtils() - Constructor for class org.apache.beam.sdk.util.SerializableUtils
 
serialize(ValueProvider<?>, JsonGenerator, SerializerProvider) - Method in class org.apache.beam.sdk.options.ValueProvider.Serializer
 
serialize(Row) - Method in interface org.apache.beam.sdk.schemas.io.payloads.PayloadSerializer
 
serialize(Row, JsonGenerator, SerializerProvider) - Method in class org.apache.beam.sdk.util.RowJson.RowJsonSerializer
 
Serializer() - Constructor for class org.apache.beam.sdk.options.ValueProvider.Serializer
 
serializeToByteArray(Serializable) - Static method in class org.apache.beam.sdk.util.SerializableUtils
Serializes the argument into an array of bytes, and returns it.
serialVersionUID - Static variable in interface org.apache.beam.sdk.schemas.io.payloads.PayloadSerializer
 
Sessions - Class in org.apache.beam.sdk.transforms.windowing
A WindowFn that windows values into sessions separated by periods with no input for at least the duration specified by Sessions.getGapDuration().
set(long) - Method in interface org.apache.beam.sdk.metrics.Gauge
Set current value for this gauge.
set(ObjectT, ValueT) - Method in interface org.apache.beam.sdk.schemas.FieldValueSetter
Sets the specified field on object to value.
set() - Static method in class org.apache.beam.sdk.state.StateSpecs
Create a StateSpec for a SetState, optimized for checking membership.
set(Coder<T>) - Static method in class org.apache.beam.sdk.state.StateSpecs
Identical to StateSpecs.set(), but with an element coder explicitly supplied.
set(Instant) - Method in interface org.apache.beam.sdk.state.Timer
Sets or resets the time in the timer's TimeDomain at which it should fire.
set(String, Instant) - Method in interface org.apache.beam.sdk.state.TimerMap
 
set(long...) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
setAppName(String) - Method in interface org.apache.beam.sdk.options.ApplicationNameOptions
 
setBlockOnRun(boolean) - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
 
setChecksum(String) - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
 
setCloningBehavior(DoFnTester.CloningBehavior) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
SetCoder<T> - Class in org.apache.beam.sdk.coders
A SetCoder encodes any Set using the format of IterableLikeCoder.
SetCoder(Coder<T>) - Constructor for class org.apache.beam.sdk.coders.SetCoder
 
setCoder(Coder<T>) - Method in class org.apache.beam.sdk.values.PCollection
Sets the Coder used by this PCollection to encode and decode the values stored in it.
setCoderRegistry(CoderRegistry) - Method in class org.apache.beam.sdk.Pipeline
Deprecated.
this should never be used - every Pipeline has a registry throughout its lifetime.
setCompression(Compression) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
 
setCurrentContainer(MetricsContainer) - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
Set the MetricsContainer for the current thread.
setDefaultEnvironmentConfig(String) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
setDefaultEnvironmentType(String) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
setDefaultPipelineOptions(PipelineOptions) - Static method in class org.apache.beam.sdk.io.FileSystems
Sets the default configuration in workers.
setDefaultSdkHarnessLogLevel(SdkHarnessOptions.LogLevel) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
 
setDelimiters(byte[]) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
 
setDescription(String) - Method in class org.apache.beam.sdk.schemas.Schema.Field.Builder
 
setDirectoryTreatment(FileIO.ReadMatches.DirectoryTreatment) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
 
setElementsPerPeriod(Long) - Method in class org.apache.beam.sdk.io.GenerateSequence.External.ExternalConfiguration
 
setElementT(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter.Builder
 
setElementT(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SideInputParameter.Builder
 
setElementType(FieldValueTypeInformation) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
 
setEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
 
setEncodingPositions(Map<String, Integer>) - Method in class org.apache.beam.sdk.schemas.Schema
Sets the encoding positions for this schema.
setEnvironmentCacheMillis(int) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
setEnvironmentExpirationMillis(int) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
setEnvironmentOptions(List<String>) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
setError(String) - Method in class org.apache.beam.sdk.schemas.io.Failure.Builder
 
setErrorField(String) - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
Adds the error message to the returned error Row.
setExperiments(List<String>) - Method in interface org.apache.beam.sdk.options.ExperimentalOptions
 
setField(Field) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
 
setFieldAccessString(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter.Builder
 
setFieldId(Integer) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Builder
 
setFieldName(String) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Builder
 
setFieldRename(String) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Builder
 
setFilePattern(String) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
 
setFilesToStage(List<String>) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
setGroupingTableMaxSizeMb(int) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
 
setIndex(int) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter.Builder
 
setIsBoundedInternal(PCollection.IsBounded) - Method in class org.apache.beam.sdk.values.PCollection
For internal use only; no backwards-compatibility guarantees.
setIsReadSeekEfficient(boolean) - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
 
setJobEndpoint(String) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
setJobName(String) - Method in interface org.apache.beam.sdk.options.PipelineOptions
 
setJsonToRowWithErrFn(JsonToRow.JsonToRowWithErrFn) - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError.Builder
 
setLastModifiedMillis(long) - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
 
setLazy() - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObserver
Sets byte counting for the current element as lazy.
setLineField(String) - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
Sets the field name for the line field in the returned Row.
setLoadBalanceBundles(boolean) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
setMapKeyType(FieldValueTypeInformation) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
 
setMapValueType(FieldValueTypeInformation) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
 
setMaxReadTime(Long) - Method in class org.apache.beam.sdk.io.GenerateSequence.External.ExternalConfiguration
 
setMethod(Method) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
 
setMetricsGraphiteHost(String) - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
 
setMetricsGraphitePort(Integer) - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
 
setMetricsHttpSinkUrl(String) - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
 
setMetricsPushPeriod(Long) - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
 
setMetricsSink(Class<? extends MetricsSink>) - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
 
setMetricsSupported(boolean) - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
Called by the run to indicate whether metrics reporting is supported.
setMimeType(String) - Method in class org.apache.beam.sdk.io.fs.CreateOptions.Builder
 
setName(String) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
 
setName(String) - Method in class org.apache.beam.sdk.schemas.Schema.Field.Builder
 
setName(String) - Method in class org.apache.beam.sdk.values.PCollection
Sets the name of this PCollection.
setName(String) - Method in class org.apache.beam.sdk.values.PValueBase
Sets the name of this PValueBase.
setNullable(boolean) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
 
setNumSampledBytesPerFile(long) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
 
setOnCreateMatcher(SerializableMatcher<PipelineResult>) - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
 
setOneOfTypes(Map<String, FieldValueTypeInformation>) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
 
setOnSuccessMatcher(SerializableMatcher<PipelineResult>) - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
 
setOption(String, Row) - Method in class org.apache.beam.sdk.schemas.Schema.Options.Builder
 
setOption(String, Schema.FieldType, Object) - Method in class org.apache.beam.sdk.schemas.Schema.Options.Builder
 
setOption(String, Schema.FieldType, Object) - Static method in class org.apache.beam.sdk.schemas.Schema.Options
 
setOption(String, Row) - Static method in class org.apache.beam.sdk.schemas.Schema.Options
 
setOptions(Schema.Options) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
Returns a copy of the Field with isNullable set.
setOptions(Schema.Options.Builder) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
 
setOptions(Schema.Options) - Method in class org.apache.beam.sdk.schemas.Schema.Field.Builder
 
setOptions(Schema.Options.Builder) - Method in class org.apache.beam.sdk.schemas.Schema.Field.Builder
 
setOptionsId(long) - Method in interface org.apache.beam.sdk.options.PipelineOptions
 
setOutput(POutput) - Method in class org.apache.beam.sdk.runners.TransformHierarchy
Set the output of the current TransformHierarchy.Node.
setOutputExecutablePath(String) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
setPayload(byte[]) - Method in class org.apache.beam.sdk.schemas.io.Failure.Builder
 
setPeriod(Long) - Method in class org.apache.beam.sdk.io.GenerateSequence.External.ExternalConfiguration
 
setProcessWideContainer(MetricsContainer) - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
Set the MetricsContainer for the current process.
setProviderRuntimeValues(ValueProvider<Map<String, Object>>) - Method in interface org.apache.beam.sdk.testing.TestPipeline.TestValueProviderOptions
 
setQualifiers(List<FieldAccessDescriptor.FieldDescriptor.Qualifier>) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Builder
 
setRawType(Class) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
 
setRelative() - Method in interface org.apache.beam.sdk.state.Timer
Sets the timer relative to the current time, according to any offset and alignment specified.
setResourceId(ResourceId) - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
 
setRetainDockerContainers(boolean) - Method in interface org.apache.beam.sdk.options.ManualDockerEnvironmentOptions
 
setRowSchema(Schema) - Method in class org.apache.beam.sdk.values.PCollection
Sets a schema on this PCollection.
setRunner(Class<? extends PipelineRunner<?>>) - Method in interface org.apache.beam.sdk.options.PipelineOptions
 
Sets - Class in org.apache.beam.sdk.transforms
The PTransforms that allow to compute different set functions across PCollections.
Sets() - Constructor for class org.apache.beam.sdk.transforms.Sets
 
sets(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for Set.
setSamplingStrategy(TextRowCountEstimator.SamplingStrategy) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
 
setScalingFactor(double) - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObserver
Sets a multiplier to use on observed sizes.
setSchema(Schema, TypeDescriptor<T>, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Method in class org.apache.beam.sdk.values.PCollection
Sets a Schema on this PCollection.
setSdkHarnessLogLevelOverrides(SdkHarnessOptions.SdkHarnessLogLevelOverrides) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
 
setSdkWorkerParallelism(int) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
 
setSemiPersistDir(String) - Method in interface org.apache.beam.sdk.options.RemoteEnvironmentOptions
 
setSideInput(PCollectionView<T>, BoundedWindow, T) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
setSideInputId(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SideInputParameter.Builder
 
setSideInputs(Map<PCollectionView<?>, Map<BoundedWindow, ?>>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
setSizeBytes(long) - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
 
setStableUniqueNames(PipelineOptions.CheckEnabled) - Method in interface org.apache.beam.sdk.options.PipelineOptions
 
setStart(Long) - Method in class org.apache.beam.sdk.io.GenerateSequence.External.ExternalConfiguration
 
SetState<T> - Interface in org.apache.beam.sdk.state
A ReadableState cell containing a set of elements.
setStop(Long) - Method in class org.apache.beam.sdk.io.GenerateSequence.External.ExternalConfiguration
 
setStreaming(boolean) - Method in interface org.apache.beam.sdk.options.StreamingOptions
 
setTempLocation(String) - Method in interface org.apache.beam.sdk.options.PipelineOptions
 
setTempRoot(String) - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
 
SetterTypeSupplier() - Constructor for class org.apache.beam.sdk.schemas.JavaBeanSchema.SetterTypeSupplier
 
setTestTimeoutSeconds(Long) - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
 
setTimer(Instant, TimeDomain) - Method in interface org.apache.beam.sdk.state.Timers
Sets a timer to fire when the event time watermark, the current processing time, or the synchronized processing time watermark surpasses a given timestamp.
setTimer(Instant, Instant, TimeDomain) - Method in interface org.apache.beam.sdk.state.Timers
Set a timer with outputTimestamp.
setType(TypeDescriptor) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
 
setType(Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Field.Builder
 
setTypeDescriptor(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.values.PCollection
setup() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.Setup method.
setUserAgent(String) - Method in interface org.apache.beam.sdk.options.PipelineOptions
 
setUUID(UUID) - Method in class org.apache.beam.sdk.schemas.Schema
Set this schema's UUID.
setWatermark(Instant) - Method in interface org.apache.beam.sdk.transforms.splittabledofn.ManualWatermarkEstimator
Sets a timestamp before or at the timestamps of all future elements produced by the associated DoFn.
setWatermark(Instant) - Method in class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.Manual
 
setWindowedWrites(boolean) - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
Indicates that the operation will be performing windowed writes.
setWindowingStrategyInternal(WindowingStrategy<?, ?>) - Method in class org.apache.beam.sdk.values.PCollection
For internal use only; no backwards-compatibility guarantees.
ShardedFile - Interface in org.apache.beam.sdk.util
Bare-bones class for using sharded files.
ShardedKey<K> - Class in org.apache.beam.sdk.util
A sharded key consisting of a user key and an opaque shard id represented by bytes.
ShardedKey(K, byte[]) - Constructor for class org.apache.beam.sdk.util.ShardedKey
 
ShardedKey<K> - Class in org.apache.beam.sdk.values
A key and a shard number.
ShardedKey.Coder<K> - Class in org.apache.beam.sdk.util
 
ShardedKeyCoder<KeyT> - Class in org.apache.beam.sdk.coders
A Coder for ShardedKey, using a wrapped key Coder.
ShardedKeyCoder(Coder<KeyT>) - Constructor for class org.apache.beam.sdk.coders.ShardedKeyCoder
 
ShardingFunction<UserT,DestinationT> - Interface in org.apache.beam.sdk.io
Function for assigning ShardedKeys to input elements for sharded WriteFiles.
ShardingWritableByteChannel - Class in org.apache.beam.sdk.util
Implements a WritableByteChannel that may contain multiple output shards.
ShardingWritableByteChannel() - Constructor for class org.apache.beam.sdk.util.ShardingWritableByteChannel
 
ShardNameTemplate - Class in org.apache.beam.sdk.io
Standard shard naming templates.
ShardNameTemplate() - Constructor for class org.apache.beam.sdk.io.ShardNameTemplate
 
shorts() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for Short.
shouldResume() - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContinuation
If false, the DoFn promises that there is no more work remaining for the current element, so the runner should not resume the DoFn.ProcessElement call.
sideInput(PCollectionView<SideInputT>) - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
Returns the value of a given side input.
sideInput(PCollectionView<T>) - Method in interface org.apache.beam.sdk.state.StateContext
Returns the value of the side input for the corresponding state window.
sideInput(PCollectionView<T>) - Method in class org.apache.beam.sdk.transforms.CombineWithContext.Context
Returns the value of the side input for the window corresponding to the main input's window in which values are being combined.
sideInput(PCollectionView<T>) - Method in class org.apache.beam.sdk.transforms.Contextful.Fn.Context
Accesses the given side input.
sideInput(PCollectionView<T>) - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContext
Returns the value of the side input.
sideInput(String) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provide a reference to the input sideInput with the specified tag.
sideInput(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
sideInput(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
sideInputId() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SideInputParameter
 
sideInputParameter(TypeDescriptor<?>, String) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
 
signatureForDoFn(FnT) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
SimpleCombineFn(SerializableFunction<Iterable<V>, V>) - Constructor for class org.apache.beam.sdk.transforms.Combine.SimpleCombineFn
Deprecated.
 
SimpleFunction<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
A SerializableFunction which is not a functional interface.
SimpleFunction() - Constructor for class org.apache.beam.sdk.transforms.SimpleFunction
 
SimpleFunction(SerializableFunction<InputT, OutputT>) - Constructor for class org.apache.beam.sdk.transforms.SimpleFunction
 
SimpleIdentifierContext(FieldSpecifierNotationParser.DotExpressionComponentContext) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.SimpleIdentifierContext
 
simpleTypeDescription(Type) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
A Function that formats types.
singletonView(PCollection<T>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>, boolean, T, Coder<T>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
Returns a PCollectionView<T> capable of processing elements windowed using the provided WindowingStrategy.
singletonViewUsingVoidKey(PCollection<KV<Void, T>>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>, boolean, T, Coder<T>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
sink(Class<ElementT>) - Static method in class org.apache.beam.sdk.io.AvroIO
A AvroIO.Sink for use with FileIO.write() and FileIO.writeDynamic(), writing elements of the given generated class, like AvroIO.write(Class).
sink(Schema) - Static method in class org.apache.beam.sdk.io.AvroIO
A AvroIO.Sink for use with FileIO.write() and FileIO.writeDynamic(), writing elements with a given (common) schema, like AvroIO.writeGenericRecords(Schema).
sink(String) - Static method in class org.apache.beam.sdk.io.AvroIO
A AvroIO.Sink for use with FileIO.write() and FileIO.writeDynamic(), writing elements with a given (common) schema, like AvroIO.writeGenericRecords(String).
Sink() - Constructor for class org.apache.beam.sdk.io.AvroIO.Sink
 
sink - Variable in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
The Sink that this WriteOperation will write to.
sink() - Static method in class org.apache.beam.sdk.io.TextIO
Creates a TextIO.Sink that writes newline-delimited strings in UTF-8, for use with FileIO.write().
Sink() - Constructor for class org.apache.beam.sdk.io.TextIO.Sink
 
sink() - Static method in class org.apache.beam.sdk.io.TFRecordIO
Sink() - Constructor for class org.apache.beam.sdk.io.TFRecordIO.Sink
 
SinkMetrics - Class in org.apache.beam.sdk.metrics
Standard Sink Metrics.
SinkMetrics() - Constructor for class org.apache.beam.sdk.metrics.SinkMetrics
 
sinkViaGenericRecords(Schema, AvroIO.RecordFormatter<ElementT>) - Static method in class org.apache.beam.sdk.io.AvroIO
Deprecated.
RecordFormatter will be removed in future versions.
size() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
size() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
Returns the number of columns for this schema.
size() - Method in class org.apache.beam.sdk.values.PCollectionList
Returns the number of PCollections in this PCollectionList.
size() - Method in class org.apache.beam.sdk.values.TupleTagList
Returns the number of TupleTags in this TupleTagList.
sizeBytes() - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata
 
sleep(long) - Method in interface org.apache.beam.sdk.util.Sleeper
Causes the currently executing thread to sleep (temporarily cease execution) for the specified number of milliseconds as specified in Thread.sleep(long).
Sleeper - Interface in org.apache.beam.sdk.util
Sleeper interface to use for requesting the current thread to sleep as specified in Thread.sleep(long).
SlidingWindows - Class in org.apache.beam.sdk.transforms.windowing
A WindowFn that windows values into possibly overlapping fixed-size timestamp-based windows.
smallest(int) - Static method in class org.apache.beam.sdk.transforms.Top
Returns a PTransform that takes an input PCollection<T> and returns a PCollection<List<T>> with a single element containing the smallest count elements of the input PCollection<T>, in increasing order, sorted according to their natural order.
Smallest() - Constructor for class org.apache.beam.sdk.transforms.Top.Smallest
Deprecated.
 
smallestDoublesFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
Returns a Top.TopCombineFn that aggregates the smallest count double values.
smallestFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
Returns a Top.TopCombineFn that aggregates the smallest count values.
smallestIntsFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
Returns a Top.TopCombineFn that aggregates the smallest count int values.
smallestLongsFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
Returns a Top.TopCombineFn that aggregates the smallest count long values.
smallestPerKey(int) - Static method in class org.apache.beam.sdk.transforms.Top
Returns a PTransform that takes an input PCollection<KV<K, V>> and returns a PCollection<KV<K, List<V>>> that contains an output element mapping each distinct key in the input PCollection to the smallest count values associated with that key in the input PCollection<KV<K, V>>, in increasing order, sorted according to their natural order.
SnappyCoder<T> - Class in org.apache.beam.sdk.coders
Wraps an existing coder with Snappy compression.
sortBySchema(List<FieldValueTypeInformation>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.StaticSchemaInference
 
Source<T> - Class in org.apache.beam.sdk.io
Base class for defining input formats and creating a Source for reading the input.
Source() - Constructor for class org.apache.beam.sdk.io.Source
 
Source.Reader<T> - Class in org.apache.beam.sdk.io
The interface that readers of custom input sources must implement.
SourceMetrics - Class in org.apache.beam.sdk.metrics
Standard Source Metrics.
SourceMetrics() - Constructor for class org.apache.beam.sdk.metrics.SourceMetrics
 
SourceTestUtils - Class in org.apache.beam.sdk.testing
Helper functions and test harnesses for checking correctness of Source implementations.
SourceTestUtils() - Constructor for class org.apache.beam.sdk.testing.SourceTestUtils
 
SourceTestUtils.ExpectedSplitOutcome - Enum in org.apache.beam.sdk.testing
span(IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
Returns the minimal window that includes both this window and the given window.
split(long, PipelineOptions) - Method in class org.apache.beam.sdk.io.BoundedSource
Splits the source into bundles of approximately desiredBundleSizeBytes.
split(long, PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSource
 
split(long, PipelineOptions) - Method in class org.apache.beam.sdk.io.OffsetBasedSource
 
split(int) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
Returns a list of up to numSplits + 1 ByteKeys in ascending order, where the keys have been interpolated to form roughly equal sub-ranges of this ByteKeyRange, assuming a uniform distribution of keys within this range.
split(long, long) - Method in class org.apache.beam.sdk.io.range.OffsetRange
 
split(int, PipelineOptions) - Method in class org.apache.beam.sdk.io.UnboundedSource
Returns a list of UnboundedSource objects representing the instances of this source that should be used when executing the workflow.
split(String) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.Split PTransform that splits a string on the regular expression and then outputs each item.
split(Pattern) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.Split PTransform that splits a string on the regular expression and then outputs each item.
split(String, boolean) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.Split PTransform that splits a string on the regular expression and then outputs each item.
split(Pattern, boolean) - Static method in class org.apache.beam.sdk.transforms.Regex
Returns a Regex.Split PTransform that splits a string on the regular expression and then outputs each item.
Split(Pattern, boolean) - Constructor for class org.apache.beam.sdk.transforms.Regex.Split
 
SPLIT_POINTS_UNKNOWN - Static variable in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
A constant to use as the return value for BoundedSource.BoundedReader.getSplitPointsConsumed() or BoundedSource.BoundedReader.getSplitPointsRemaining() when the exact value is unknown.
splitAtFraction(double) - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
Tells the reader to narrow the range of the input it's going to read and give up the remainder, so that the new range would contain approximately the given fraction of the amount of data in the current range.
splitAtFraction(double) - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
 
splitRestriction() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.SplitRestriction method.
SplitRestrictionMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.SplitRestrictionMethod
 
SplitResult<RestrictionT> - Class in org.apache.beam.sdk.transforms.splittabledofn
A representation of a split result.
SplitResult() - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.SplitResult
 
SqlTypes - Class in org.apache.beam.sdk.schemas.logicaltypes
Beam Schema.LogicalTypes corresponding to SQL data types.
StandardCreateOptions() - Constructor for class org.apache.beam.sdk.io.fs.CreateOptions.StandardCreateOptions
 
start() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
 
start() - Method in class org.apache.beam.sdk.io.Source.Reader
Initializes the reader and advances the reader to the first record.
start() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
Initializes the reader and advances the reader to the first record.
start() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
Returns the start of this window, inclusive.
startAt(Instant) - Method in class org.apache.beam.sdk.transforms.PeriodicImpulse
 
startBundle() - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
startBundle() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.StartBundle method.
StartBundleContext() - Constructor for class org.apache.beam.sdk.transforms.DoFn.StartBundleContext
 
startBundleContext(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provide a DoFn.StartBundleContext to use with the given DoFn.
startBundleContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
startBundleContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
startBundleContext() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
startImpl() - Method in class org.apache.beam.sdk.io.FileBasedSource.FileBasedReader
 
startImpl() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
Initializes the OffsetBasedSource.OffsetBasedReader and advances to the first record, returning true if there is a record available to be read.
startReading(ReadableByteChannel) - Method in class org.apache.beam.sdk.io.AvroSource.AvroReader
 
startReading(ReadableByteChannel) - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
Creates a decompressing channel from the input channel and passes it to its delegate reader's FileBasedReader#startReading(ReadableByteChannel).
startReading(ReadableByteChannel) - Method in class org.apache.beam.sdk.io.FileBasedSource.FileBasedReader
Performs any initialization of the subclass of FileBasedReader that involves IO operations.
startsWith(String) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
A SerializableMatcher with identical criteria to Matchers.startsWith(java.lang.String).
State - Interface in org.apache.beam.sdk.state
A state cell, supporting a State.clear() operation.
state(String, boolean) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Returns the state cell for the given DoFn.StateId.
state(String, boolean) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
state(String, boolean) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
STATE_CACHE_SIZE - Static variable in interface org.apache.beam.sdk.options.ExperimentalOptions
 
StateBinder - Interface in org.apache.beam.sdk.state
For internal use only; no backwards-compatibility guarantees.
StateContext<W extends BoundedWindow> - Interface in org.apache.beam.sdk.state
For internal use only; no backwards-compatibility guarantees.
StateContexts - Class in org.apache.beam.sdk.state
For internal use only; no backwards-compatibility guarantees.
StateContexts() - Constructor for class org.apache.beam.sdk.state.StateContexts
 
StateDeclaration() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.StateDeclaration
 
stateDeclarations() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about the state cells that this DoFn declares.
StateKeySpec - Class in org.apache.beam.sdk.state
 
stateParameter(DoFnSignature.StateDeclaration, boolean) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
StateSpec<StateT extends State> - Interface in org.apache.beam.sdk.state
A specification of a persistent state cell.
StateSpec.Cases<ResultT> - Interface in org.apache.beam.sdk.state
Cases for doing a "switch" on the type of StateSpec.
StateSpec.Cases.WithDefault<ResultT> - Class in org.apache.beam.sdk.state
A base class for a visitor with a default method for cases it is not interested in.
StateSpecs - Class in org.apache.beam.sdk.state
Static methods for working with StateSpecs.
stateType() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.StateDeclaration
 
StaticSchemaInference - Class in org.apache.beam.sdk.schemas.utils
A set of utilities for inferring a Beam Schema from static Java types.
StaticSchemaInference() - Constructor for class org.apache.beam.sdk.schemas.utils.StaticSchemaInference
 
status() - Method in class org.apache.beam.sdk.io.fs.MatchResult
Status of the MatchResult.
stepName() - Method in class org.apache.beam.sdk.metrics.MetricKey
The step name that is associated with this metric or Null if none is associated.
steps() - Method in class org.apache.beam.sdk.metrics.MetricsFilter
 
stop() - Static method in class org.apache.beam.sdk.transforms.DoFn.ProcessContinuation
Indicates that there is no more work to be done for the current element.
STOP - Static variable in interface org.apache.beam.sdk.util.BackOff
Indicates that no more retries should be made for use in BackOff.nextBackOffMillis().
STOP_BACKOFF - Static variable in interface org.apache.beam.sdk.util.BackOff
Fixed back-off policy that always returns #STOP for BackOff.nextBackOffMillis(), meaning that the operation should not be retried.
stopAt(Instant) - Method in class org.apache.beam.sdk.transforms.PeriodicImpulse
 
stopSampling(int, long) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.LimitNumberOfFiles
 
stopSampling(int, long) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.LimitNumberOfTotalBytes
 
stopSampling(int, long) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.SampleAllFiles
 
stopSampling(int, long) - Method in interface org.apache.beam.sdk.io.TextRowCountEstimator.SamplingStrategy
 
StreamingIT - Interface in org.apache.beam.sdk.testing
Deprecated.
tests which use unbounded PCollections should be in the category UsesUnboundedPCollections. Beyond that, it is up to the runner and test configuration to decide whether to run in streaming mode.
StreamingOptions - Interface in org.apache.beam.sdk.options
Options used to configure streaming.
StreamUtils - Class in org.apache.beam.sdk.util
Utility functions for stream operations.
STRING - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
The type of string fields.
STRING_TYPES - Static variable in enum org.apache.beam.sdk.schemas.Schema.TypeName
 
StringDelegateCoder<T> - Class in org.apache.beam.sdk.coders
A Coder that wraps a Coder<String> and encodes/decodes values via string representations.
StringDelegateCoder(Class<T>, TypeDescriptor<T>) - Constructor for class org.apache.beam.sdk.coders.StringDelegateCoder
 
strings() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
The TypeDescriptor for String.
StringUtf8Coder - Class in org.apache.beam.sdk.coders
A Coder that encodes Strings in UTF-8 encoding.
StringUtils - Class in org.apache.beam.sdk.util
Utilities for working with JSON and other human-readable string formats.
StringUtils() - Constructor for class org.apache.beam.sdk.util.StringUtils
 
stripGetterPrefix(String) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
 
StripIdsDoFn() - Constructor for class org.apache.beam.sdk.values.ValueWithRecordId.StripIdsDoFn
 
stripPrefix(String, String) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
 
stripSetterPrefix(String) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
 
StructuralByteArray - Class in org.apache.beam.sdk.coders
A wrapper around a byte[] that uses structural, value-based equality rather than byte[]'s normal object identity.
StructuralByteArray(byte[]) - Constructor for class org.apache.beam.sdk.coders.StructuralByteArray
 
structuralValue(byte[]) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
Returns an object with an Object.equals() method that represents structural equality on the argument.
structuralValue(T) - Method in class org.apache.beam.sdk.coders.Coder
Returns an object with an Object.equals() method that represents structural equality on the argument.
structuralValue(T) - Method in class org.apache.beam.sdk.coders.DelegateCoder
Returns an object with an Object.equals() method that represents structural equality on the argument.
structuralValue(Deque<T>) - Method in class org.apache.beam.sdk.coders.DequeCoder
 
structuralValue(Iterable<T>) - Method in class org.apache.beam.sdk.coders.IterableCoder
 
structuralValue(KV<K, V>) - Method in class org.apache.beam.sdk.coders.KvCoder
 
structuralValue(List<T>) - Method in class org.apache.beam.sdk.coders.ListCoder
 
structuralValue(Map<K, V>) - Method in class org.apache.beam.sdk.coders.MapCoder
 
structuralValue(T) - Method in class org.apache.beam.sdk.coders.NullableCoder
 
structuralValue(T) - Method in class org.apache.beam.sdk.coders.SerializableCoder
The structural value of the object is the object itself.
structuralValue(T) - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
 
structuralValue(Void) - Method in class org.apache.beam.sdk.coders.VoidCoder
 
structuralValue(ShardedKey<K>) - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
 
structuralValue(TimestampedValue<T>) - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
 
structuralValueConsistentWithEquals(Coder<T>, T, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<T> and values of type T, the structural values are equal if and only if the encoded bytes are equal.
structuralValueConsistentWithEqualsInContext(Coder<T>, Coder.Context, T, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<T>, Coder.Context, and values of type T, the structural values are equal if and only if the encoded bytes are equal, in any Coder.Context.
structuralValueDecodeEncodeEqual(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<T> and value of type T, the structural value is equal to the structural value yield by encoding and decoding the original value.
structuralValueDecodeEncodeEqualInContext(Coder<T>, Coder.Context, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<T>, Coder.Context, and value of type T, the structural value is equal to the structural value yield by encoding and decoding the original value, in any Coder.Context.
structuralValueDecodeEncodeEqualIterable(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<T> and value of type T, the structural value of the content of the Iterable is equal to the structural value yield by encoding and decoding the original value.
structuralValueDecodeEncodeEqualIterableInContext(Coder<T>, Coder.Context, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
Verifies that for the given Coder<T>, Coder.Context, and value of type T, the structural content of the Iterable of the value is equal to the structural value yield by encoding and decoding the original value, in any Coder.Context.
StructuredCoder<T> - Class in org.apache.beam.sdk.coders
An abstract base class to implement a Coder that defines equality, hashing, and printing via the class name and recursively using StructuredCoder.getComponents().
StructuredCoder() - Constructor for class org.apache.beam.sdk.coders.StructuredCoder
 
subclassGetterInterface(ByteBuddy, Type, Type) - Static method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils
 
subclassSetterInterface(ByteBuddy, Type, Type) - Static method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils
 
subPathMatches(String, String) - Static method in class org.apache.beam.sdk.metrics.MetricFiltering
subPathMatches(haystack, needle) returns true if needle represents a path within haystack.
subTriggers - Variable in class org.apache.beam.sdk.transforms.windowing.Trigger
 
subTriggers() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
 
success() - Static method in class org.apache.beam.sdk.testing.SuccessOrFailure
 
SUCCESS_COUNTER - Static variable in class org.apache.beam.sdk.testing.PAssert
 
SuccessOrFailure - Class in org.apache.beam.sdk.testing
Output of PAssert.
Sum - Class in org.apache.beam.sdk.transforms
PTransforms for computing the sum of the elements in a PCollection, or the sum of the values associated with each key in a PCollection of KVs.
supplyAsync(ThrowingSupplier<T>, ExecutorService) - Static method in class org.apache.beam.sdk.util.MoreFutures
Like CompletableFuture.supplyAsync(Supplier) but for ThrowingSupplier.
supplyAsync(ThrowingSupplier<T>) - Static method in class org.apache.beam.sdk.util.MoreFutures
Shorthand for MoreFutures.supplyAsync(ThrowingSupplier, ExecutorService) using ForkJoinPool.commonPool().
SystemDoFnInternal - Annotation Type in org.apache.beam.sdk.util
Annotation to mark DoFns as an internal component of the Beam SDK.

T

T__0 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
T__0 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
T__1 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
T__1 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
T__2 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
T__2 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
T__3 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
T__3 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
T__4 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
T__4 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
TaggedKeyedPCollection(TupleTag<V>, PCollection<KV<K, V>>) - Constructor for class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple.TaggedKeyedPCollection
 
taggedOutputReceiver(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provide a DoFn.MultiOutputReceiver for outputting to the default output.
taggedOutputReceiver(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
taggedOutputReceiver(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
taggedOutputReceiverParameter() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
 
TaggedPValue - Class in org.apache.beam.sdk.values
For internal use only; no backwards-compatibility guarantees.
TaggedPValue() - Constructor for class org.apache.beam.sdk.values.TaggedPValue
 
takeOutputElements() - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
takeOutputElements(TupleTag<T>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
takeOutputElementsWithTimestamp() - Method in class org.apache.beam.sdk.transforms.DoFnTester
Deprecated.
Use TestPipeline with the DirectRunner.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.BundleMethod
The annotated method itself.
targetMethod() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.DoFnMethod
The annotated method itself.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialRestrictionMethod
The annotated method itself.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialWatermarkEstimatorStateMethod
The annotated method itself.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetRestrictionCoderMethod
The annotated method itself.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetSizeMethod
The annotated method itself.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetWatermarkEstimatorStateCoderMethod
The annotated method itself.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.LifecycleMethod
The annotated method itself.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewTrackerMethod
The annotated method itself.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewWatermarkEstimatorMethod
The annotated method itself.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerFamilyMethod
The annotated method itself.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerMethod
The annotated method itself.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnWindowExpirationMethod
The annotated method itself.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
The annotated method itself.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.SplitRestrictionMethod
The annotated method itself.
targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TruncateRestrictionMethod
The annotated method itself.
teardown() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.Teardown method.
tempDirectory - Variable in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
Directory for temporary output files.
testByteCount(Coder<T>, Coder.Context, T[]) - Static method in class org.apache.beam.sdk.testing.CoderProperties
A utility method that passes the given (unencoded) elements through coder's registerByteSizeObserver() and encode() methods, and confirms they are mutually consistent.
testCombineFn(Combine.CombineFn<InputT, AccumT, OutputT>, List<InputT>, OutputT) - Static method in class org.apache.beam.sdk.testing.CombineFnTester
Tests that the the Combine.CombineFn, when applied to the provided input, produces the provided output.
testCombineFn(Combine.CombineFn<InputT, AccumT, OutputT>, List<InputT>, Matcher<? super OutputT>) - Static method in class org.apache.beam.sdk.testing.CombineFnTester
 
TestElementByteSizeObserver() - Constructor for class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
 
testingPipelineOptions() - Static method in class org.apache.beam.sdk.testing.TestPipeline
Creates PipelineOptions for testing.
TestPipeline - Class in org.apache.beam.sdk.testing
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.
TestPipeline.AbandonedNodeException - Exception in org.apache.beam.sdk.testing
An exception thrown in case an abandoned PTransform is detected, that is, a PTransform that has not been run.
TestPipeline.PipelineRunMissingException - Exception in org.apache.beam.sdk.testing
An exception thrown in case a test finishes without invoking Pipeline.run().
TestPipeline.TestValueProviderOptions - Interface in org.apache.beam.sdk.testing
Implementation detail of TestPipeline.newProvider(T), do not use.
TestPipelineOptions - Interface in org.apache.beam.sdk.testing
TestPipelineOptions is a set of options for test pipelines.
TestPipelineOptions.AlwaysPassMatcher - Class in org.apache.beam.sdk.testing
Matcher which will always pass.
TestPipelineOptions.AlwaysPassMatcherFactory - Class in org.apache.beam.sdk.testing
Factory for PipelineResult matchers which always pass.
TestStream<T> - Class in org.apache.beam.sdk.testing
A testing input that generates an unbounded PCollection of elements, advancing the watermark and processing time as elements are emitted.
TestStream.Builder<T> - Class in org.apache.beam.sdk.testing
An incomplete TestStream.
TestStream.ElementEvent<T> - Class in org.apache.beam.sdk.testing
A TestStream.Event that produces elements.
TestStream.Event<T> - Interface in org.apache.beam.sdk.testing
An event in a TestStream.
TestStream.EventType - Enum in org.apache.beam.sdk.testing
The types of TestStream.Event that are supported by TestStream.
TestStream.ProcessingTimeEvent<T> - Class in org.apache.beam.sdk.testing
A TestStream.Event that advances the processing time clock.
TestStream.TestStreamCoder<T> - Class in org.apache.beam.sdk.testing
Coder for TestStream.
TestStream.WatermarkEvent<T> - Class in org.apache.beam.sdk.testing
A TestStream.Event that advances the watermark.
TEXT - Static variable in class org.apache.beam.sdk.util.MimeTypes
 
TextIO - Class in org.apache.beam.sdk.io
PTransforms for reading and writing text files.
TextIO.CompressionType - Enum in org.apache.beam.sdk.io
Deprecated.
TextIO.Read - Class in org.apache.beam.sdk.io
Implementation of TextIO.read().
TextIO.ReadAll - Class in org.apache.beam.sdk.io
Deprecated.
See TextIO.readAll() for details.
TextIO.ReadFiles - Class in org.apache.beam.sdk.io
Implementation of TextIO.readFiles().
TextIO.Sink - Class in org.apache.beam.sdk.io
Implementation of TextIO.sink().
TextIO.TypedWrite<UserT,DestinationT> - Class in org.apache.beam.sdk.io
Implementation of TextIO.write().
TextIO.Write - Class in org.apache.beam.sdk.io
This class is used as the default return value of TextIO.write().
TextRowCountEstimator - Class in org.apache.beam.sdk.io
This returns a row count estimation for files associated with a file pattern.
TextRowCountEstimator() - Constructor for class org.apache.beam.sdk.io.TextRowCountEstimator
 
TextRowCountEstimator.Builder - Class in org.apache.beam.sdk.io
TextRowCountEstimator.LimitNumberOfFiles - Class in org.apache.beam.sdk.io
This strategy stops sampling if we sample enough number of bytes.
TextRowCountEstimator.LimitNumberOfTotalBytes - Class in org.apache.beam.sdk.io
This strategy stops sampling when total number of sampled bytes are more than some threshold.
TextRowCountEstimator.NoEstimationException - Exception in org.apache.beam.sdk.io
An exception that will be thrown if the estimator cannot get an estimation of the number of lines.
TextRowCountEstimator.SampleAllFiles - Class in org.apache.beam.sdk.io
This strategy samples all the files.
TextRowCountEstimator.SamplingStrategy - Interface in org.apache.beam.sdk.io
Sampling Strategy shows us when should we stop reading further files.
TextualIntegerCoder - Class in org.apache.beam.sdk.coders
A Coder that encodes Integer Integers as the ASCII bytes of their textual, decimal, representation.
TextualIntegerCoder() - Constructor for class org.apache.beam.sdk.coders.TextualIntegerCoder
 
TFRecordIO - Class in org.apache.beam.sdk.io
PTransforms for reading and writing TensorFlow TFRecord files.
TFRecordIO.CompressionType - Enum in org.apache.beam.sdk.io
Deprecated.
TFRecordIO.Read - Class in org.apache.beam.sdk.io
Implementation of TFRecordIO.read().
TFRecordIO.ReadFiles - Class in org.apache.beam.sdk.io
Implementation of TFRecordIO.readFiles().
TFRecordIO.Sink - Class in org.apache.beam.sdk.io
TFRecordIO.Write - Class in org.apache.beam.sdk.io
Implementation of TFRecordIO.write().
that(PCollection<T>) - Static method in class org.apache.beam.sdk.testing.PAssert
Constructs an PAssert.IterableAssert for the elements of the provided PCollection.
that(String, PCollection<T>) - Static method in class org.apache.beam.sdk.testing.PAssert
Constructs an PAssert.IterableAssert for the elements of the provided PCollection with the specified reason.
thatMap(PCollection<KV<K, V>>) - Static method in class org.apache.beam.sdk.testing.PAssert
Constructs a PAssert.SingletonAssert for the value of the provided PCollection, which must have at most one value per key.
thatMap(String, PCollection<KV<K, V>>) - Static method in class org.apache.beam.sdk.testing.PAssert
Constructs a PAssert.SingletonAssert for the value of the provided PCollection with the specified reason.
thatMultimap(PCollection<KV<K, V>>) - Static method in class org.apache.beam.sdk.testing.PAssert
Constructs a PAssert.SingletonAssert for the value of the provided PCollection.
thatMultimap(String, PCollection<KV<K, V>>) - Static method in class org.apache.beam.sdk.testing.PAssert
Constructs a PAssert.SingletonAssert for the value of the provided PCollection with the specified reason.
thatSingleton(PCollection<T>) - Static method in class org.apache.beam.sdk.testing.PAssert
Constructs a PAssert.SingletonAssert for the value of the provided PCollection PCollection<T>, which must be a singleton.
thatSingleton(String, PCollection<T>) - Static method in class org.apache.beam.sdk.testing.PAssert
Constructs a PAssert.SingletonAssert for the value of the provided PCollection PCollection<T> with the specified reason.
thatSingletonIterable(PCollection<? extends Iterable<T>>) - Static method in class org.apache.beam.sdk.testing.PAssert
Constructs an PAssert.IterableAssert for the value of the provided PCollection which must contain a single Iterable<T> value.
thatSingletonIterable(String, PCollection<? extends Iterable<T>>) - Static method in class org.apache.beam.sdk.testing.PAssert
Constructs an PAssert.IterableAssert for the value of the provided PCollection with the specified reason.
ThrowingBiConsumer<T1,T2> - Interface in org.apache.beam.sdk.function
A BiConsumer which can throw Exceptions.
ThrowingBiFunction<T1,T2,T3> - Interface in org.apache.beam.sdk.function
A BiFunction which can throw Exceptions.
ThrowingConsumer<ExceptionT extends java.lang.Exception,T> - Interface in org.apache.beam.sdk.function
A Consumer which can throw Exceptions.
ThrowingFunction<T1,T2> - Interface in org.apache.beam.sdk.function
A Function which can throw Exceptions.
ThrowingRunnable - Interface in org.apache.beam.sdk.function
A Runnable which can throw Exceptions.
ThrowingRunnable - Interface in org.apache.beam.sdk.util
Like Runnable but allowed to throw any exception.
ThrowingSupplier<T> - Interface in org.apache.beam.sdk.util
Like Supplier but allowed to throw any exception.
TIME - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.SqlTypes
Beam LogicalType corresponding to ZetaSQL/CalciteSQL TIME type.
Time - Class in org.apache.beam.sdk.schemas.logicaltypes
A time without a time-zone.
Time() - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.Time
 
TIME_FIELD_NAME - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
 
TimeDomain - Enum in org.apache.beam.sdk.state
TimeDomain specifies whether an operation is based on timestamps of elements or current "real-world" time as reported while processing.
timeDomain() - Method in class org.apache.beam.sdk.transforms.DoFn.OnTimerContext
Returns the time domain of the current timer.
timeDomain(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provide a reference to the time domain for a timer firing.
timeDomain(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
timeDomain(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
timeDomainParameter() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
 
Timer - Interface in org.apache.beam.sdk.state
A timer for a specified time domain that can be set to register the desire for further processing at particular time in its specified time domain.
timer(TimeDomain) - Static method in class org.apache.beam.sdk.state.TimerSpecs
 
timer(String) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Returns the timer for the given DoFn.TimerId.
timer(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
timer(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
TimerDeclaration() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TimerDeclaration
 
timerDeclarations() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Timer declarations present on the DoFn class.
timerFamily(String) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Returns the timerMap for the given DoFn.TimerFamily.
timerFamily(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
timerFamily(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
TimerFamilyDeclaration() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TimerFamilyDeclaration
 
timerFamilyDeclarations() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
TimerMap declarations present on the DoFn class.
timerFamilyParameter(DoFnSignature.TimerFamilyDeclaration) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
 
timerId(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Returns the timer id for the current timer of a DoFn.TimerFamily.
timerId(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
timerId(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
timerIdParameter() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
 
TimerMap - Interface in org.apache.beam.sdk.state
 
timerMap(TimeDomain) - Static method in class org.apache.beam.sdk.state.TimerSpecs
 
timerParameter(DoFnSignature.TimerDeclaration) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
 
Timers - Interface in org.apache.beam.sdk.state
Interface for interacting with time.
TimerSpec - Interface in org.apache.beam.sdk.state
A specification for a Timer.
TimerSpecs - Class in org.apache.beam.sdk.state
Static methods for working with TimerSpecs.
TimerSpecs() - Constructor for class org.apache.beam.sdk.state.TimerSpecs
 
TIMESTAMP - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.SqlTypes
Beam LogicalType corresponding to ZetaSQL TIMESTAMP type.
timestamp() - Method in class org.apache.beam.sdk.transforms.DoFn.OnTimerContext
Returns the output timestamp of the current timer.
timestamp() - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContext
Returns the timestamp of the input element.
timestamp(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Provide a reference to the input element timestamp.
timestamp(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
timestamp(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
timestamp() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn.AssignContext
Returns the timestamp of the current element.
TIMESTAMP_MAX_VALUE - Static variable in class org.apache.beam.sdk.transforms.windowing.BoundedWindow
The maximum value for any Beam timestamp.
TIMESTAMP_MIN_VALUE - Static variable in class org.apache.beam.sdk.transforms.windowing.BoundedWindow
The minimum value for any Beam timestamp.
TimestampCombiner - Enum in org.apache.beam.sdk.transforms.windowing
Policies for combining timestamps that occur within a window.
timestamped(Iterable<TimestampedValue<T>>) - Static method in class org.apache.beam.sdk.transforms.Create
Returns a new Create.TimestampedValues transform that produces a PCollection containing the elements of the provided Iterable with the specified timestamps.
timestamped(TimestampedValue<T>, TimestampedValue<T>...) - Static method in class org.apache.beam.sdk.transforms.Create
Returns a new Create.TimestampedValues transform that produces a PCollection containing the specified elements with the specified timestamps.
timestamped(Iterable<T>, Iterable<Long>) - Static method in class org.apache.beam.sdk.transforms.Create
Returns a new root transform that produces a PCollection containing the specified elements with the specified timestamps.
TimestampedValue<V> - Class in org.apache.beam.sdk.values
An immutable pair of a value and a timestamp.
TimestampedValue(V, Instant) - Constructor for class org.apache.beam.sdk.values.TimestampedValue
 
TimestampedValue.TimestampedValueCoder<T> - Class in org.apache.beam.sdk.values
timestampedValueInGlobalWindow(T, Instant) - Static method in class org.apache.beam.sdk.util.WindowedValue
Returns a WindowedValue with the given value and timestamp, GlobalWindow and default pane.
TimestampObservingWatermarkEstimator<WatermarkEstimatorStateT> - Interface in org.apache.beam.sdk.transforms.splittabledofn
A WatermarkEstimator that observes the timestamps of all records output from a DoFn.
timestampParameter() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
 
timestamps() - Static method in class org.apache.beam.sdk.transforms.Reify
Create a PTransform that will output all inputs wrapped in a TimestampedValue.
timestampsInValue() - Static method in class org.apache.beam.sdk.transforms.Reify
Create a PTransform that will output all input KVs with the timestamp inside the value.
TimestampTransform - Class in org.apache.beam.sdk.transforms.windowing
For internal use only; no backwards-compatibility guarantees.
TimestampTransform.AlignTo - Class in org.apache.beam.sdk.transforms.windowing
For internal use only; no backwards-compatibility guarantees.
TimestampTransform.Delay - Class in org.apache.beam.sdk.transforms.windowing
For internal use only; no backwards-compatibility guarantees.
to(String) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Writes to file(s) with the given output prefix.
to(ResourceId) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Writes to file(s) with the given output prefix.
to(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
to(FileBasedSink.FilenamePolicy) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Writes to files named according to the given FileBasedSink.FilenamePolicy.
to(DynamicAvroDestinations<UserT, NewDestinationT, OutputT>) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Deprecated.
to(String) - Method in class org.apache.beam.sdk.io.AvroIO.Write
to(ResourceId) - Method in class org.apache.beam.sdk.io.AvroIO.Write
to(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.AvroIO.Write
to(FileBasedSink.FilenamePolicy) - Method in class org.apache.beam.sdk.io.AvroIO.Write
See TypedWrite#to(FilenamePolicy).
to(DynamicAvroDestinations<T, ?, T>) - Method in class org.apache.beam.sdk.io.AvroIO.Write
Deprecated.
to(String) - Method in class org.apache.beam.sdk.io.FileIO.Write
Specifies a common directory for all generated files.
to(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.FileIO.Write
to(long) - Method in class org.apache.beam.sdk.io.GenerateSequence
Specifies the maximum number to generate (exclusive).
to(String) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Writes to text files with the given prefix.
to(ResourceId) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
to(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
to(FileBasedSink.FilenamePolicy) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Writes to files named according to the given FileBasedSink.FilenamePolicy.
to(FileBasedSink.DynamicDestinations<UserT, NewDestinationT, String>) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Deprecated.
to(SerializableFunction<UserT, DefaultFilenamePolicy.Params>, DefaultFilenamePolicy.Params) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Deprecated.
to(String) - Method in class org.apache.beam.sdk.io.TextIO.Write
to(ResourceId) - Method in class org.apache.beam.sdk.io.TextIO.Write
to(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.TextIO.Write
to(FileBasedSink.FilenamePolicy) - Method in class org.apache.beam.sdk.io.TextIO.Write
See TypedWrite#to(FilenamePolicy).
to(FileBasedSink.DynamicDestinations<String, ?, String>) - Method in class org.apache.beam.sdk.io.TextIO.Write
Deprecated.
to(SerializableFunction<String, DefaultFilenamePolicy.Params>, DefaultFilenamePolicy.Params) - Method in class org.apache.beam.sdk.io.TextIO.Write
Deprecated.
to(String) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
Writes TFRecord file(s) with the given output prefix.
to(ResourceId) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
Writes TFRecord file(s) with a prefix given by the specified resource.
to(FileBasedSink<UserT, DestinationT, OutputT>) - Static method in class org.apache.beam.sdk.io.WriteFiles
Creates a WriteFiles transform that writes to the given FileBasedSink, letting the runner control how many different shards are produced.
to(Class<OutputT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Convert
Convert a PCollection<InputT> to a PCollection<OutputT>.
to(TypeDescriptor<OutputT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Convert
Convert a PCollection<InputT> to a PCollection<OutputT>.
toAdditionalInputs(Iterable<PCollectionView<?>>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
Expands a list of PCollectionView into the form needed for PTransform.getAdditionalInputs().
toAppliedPTransform(Pipeline) - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
Returns the AppliedPTransform representing this TransformHierarchy.Node.
toAvroField(Schema.Field, String) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Get Avro Field from Beam Field.
toAvroSchema(Schema, String, String) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Converts a Beam Schema into an AVRO schema.
toAvroSchema(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
 
toAvroType(String, String) - Method in class org.apache.beam.sdk.schemas.utils.AvroUtils.FixedBytesField
Convert to an AVRO type.
toBaseType(LocalDate) - Method in class org.apache.beam.sdk.schemas.logicaltypes.Date
 
toBaseType(LocalDateTime) - Method in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
 
toBaseType(EnumerationType.Value) - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
 
toBaseType(byte[]) - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
 
toBaseType(Instant) - Method in class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
 
toBaseType(Duration) - Method in class org.apache.beam.sdk.schemas.logicaltypes.NanosDuration
 
toBaseType(Instant) - Method in class org.apache.beam.sdk.schemas.logicaltypes.NanosInstant
 
toBaseType(OneOfType.Value) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
 
toBaseType(T) - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
 
toBaseType(LocalTime) - Method in class org.apache.beam.sdk.schemas.logicaltypes.Time
 
toBaseType(InputT) - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
Convert the input type to the type Java type used by the base Schema.FieldType.
toBeamField(Schema.Field) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Get Beam Field from avro Field.
toBeamRowStrict(GenericRecord, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Strict conversion from AVRO to Beam, strict because it doesn't do widening or narrowing during conversion.
toBeamSchema(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Converts AVRO schema to Beam row schema.
toBeamType() - Method in class org.apache.beam.sdk.schemas.utils.AvroUtils.FixedBytesField
Convert to a Beam type.
toBuilder() - Method in class org.apache.beam.sdk.schemas.Schema.Field
 
toBuilder() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
toBuilder() - Method in class org.apache.beam.sdk.transforms.DoFnSchemaInformation
 
toBuilder() - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError
 
toBuilder() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter
 
toBuilder() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SideInputParameter
 
toByteArray() - Method in class org.apache.beam.sdk.util.ExposedByteArrayOutputStream
 
toDefaultPolicies(SerializableFunction<UserT, DefaultFilenamePolicy.Params>, DefaultFilenamePolicy.Params, SerializableFunction<UserT, OutputT>) - Static method in class org.apache.beam.sdk.io.DynamicFileDestinations
Returns a FileBasedSink.DynamicDestinations that returns instances of DefaultFilenamePolicy configured with the given DefaultFilenamePolicy.Params.
toFnWithContext(CombineFnBase.GlobalCombineFn<InputT, AccumT, OutputT>) - Static method in class org.apache.beam.sdk.util.CombineFnUtil
toGenericRecord(Row, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
Convert from a Beam Row to an AVRO GenericRecord.
toInputType(Long) - Method in class org.apache.beam.sdk.schemas.logicaltypes.Date
 
toInputType(Row) - Method in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
 
toInputType(Integer) - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
 
toInputType(byte[]) - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
 
toInputType(Row) - Method in class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
 
toInputType(Row) - Method in class org.apache.beam.sdk.schemas.logicaltypes.NanosDuration
 
toInputType(Row) - Method in class org.apache.beam.sdk.schemas.logicaltypes.NanosInstant
 
toInputType(Row) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
 
toInputType(T) - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
 
toInputType(Long) - Method in class org.apache.beam.sdk.schemas.logicaltypes.Time
 
toInputType(BaseT) - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
Convert the Java type used by the base Schema.FieldType to the input type.
ToJson<T> - Class in org.apache.beam.sdk.transforms
Experimental
tokenNames - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
Deprecated.
tokenNames - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
Deprecated.
toLong(DateTime, Schema, LogicalType) - Method in class org.apache.beam.sdk.coders.AvroCoder.JodaTimestampConversion
 
Top - Class in org.apache.beam.sdk.transforms
PTransforms for finding the largest (or smallest) set of elements in a PCollection, or the largest (or smallest) set of values associated with each key in a PCollection of KVs.
Top.Largest<T extends java.lang.Comparable<? super T>> - Class in org.apache.beam.sdk.transforms
Deprecated.
use Top.Natural instead
Top.Natural<T extends java.lang.Comparable<? super T>> - Class in org.apache.beam.sdk.transforms
A Serializable Comparator that that uses the compared elements' natural ordering.
Top.Reversed<T extends java.lang.Comparable<? super T>> - Class in org.apache.beam.sdk.transforms
Serializable Comparator that that uses the reverse of the compared elements' natural ordering.
Top.Smallest<T extends java.lang.Comparable<? super T>> - Class in org.apache.beam.sdk.transforms
Deprecated.
use Top.Reversed instead
Top.TopCombineFn<T,ComparatorT extends java.util.Comparator<T> & java.io.Serializable> - Class in org.apache.beam.sdk.transforms
CombineFn for Top transforms that combines a bunch of Ts into a single count-long List<T>, using compareFn to choose the largest Ts.
TopCombineFn(int, ComparatorT) - Constructor for class org.apache.beam.sdk.transforms.Top.TopCombineFn
 
toResource(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
toResource(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.AvroIO.Write
toResource(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
toResource(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.TextIO.Write
toResource(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
toRow(Schema) - Static method in class org.apache.beam.sdk.values.Row
Creates a Row from the list of values and Row.getSchema().
toRowFunction(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProvider
Given a type, return a function that converts that type to a Row object If no schema exists, returns null.
toRowFunction(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
 
toRowFunction(TypeDescriptor<T>) - Method in interface org.apache.beam.sdk.schemas.SchemaProvider
Given a type, return a function that converts that type to a Row object If no schema exists, returns null.
toRows() - Static method in class org.apache.beam.sdk.schemas.transforms.Convert
Convert a PCollection<InputT> into a PCollection<Row>.
toSchema() - Static method in class org.apache.beam.sdk.schemas.Schema
Collects a stream of Schema.Fields into a Schema.
toString() - Method in class org.apache.beam.sdk.coders.Coder.Context
Deprecated.
 
toString() - Method in class org.apache.beam.sdk.coders.DelegateCoder
 
toString() - Method in class org.apache.beam.sdk.coders.SerializableCoder
 
toString() - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
 
toString() - Method in class org.apache.beam.sdk.coders.StructuralByteArray
 
toString() - Method in class org.apache.beam.sdk.coders.StructuredCoder
 
toString() - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
 
toString() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
 
toString() - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
 
toString() - Method in class org.apache.beam.sdk.io.FileBasedSource
 
toString() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
 
toString() - Method in interface org.apache.beam.sdk.io.fs.ResourceId
Returns the string representation of this ResourceId.
toString() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
 
toString() - Method in class org.apache.beam.sdk.io.range.ByteKey
 
toString() - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
 
toString() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
 
toString() - Method in class org.apache.beam.sdk.io.range.OffsetRange
 
toString() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
 
toString() - Method in class org.apache.beam.sdk.metrics.MetricKey
 
toString() - Method in class org.apache.beam.sdk.metrics.MetricName
 
toString() - Method in class org.apache.beam.sdk.metrics.MetricQueryResults
 
toString() - Method in class org.apache.beam.sdk.metrics.MetricResults
 
toString() - Method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
 
toString() - Method in class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
 
toString() - Method in class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
 
toString() - Method in class org.apache.beam.sdk.Pipeline
 
toString() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
 
toString() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
 
toString(EnumerationType.Value) - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
 
toString() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
 
toString() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType.Value
 
toString() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
 
toString() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
 
toString() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
 
toString() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
toString() - Method in class org.apache.beam.sdk.schemas.Schema.Options
 
toString() - Method in class org.apache.beam.sdk.schemas.Schema
 
toString() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
 
toString() - Method in class org.apache.beam.sdk.schemas.transforms.Cast.Narrowing
 
toString() - Method in class org.apache.beam.sdk.schemas.transforms.Cast.Widening
 
toString() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
toString() - Method in class org.apache.beam.sdk.testing.SuccessOrFailure
 
toString() - Method in class org.apache.beam.sdk.testing.TestPipeline
 
toString() - Method in class org.apache.beam.sdk.transforms.Combine.Holder
 
toString() - Method in class org.apache.beam.sdk.transforms.Contextful
 
toString() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
 
toString() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
 
toString() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
 
toString() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
 
toString() - Method in class org.apache.beam.sdk.transforms.display.DisplayData
 
toString() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
 
toString() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
 
toString() - Method in class org.apache.beam.sdk.transforms.join.RawUnionValue
 
toString() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
 
toString() - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
 
toString() - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.OutputRangeTracker
 
toString() - Method in class org.apache.beam.sdk.transforms.PTransform
 
toString() - Method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
 
toString() - Method in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
 
ToString - Class in org.apache.beam.sdk.transforms
toString() - Method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
 
toString(StateT) - Method in interface org.apache.beam.sdk.transforms.Watch.Growth.TerminationCondition
Creates a human-readable representation of the given state of this condition.
toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterAll
 
toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterEach
 
toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterFirst
 
toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
 
toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
 
toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
 
toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
 
toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
 
toString() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
 
toString() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
 
toString() - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
 
toString() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
 
toString() - Method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
 
toString() - Method in class org.apache.beam.sdk.transforms.windowing.ReshuffleTrigger
Deprecated.
 
toString() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
 
toString() - Method in class org.apache.beam.sdk.util.ExplicitShardedFile
 
toString() - Method in class org.apache.beam.sdk.util.FilePatternMatchingShardedFile
 
toString() - Method in class org.apache.beam.sdk.util.FluentBackoff
 
toString() - Method in class org.apache.beam.sdk.util.NumberedShardedFile
 
toString() - Method in class org.apache.beam.sdk.util.ShardedKey
 
toString() - Method in class org.apache.beam.sdk.util.UnownedInputStream
 
toString() - Method in class org.apache.beam.sdk.util.UnownedOutputStream
 
toString() - Method in class org.apache.beam.sdk.util.WindowedValue
 
toString() - Method in class org.apache.beam.sdk.values.KV
 
toString() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
 
toString() - Method in class org.apache.beam.sdk.values.PValueBase
 
toString() - Method in class org.apache.beam.sdk.values.Row
 
toString() - Method in class org.apache.beam.sdk.values.ShardedKey
 
toString() - Method in class org.apache.beam.sdk.values.TimestampedValue
 
toString() - Method in class org.apache.beam.sdk.values.TupleTag
 
toString() - Method in class org.apache.beam.sdk.values.TupleTagList
 
toString() - Method in class org.apache.beam.sdk.values.TypeDescriptor
 
toString() - Method in class org.apache.beam.sdk.values.TypeParameter
 
toString() - Method in class org.apache.beam.sdk.values.ValueWithRecordId
 
toString() - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
toUnsplittableSource(BoundedSource<T>) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
Returns an equivalent unsplittable BoundedSource<T>.
trace(String, Object...) - Static method in class org.apache.beam.sdk.util.WindowTracing
 
trackerT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewTrackerMethod
Type of the returned RestrictionTracker.
trackerT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.RestrictionTrackerParameter
 
trackerT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
Concrete type of the RestrictionTracker parameter, if present.
transform(Function<T, V>) - Method in class org.apache.beam.sdk.metrics.MetricResult
 
transformContainer(Iterable<FromT>, Function<FromT, DestT>) - Static method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils
 
TransformHierarchy - Class in org.apache.beam.sdk.runners
For internal use only; no backwards-compatibility guarantees.
TransformHierarchy() - Constructor for class org.apache.beam.sdk.runners.TransformHierarchy
 
TransformHierarchy.Node - Class in org.apache.beam.sdk.runners
Provides internal tracking of transform relationships with helper methods for initialization and ordered visitation.
TransformingMap(Map<K1, V1>, Function<K1, K2>, Function<V1, V2>) - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
traverseTopologically(Pipeline.PipelineVisitor) - Method in class org.apache.beam.sdk.Pipeline
For internal use only; no backwards-compatibility guarantees.
Trigger - Class in org.apache.beam.sdk.transforms.windowing
Triggers control when the elements for a specific key and window are output.
Trigger(List<Trigger>) - Constructor for class org.apache.beam.sdk.transforms.windowing.Trigger
 
Trigger() - Constructor for class org.apache.beam.sdk.transforms.windowing.Trigger
 
Trigger.OnceTrigger - Class in org.apache.beam.sdk.transforms.windowing
For internal use only; no backwards-compatibility guarantees.
triggering(Trigger) - Method in class org.apache.beam.sdk.transforms.windowing.Window
Sets a non-default trigger for this Window PTransform.
truncateRestriction() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Details about this DoFn's DoFn.TruncateRestriction method.
TruncateRestrictionMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TruncateRestrictionMethod
 
TruncateResult() - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.TruncateResult
 
tryClaim(Long) - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.OutputRangeTracker
 
tryClaim(ByteKey) - Method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
Attempts to claim the given key.
tryClaim(Long) - Method in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
Attempts to claim the given offset.
tryClaim(PositionT) - Method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker
Attempts to claim the block of work in the current restriction identified by the given position.
tryInvokeSetupFor(DoFn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnInvokers
Tries to invoke setup on the given DoFn.
tryLock() - Method in class org.apache.beam.sdk.util.NoopLock
 
tryLock(long, TimeUnit) - Method in class org.apache.beam.sdk.util.NoopLock
 
tryLoggingMetrics(String, Set<MetricName>, long, boolean) - Method in interface org.apache.beam.sdk.metrics.MetricsLogger
 
tryReturnRecordAt(boolean, ByteKey) - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
 
tryReturnRecordAt(boolean, Long) - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
 
tryReturnRecordAt(boolean, long) - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
 
tryReturnRecordAt(boolean, PositionT) - Method in interface org.apache.beam.sdk.io.range.RangeTracker
Atomically determines whether a record at the given position can be returned and updates internal state.
trySplit(double) - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.OutputRangeTracker
 
trySplit(double) - Method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
 
trySplit(double) - Method in class org.apache.beam.sdk.transforms.splittabledofn.GrowableOffsetRangeTracker
 
trySplit(double) - Method in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
 
trySplit(double) - Method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker
Splits current restriction based on fractionOfRemainder.
trySplitAtPosition(ByteKey) - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
 
trySplitAtPosition(Long) - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
 
trySplitAtPosition(long) - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
 
trySplitAtPosition(PositionT) - Method in interface org.apache.beam.sdk.io.range.RangeTracker
Atomically splits the current range [RangeTracker.getStartPosition(), RangeTracker.getStopPosition()) into a "primary" part [RangeTracker.getStartPosition(), splitPosition) and a "residual" part [splitPosition, RangeTracker.getStopPosition()), assuming the current last-consumed position is within [RangeTracker.getStartPosition(), splitPosition) (i.e., splitPosition has not been consumed yet).
TupleTag<V> - Class in org.apache.beam.sdk.values
A TupleTag is a typed tag to use as the key of a heterogeneously typed tuple, like PCollectionTuple.
TupleTag() - Constructor for class org.apache.beam.sdk.values.TupleTag
Constructs a new TupleTag, with a fresh unique id.
TupleTag(String) - Constructor for class org.apache.beam.sdk.values.TupleTag
Constructs a new TupleTag with the given id.
TupleTagList - Class in org.apache.beam.sdk.values
A TupleTagList is an immutable list of heterogeneously typed TupleTags.
TypeConversion() - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
 
TypeDescriptor<T> - Class in org.apache.beam.sdk.values
A description of a Java type, including actual generic parameters where possible.
TypeDescriptor() - Constructor for class org.apache.beam.sdk.values.TypeDescriptor
Creates a TypeDescriptor representing the type parameter T.
TypeDescriptor(Object) - Constructor for class org.apache.beam.sdk.values.TypeDescriptor
Creates a TypeDescriptor representing the type parameter T, which should resolve to a concrete type in the context of the class clazz.
TypeDescriptor(Class<?>) - Constructor for class org.apache.beam.sdk.values.TypeDescriptor
Creates a TypeDescriptor representing the type parameter T, which should resolve to a concrete type in the context of the class clazz.
TypeDescriptors - Class in org.apache.beam.sdk.values
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.
TypeDescriptors() - Constructor for class org.apache.beam.sdk.values.TypeDescriptors
 
TypeDescriptors.TypeVariableExtractor<InputT,OutputT> - Interface in org.apache.beam.sdk.values
TypedWrite() - Constructor for class org.apache.beam.sdk.io.AvroIO.TypedWrite
 
TypedWrite() - Constructor for class org.apache.beam.sdk.io.TextIO.TypedWrite
 
TypeParameter<T> - Class in org.apache.beam.sdk.values
TypeParameter() - Constructor for class org.apache.beam.sdk.values.TypeParameter
 
typesEqual(Schema.Field) - Method in class org.apache.beam.sdk.schemas.Schema.Field
Returns true if two fields are equal, ignoring name and description.
typesEqual(Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
Returns true if two FieldTypes are equal.
typesEqual(Schema) - Method in class org.apache.beam.sdk.schemas.Schema
Returns true if two schemas are equal ignoring field names and descriptions.

U

unbounded() - Static method in class org.apache.beam.sdk.io.CountingSource
Deprecated.
use GenerateSequence instead
UnboundedReader() - Constructor for class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
 
UnboundedSource<OutputT,CheckpointMarkT extends UnboundedSource.CheckpointMark> - Class in org.apache.beam.sdk.io
A Source that reads an unbounded amount of input and, because of that, supports some additional operations such as checkpointing, watermarks, and record ids.
UnboundedSource() - Constructor for class org.apache.beam.sdk.io.UnboundedSource
 
UnboundedSource.CheckpointMark - Interface in org.apache.beam.sdk.io
A marker representing the progress and state of an UnboundedSource.UnboundedReader.
UnboundedSource.CheckpointMark.NoopCheckpointMark - Class in org.apache.beam.sdk.io
A checkpoint mark that does nothing when finalized.
UnboundedSource.UnboundedReader<OutputT> - Class in org.apache.beam.sdk.io
A Reader that reads an unbounded amount of input.
unboundedWithTimestampFn(SerializableFunction<Long, Instant>) - Static method in class org.apache.beam.sdk.io.CountingSource
unboxedType - Variable in class org.apache.beam.sdk.schemas.utils.ConvertHelpers.ConvertedSchemaInformation
 
union(Iterable<FieldAccessDescriptor>) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
 
union(Contextful...) - Static method in class org.apache.beam.sdk.transforms.Requirements
 
unionAll(PCollection<T>) - Static method in class org.apache.beam.sdk.transforms.Sets
Returns a new PTransform transform that follows SET ALL semantics to compute the unionAll with provided PCollection<T>.
unionAll() - Static method in class org.apache.beam.sdk.transforms.Sets
Returns a new PTransform transform that follows SET ALL semantics which takes a PCollectionList<PCollection<T>> and returns a PCollection<T> containing the unionAll of collections done in order for all collections in PCollectionList<T>.
UnionCoder - Class in org.apache.beam.sdk.transforms.join
A UnionCoder encodes RawUnionValues.
unionDistinct(PCollection<T>) - Static method in class org.apache.beam.sdk.transforms.Sets
Returns a new PTransform transform that follows SET DISTINCT semantics to compute the union with provided PCollection<T>.
unionDistinct() - Static method in class org.apache.beam.sdk.transforms.Sets
Returns a new PTransform transform that follows SET DISTINCT semantics which takes a PCollectionList<PCollection<T>> and returns a PCollection<T> containing the union of collections done in order for all collections in PCollectionList<T>.
unknown() - Static method in class org.apache.beam.sdk.io.fs.MatchResult
unlock() - Method in class org.apache.beam.sdk.util.NoopLock
 
UnownedInputStream - Class in org.apache.beam.sdk.util
A OutputStream wrapper which protects against the user attempting to modify the underlying stream by closing it or using mark.
UnownedInputStream(InputStream) - Constructor for class org.apache.beam.sdk.util.UnownedInputStream
 
UnownedOutputStream - Class in org.apache.beam.sdk.util
A OutputStream wrapper which protects against the user attempting to modify the underlying stream by closing it.
UnownedOutputStream(OutputStream) - Constructor for class org.apache.beam.sdk.util.UnownedOutputStream
 
unwindowedFilename(int, int, FileBasedSink.OutputFileHints) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy
 
unwindowedFilename(int, int, FileBasedSink.OutputFileHints) - Method in class org.apache.beam.sdk.io.FileBasedSink.FilenamePolicy
When a sink has not requested windowed or triggered output, this method will be invoked to return the file resource to be created given the base output directory and a FileBasedSink.OutputFileHints containing information about the file, including a suggested (e.g.
update(long) - Method in class org.apache.beam.sdk.metrics.DelegatingDistribution
 
update(long, long, long, long) - Method in class org.apache.beam.sdk.metrics.DelegatingDistribution
 
update(double) - Method in class org.apache.beam.sdk.metrics.DelegatingHistogram
 
update(long) - Method in interface org.apache.beam.sdk.metrics.Distribution
Add an observation to this distribution.
update(long, long, long, long) - Method in interface org.apache.beam.sdk.metrics.Distribution
 
update(double) - Method in interface org.apache.beam.sdk.metrics.Histogram
Add an observation to this histogram.
update(Object) - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObserver
Updates the observer with a context specified, but without an instance of the Observable.
update(Observable, Object) - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObserver
 
updateSerializedOptions(String, Map<String, String>) - Static method in class org.apache.beam.sdk.options.ValueProviders
Deprecated.
updateWindowingStrategy(WindowingStrategy<?, ?>) - Method in class org.apache.beam.sdk.transforms.GroupByKey
 
upTo(long) - Static method in class org.apache.beam.sdk.io.CountingSource
Deprecated.
use GenerateSequence instead
URN - Static variable in class org.apache.beam.sdk.io.GenerateSequence.External
 
UserAgentFactory() - Constructor for class org.apache.beam.sdk.options.PipelineOptions.UserAgentFactory
 
UserCodeException - Exception in org.apache.beam.sdk.util
An exception that was thrown in user-code.
UsesAttemptedMetrics - Class in org.apache.beam.sdk.testing
Category tag for validation tests which utilize Metrics.
UsesAttemptedMetrics() - Constructor for class org.apache.beam.sdk.testing.UsesAttemptedMetrics
 
usesBagState(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
UsesBoundedSplittableParDo - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize splittable ParDo with a DoFn.BoundedPerElement DoFn.
UsesBundleFinalizer - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which use DoFn.BundleFinalizer.
UsesCommittedMetrics - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize Metrics.
UsesCounterMetrics - Class in org.apache.beam.sdk.testing
Category tag for validation tests which utilize Counter.
UsesCounterMetrics() - Constructor for class org.apache.beam.sdk.testing.UsesCounterMetrics
 
UsesCrossLanguageTransforms - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which use cross-language transforms.
UsesCustomWindowMerging - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize custom window merging.
UsesDistributionMetrics - Class in org.apache.beam.sdk.testing
Category tag for validation tests which utilize Distribution.
UsesDistributionMetrics() - Constructor for class org.apache.beam.sdk.testing.UsesDistributionMetrics
 
UsesFailureMessage - Interface in org.apache.beam.sdk.testing
Category tag for tests which validate that currect failure message is provided by failed pipeline.
UsesGaugeMetrics - Class in org.apache.beam.sdk.testing
Category tag for validation tests which utilize Gauge.
UsesGaugeMetrics() - Constructor for class org.apache.beam.sdk.testing.UsesGaugeMetrics
 
UsesImpulse - Class in org.apache.beam.sdk.testing
Category for tests that use Impulse transformations.
UsesImpulse() - Constructor for class org.apache.beam.sdk.testing.UsesImpulse
 
UsesKeyInParDo - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which use key.
UsesKms - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize --tempRoot from TestPipelineOptions and and expect a default KMS key enable for the bucket specified.
UsesMapState - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize MapState.
usesMapState(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
UsesMetricsPusher - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize the metrics pusher feature.
UsesOnWindowExpiration - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize DoFn.OnWindowExpiration.
UsesOrderedListState - Class in org.apache.beam.sdk.testing
Category tag for validation tests which utilize OrderedListState.
UsesOrderedListState() - Constructor for class org.apache.beam.sdk.testing.UsesOrderedListState
 
usesOrderedListState(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
UsesParDoLifecycle - Interface in org.apache.beam.sdk.testing
Category tag for the ParDoLifecycleTest for exclusion (BEAM-3241).
UsesPythonExpansionService - Interface in org.apache.beam.sdk.testing
Category tag for tests which use the expansion service in Python.
UsesRequiresTimeSortedInput - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilizeDoFn.RequiresTimeSortedInput in stateful ParDo.
UsesSchema - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize schemas.
UsesSetState - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize SetState.
usesSetState(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
UsesSideInputs - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which use sideinputs.
UsesSideInputsWithDifferentCoders - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which use multiple side inputs with different coders.
UsesSplittableParDoWithWindowedSideInputs - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize splittable ParDo and use windowed side inputs.
usesState() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Whether the DoFn described by this signature uses state.
usesState(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
UsesStatefulParDo - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize stateful ParDo.
UsesStrictTimerOrdering - Interface in org.apache.beam.sdk.testing
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 - Interface in org.apache.beam.sdk.testing
Category tag for tests that use System metrics.
UsesTestStream - Interface in org.apache.beam.sdk.testing
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 - Interface in org.apache.beam.sdk.testing
Subcategory for UsesTestStream tests which use TestStream # across multiple stages.
UsesTestStreamWithOutputTimestamp - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which use outputTimestamp.
UsesTestStreamWithProcessingTime - Interface in org.apache.beam.sdk.testing
Subcategory for UsesTestStream tests which use the processing time feature of TestStream.
UsesTimerMap - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which use timerMap.
usesTimers() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
Whether the DoFn described by this signature uses timers.
usesTimers(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
UsesTimersInParDo - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize timers in ParDo.
UsesUnboundedPCollections - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize at least one unbounded PCollection.
UsesUnboundedSplittableParDo - Interface in org.apache.beam.sdk.testing
Category tag for validation tests which utilize splittable ParDo with a DoFn.UnboundedPerElement DoFn.
usesValueState(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
usesWatermarkHold(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
 
using(String...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.Impl
Perform a natural join between the PCollections.
using(Integer...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.Impl
Perform a natural join between the PCollections.
using(FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.transforms.Join.Impl
Perform a natural join between the PCollections.

V

validate() - Method in class org.apache.beam.sdk.io.AvroSource
 
validate() - Method in class org.apache.beam.sdk.io.CompressedSource
Validates that the delegate source is a valid source and that the channel factory is not null.
validate(PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSink
 
validate() - Method in class org.apache.beam.sdk.io.FileBasedSource
 
validate() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
 
validate() - Method in class org.apache.beam.sdk.io.Source
Checks that this source is valid, before it can be used in a pipeline.
validate(PipelineOptions) - Method in class org.apache.beam.sdk.io.WriteFiles
 
validate(Class<T>, PipelineOptions) - Static method in class org.apache.beam.sdk.options.PipelineOptionsValidator
Validates that the passed PipelineOptions conforms to all the validation criteria from the passed in interface.
validate(PipelineOptions) - Method in class org.apache.beam.sdk.transforms.PTransform
Called before running the Pipeline to verify this transform is fully and correctly specified.
validateCli(Class<T>, PipelineOptions) - Static method in class org.apache.beam.sdk.options.PipelineOptionsValidator
Validates that the passed PipelineOptions from command line interface (CLI) conforms to all the validation criteria from the passed in interface.
validateGetOutputTimestamp(WindowFn<T, W>, long) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
Assigns the given timestamp to windows using the specified windowFn, and verifies that result of windowFn.getOutputTime for later windows (as defined by maxTimestamp won't prevent the watermark from passing the end of earlier windows.
validateGetOutputTimestamps(WindowFn<T, W>, TimestampCombiner, List<List<Long>>) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
Verifies that later-ending merged windows from any of the timestamps hold up output of earlier-ending windows, using the provided WindowFn and TimestampCombiner.
validateGetOutputTimestampsWithValue(WindowFn<T, W>, TimestampCombiner, List<List<TimestampedValue<T>>>) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
Verifies that later-ending merged windows from any of the timestampValues hold up output of earlier-ending windows, using the provided WindowFn and TimestampCombiner.
validateGetOutputTimestampWithValue(WindowFn<T, W>, TimestampedValue<T>) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
Assigns the given timestampedValue to windows using the specified windowFn, and verifies that result of windowFn.getOutputTime for later windows (as defined by maxTimestamp won't prevent the watermark from passing the end of earlier windows.
validateJavaBean(List<FieldValueTypeInformation>, List<FieldValueTypeInformation>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
 
validateNonInterferingOutputTimes(WindowFn<T, W>, long) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
Assigns the given timestamp to windows using the specified windowFn, and verifies that result of windowFn.getOutputTimestamp for each window is within the proper bound.
validateNonInterferingOutputTimesWithValue(WindowFn<T, W>, TimestampedValue<T>) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
Assigns the given timestampedValue to windows using the specified windowFn, and verifies that result of windowFn.getOutputTimestamp for each window is within the proper bound.
ValidatesRunner - Interface in org.apache.beam.sdk.testing
Category tag for tests which validate that a Beam runner is correctly implemented.
validateTimestampBounds(Instant) - Static method in class org.apache.beam.sdk.transforms.windowing.BoundedWindow
Validates that a given timestamp is within min and max bounds.
Validation - Annotation Type in org.apache.beam.sdk.options
Validation represents a set of annotations that can be used to annotate getter properties on PipelineOptions with information representing the validation criteria to be used when validating with the PipelineOptionsValidator.
Validation.Required - Annotation Type in org.apache.beam.sdk.options
This criteria specifies that the value must be not null.
validator() - Method in class org.apache.beam.sdk.schemas.transforms.Cast
 
Value(int) - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType.Value
 
Value(EnumerationType.Value, Object) - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
 
value() - Static method in class org.apache.beam.sdk.state.StateSpecs
Create a StateSpec for a single value of type T.
value(Coder<T>) - Static method in class org.apache.beam.sdk.state.StateSpecs
Identical to StateSpecs.value(), but with a coder explicitly supplied.
valueInGlobalWindow(T) - Static method in class org.apache.beam.sdk.util.WindowedValue
Returns a WindowedValue with the given value in the GlobalWindow using the default timestamp and pane.
valueInGlobalWindow(T, PaneInfo) - Static method in class org.apache.beam.sdk.util.WindowedValue
Returns a WindowedValue with the given value in the GlobalWindow using the default timestamp and the specified pane.
ValueInSingleWindow<T> - Class in org.apache.beam.sdk.values
An immutable tuple of value, timestamp, window, and pane.
ValueInSingleWindow() - Constructor for class org.apache.beam.sdk.values.ValueInSingleWindow
 
ValueInSingleWindow.Coder<T> - Class in org.apache.beam.sdk.values
A coder for ValueInSingleWindow.
valueOf(String) - Static method in enum org.apache.beam.sdk.annotations.Experimental.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.coders.CannotProvideCoderException.ReasonCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.io.CompressedSource.CompressionMode
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.io.Compression
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.io.FileBasedSink.CompressionType
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.io.FileBasedSource.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.io.FileIO.ReadMatches.DirectoryTreatment
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.io.fs.EmptyMatchTreatment
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.io.fs.MatchResult.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.io.fs.MoveOptions.StandardMoveOptions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.io.fs.ResolveOptions.StandardResolveOptions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.io.TextIO.CompressionType
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.io.TFRecordIO.CompressionType
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.options.PipelineOptions.CheckEnabled
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.options.SdkHarnessOptions.LogLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.Pipeline.PipelineVisitor.CompositeBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.PipelineResult.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.ListQualifier
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.MapQualifier
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
Return an EnumerationType.Value corresponding to one of the enumeration strings.
valueOf(int) - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
Return an EnumerationType.Value corresponding to one of the enumeration integer values.
valueOf(String) - Static method in enum org.apache.beam.sdk.schemas.Schema.EquivalenceNullablePolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.schemas.Schema.TypeName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.state.TimeDomain
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.testing.SourceTestUtils.ExpectedSplitOutcome
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.testing.TestStream.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.transforms.display.DisplayData.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.transforms.DoFnTester.CloningBehavior
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.IsBounded
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.transforms.windowing.PaneInfo.Timing
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.transforms.windowing.Window.ClosingBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.transforms.windowing.Window.OnTimeBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult.IsException
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.util.RowJson.RowJsonDeserializer.NullBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.values.PCollection.IsBounded
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.beam.sdk.values.WindowingStrategy.AccumulationMode
Returns the enum constant of this type with the specified name.
ValueOrMetadata(boolean, T, MetaT) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadata
 
ValueProvider<T> - Interface in org.apache.beam.sdk.options
A ValueProvider abstracts the notion of fetching a value that may or may not be currently available.
ValueProvider.Deserializer - Class in org.apache.beam.sdk.options
For internal use only; no backwards compatibility guarantees.
ValueProvider.NestedValueProvider<T,X> - Class in org.apache.beam.sdk.options
ValueProvider.NestedValueProvider is an implementation of ValueProvider that allows for wrapping another ValueProvider object.
ValueProvider.RuntimeValueProvider<T> - Class in org.apache.beam.sdk.options
ValueProvider.RuntimeValueProvider is an implementation of ValueProvider that allows for a value to be provided at execution time rather than at graph construction time.
ValueProvider.Serializer - Class in org.apache.beam.sdk.options
For internal use only; no backwards compatibility guarantees.
ValueProvider.StaticValueProvider<T> - Class in org.apache.beam.sdk.options
ValueProvider.StaticValueProvider is an implementation of ValueProvider that allows for a static value to be provided.
ValueProviders - Class in org.apache.beam.sdk.options
Utilities for working with the ValueProvider interface.
values() - Static method in enum org.apache.beam.sdk.annotations.Experimental.Kind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.coders.CannotProvideCoderException.ReasonCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.io.CompressedSource.CompressionMode
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.io.Compression
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.io.FileBasedSink.CompressionType
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.io.FileBasedSource.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.io.FileIO.ReadMatches.DirectoryTreatment
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.io.fs.EmptyMatchTreatment
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.io.fs.MatchResult.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.io.fs.MoveOptions.StandardMoveOptions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.io.fs.ResolveOptions.StandardResolveOptions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.io.TextIO.CompressionType
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.io.TFRecordIO.CompressionType
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.options.PipelineOptions.CheckEnabled
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.options.SdkHarnessOptions.LogLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.Pipeline.PipelineVisitor.CompositeBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.PipelineResult.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.ListQualifier
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.MapQualifier
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier.Kind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.schemas.Schema.EquivalenceNullablePolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.schemas.Schema.TypeName
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
 
values() - Method in interface org.apache.beam.sdk.state.MapState
Returns an Iterable over the values contained in this map.
values() - Static method in enum org.apache.beam.sdk.state.TimeDomain
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.testing.SourceTestUtils.ExpectedSplitOutcome
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.testing.TestStream.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in class org.apache.beam.sdk.transforms.Deduplicate
Returns a deduplication transform that deduplicates values for up to 10 mins within the processing time domain.
values() - Static method in enum org.apache.beam.sdk.transforms.display.DisplayData.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.transforms.DoFnTester.CloningBehavior
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.IsBounded
Returns an array containing the constants of this enum type, in the order they are declared.
Values<V> - Class in org.apache.beam.sdk.transforms
Values<V> takes a PCollection of KV<K, V>s and returns a PCollection<V> of the values.
values() - Static method in enum org.apache.beam.sdk.transforms.windowing.PaneInfo.Timing
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.transforms.windowing.Window.ClosingBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.transforms.windowing.Window.OnTimeBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult.IsException
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.util.RowJson.RowJsonDeserializer.NullBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.values.PCollection.IsBounded
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.beam.sdk.values.WindowingStrategy.AccumulationMode
Returns an array containing the constants of this enum type, in the order they are declared.
ValueState<T> - Interface in org.apache.beam.sdk.state
A ReadableState cell containing a single value.
ValueWithRecordId<ValueT> - Class in org.apache.beam.sdk.values
For internal use only; no backwards compatibility guarantees.
ValueWithRecordId(ValueT, byte[]) - Constructor for class org.apache.beam.sdk.values.ValueWithRecordId
 
ValueWithRecordId.StripIdsDoFn<T> - Class in org.apache.beam.sdk.values
DoFn to turn a ValueWithRecordId<T> back to the value T.
ValueWithRecordId.ValueWithRecordIdCoder<ValueT> - Class in org.apache.beam.sdk.values
A Coder for ValueWithRecordId, using a wrapped value Coder.
ValueWithRecordIdCoder(Coder<ValueT>) - Constructor for class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
 
VarInt - Class in org.apache.beam.sdk.util
Variable-length encoding for integers.
VarInt() - Constructor for class org.apache.beam.sdk.util.VarInt
 
VarIntCoder - Class in org.apache.beam.sdk.coders
A Coder that encodes Integers using between 1 and 5 bytes.
VarLongCoder - Class in org.apache.beam.sdk.coders
A Coder that encodes Longs using between 1 and 10 bytes.
verifyCompatibility(Schema) - Method in class org.apache.beam.sdk.schemas.transforms.Cast
 
verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
 
verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
 
verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
 
verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
 
verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
 
verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
 
verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
 
verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
Throw IncompatibleWindowException if this WindowFn does not perform the same merging as the given $WindowFn.
verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.util.IdentityWindowFn
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.AtomicCoder
Throw Coder.NonDeterministicException if the coding is not deterministic.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.AvroCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.BitSetCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.ByteCoder
Throw Coder.NonDeterministicException if the coding is not deterministic.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.Coder
Throw Coder.NonDeterministicException if the coding is not deterministic.
verifyDeterministic(Coder<?>, String, Iterable<Coder<?>>) - Static method in class org.apache.beam.sdk.coders.Coder
Verifies all of the provided coders are deterministic.
verifyDeterministic(Coder<?>, String, Coder<?>...) - Static method in class org.apache.beam.sdk.coders.Coder
Verifies all of the provided coders are deterministic.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.CustomCoder
Throw Coder.NonDeterministicException if the coding is not deterministic.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.DelegateCoder
Throw Coder.NonDeterministicException if the coding is not deterministic.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.DequeCoder
Deque sizes are always known, so DequeIterable may be deterministic while the general IterableLikeCoder is not.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.DoubleCoder
Throw Coder.NonDeterministicException if the coding is not deterministic.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.DurationCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.FloatCoder
Throw Coder.NonDeterministicException if the coding is not deterministic.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.InstantCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
Throw Coder.NonDeterministicException if the coding is not deterministic.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.KvCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
LengthPrefixCoder is deterministic if the nested Coder is.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.ListCoder
List sizes are always known, so ListIterable may be deterministic while the general IterableLikeCoder is not.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.MapCoder
Throw Coder.NonDeterministicException if the coding is not deterministic.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.NullableCoder
NullableCoder is deterministic if the nested Coder is.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.SerializableCoder
Throw Coder.NonDeterministicException if the coding is not deterministic.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.SetCoder
Throw Coder.NonDeterministicException if the coding is not deterministic.
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.ShardedKeyCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.SnappyCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.VarIntCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.VarLongCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.coders.VoidCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResultCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.testing.TestStream.TestStreamCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindow.Coder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo.PaneInfoCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.util.BitSetCoder
Deprecated.
 
verifyDeterministic() - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.util.WindowedValue.FullWindowedValueCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.util.WindowedValue.ValueOnlyWindowedValueCoder
Deprecated.
 
verifyDeterministic() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow.Coder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadataCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
 
verifyDeterministic() - Method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
 
verifyFieldValue(Object, Schema.FieldType, String) - Static method in class org.apache.beam.sdk.values.SchemaVerification
 
verifyPAssertsSucceeded(Pipeline, PipelineResult) - Static method in class org.apache.beam.sdk.testing.TestPipeline
Verifies all {PAsserts} in the pipeline have been executed and were successful.
verifySchemaSupported(Schema) - Static method in class org.apache.beam.sdk.util.RowJson
Throws RowJson.UnsupportedRowJsonException if schema contains an unsupported field type.
verifyUnmodified() - Method in interface org.apache.beam.sdk.util.MutationDetector
 
via(Contextful<Contextful.Fn<UserT, OutputT>>, Contextful<Contextful.Fn<DestinationT, FileIO.Sink<OutputT>>>) - Method in class org.apache.beam.sdk.io.FileIO.Write
Specifies how to create a FileIO.Sink for a particular destination and how to map the element type to the sink's output type.
via(Contextful<Contextful.Fn<UserT, OutputT>>, FileIO.Sink<OutputT>) - Method in class org.apache.beam.sdk.io.FileIO.Write
Like FileIO.Write.via(Contextful, Contextful), but uses the same sink for all destinations.
via(Contextful<Contextful.Fn<DestinationT, FileIO.Sink<UserT>>>) - Method in class org.apache.beam.sdk.io.FileIO.Write
Like FileIO.Write.via(Contextful, Contextful), but the output type of the sink is the same as the type of the input collection.
via(FileIO.Sink<UserT>) - Method in class org.apache.beam.sdk.io.FileIO.Write
Like FileIO.Write.via(Contextful), but uses the same FileIO.Sink for all destinations.
via(InferableFunction<? super InputT, ? extends Iterable<OutputT>>) - Static method in class org.apache.beam.sdk.transforms.FlatMapElements
For a InferableFunction<InputT, ? extends Iterable<OutputT>> fn, return a PTransform that applies fn to every element of the input PCollection<InputT> and outputs all of the elements to the output PCollection<OutputT>.
via(SimpleFunction<? super InputT, ? extends Iterable<OutputT>>) - Static method in class org.apache.beam.sdk.transforms.FlatMapElements
Binary compatibility adapter for FlatMapElements.via(ProcessFunction).
via(ProcessFunction<NewInputT, ? extends Iterable<OutputT>>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
For a ProcessFunction<InputT, ? extends Iterable<OutputT>> fn, returns a PTransform that applies fn to every element of the input PCollection<InputT> and outputs all of the elements to the output PCollection<OutputT>.
via(SerializableFunction<NewInputT, ? extends Iterable<OutputT>>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
Binary compatibility adapter for FlatMapElements.via(ProcessFunction).
via(Contextful<Contextful.Fn<NewInputT, Iterable<OutputT>>>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
Like FlatMapElements.via(ProcessFunction), but allows access to additional context.
via(InferableFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.MapElements
For InferableFunction<InputT, OutputT> fn, returns a PTransform that takes an input PCollection<InputT> and returns a PCollection<OutputT> containing fn.apply(v) for every element v in the input.
via(SimpleFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.MapElements
Binary compatibility adapter for MapElements.via(InferableFunction).
via(ProcessFunction<NewInputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.MapElements
For a ProcessFunction<InputT, OutputT> fn and output type descriptor, returns a PTransform that takes an input PCollection<InputT> and returns a PCollection<OutputT> containing fn.apply(v) for every element v in the input.
via(SerializableFunction<NewInputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.MapElements
Binary compatibility adapter for MapElements.via(ProcessFunction).
via(Contextful<Contextful.Fn<NewInputT, OutputT>>) - Method in class org.apache.beam.sdk.transforms.MapElements
Like MapElements.via(ProcessFunction), but supports access to context, such as side inputs.
viaRandomKey() - Static method in class org.apache.beam.sdk.transforms.Reshuffle
Deprecated.
Encapsulates the sequence "pair input with unique key, apply Reshuffle.of(), drop the key" commonly used to break fusion.
View - Class in org.apache.beam.sdk.transforms
Transforms for creating PCollectionViews from PCollections (to read them as side inputs).
View.AsIterable<T> - Class in org.apache.beam.sdk.transforms
For internal use only; no backwards-compatibility guarantees.
View.AsList<T> - Class in org.apache.beam.sdk.transforms
For internal use only; no backwards-compatibility guarantees.
View.AsMap<K,V> - Class in org.apache.beam.sdk.transforms
For internal use only; no backwards-compatibility guarantees.
View.AsMultimap<K,V> - Class in org.apache.beam.sdk.transforms
For internal use only; no backwards-compatibility guarantees.
View.AsSingleton<T> - Class in org.apache.beam.sdk.transforms
For internal use only; no backwards-compatibility guarantees.
View.CreatePCollectionView<ElemT,ViewT> - Class in org.apache.beam.sdk.transforms
For internal use only; no backwards-compatibility guarantees.
View.VoidKeyToMultimapMaterialization<T> - Class in org.apache.beam.sdk.transforms
A PTransform which converts all values into KVs with Void keys.
viewAsValues(PCollectionView<V>, Coder<V>) - Static method in class org.apache.beam.sdk.transforms.Reify
Pairs each element in a collection with the value of a side input associated with the element's window.
ViewFn<PrimitiveViewT,ViewT> - Class in org.apache.beam.sdk.transforms
For internal use only; no backwards-compatibility guarantees.
ViewFn() - Constructor for class org.apache.beam.sdk.transforms.ViewFn
 
viewInGlobalWindow(PCollectionView<V>, Coder<V>) - Static method in class org.apache.beam.sdk.transforms.Reify
Returns a PCollection consisting of a single element, containing the value of the given view in the global window.
visit(Pipeline.PipelineVisitor) - Method in class org.apache.beam.sdk.runners.TransformHierarchy
 
visitArrayQualifier(FieldSpecifierNotationParser.ArrayQualifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
Visit a parse tree produced by FieldSpecifierNotationParser.arrayQualifier().
visitArrayQualifier(FieldSpecifierNotationParser.ArrayQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
Visit a parse tree produced by FieldSpecifierNotationParser.arrayQualifier().
visitArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
Visit a parse tree produced by the arrayQualifierList labeled alternative in FieldSpecifierNotationParser.qualifierList().
visitArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
Visit a parse tree produced by the arrayQualifierList labeled alternative in FieldSpecifierNotationParser.qualifierList().
visitDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
Visit a parse tree produced by FieldSpecifierNotationParser.dotExpression().
visitDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
Visit a parse tree produced by FieldSpecifierNotationParser.dotExpression().
visitErrorNode(ErrorNode) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
visitFieldSpecifier(FieldSpecifierNotationParser.FieldSpecifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
Visit a parse tree produced by FieldSpecifierNotationParser.fieldSpecifier().
visitFieldSpecifier(FieldSpecifierNotationParser.FieldSpecifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
Visit a parse tree produced by FieldSpecifierNotationParser.fieldSpecifier().
visitMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
Visit a parse tree produced by FieldSpecifierNotationParser.mapQualifier().
visitMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
Visit a parse tree produced by FieldSpecifierNotationParser.mapQualifier().
visitMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
Visit a parse tree produced by the mapQualifierList labeled alternative in FieldSpecifierNotationParser.qualifierList().
visitMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
Visit a parse tree produced by the mapQualifierList labeled alternative in FieldSpecifierNotationParser.qualifierList().
visitPrimitiveTransform(TransformHierarchy.Node) - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
 
visitPrimitiveTransform(TransformHierarchy.Node) - Method in interface org.apache.beam.sdk.Pipeline.PipelineVisitor
Called for each primitive transform after all of its topological predecessors and inputs have been visited.
visitQualifiedComponent(FieldSpecifierNotationParser.QualifiedComponentContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
visitQualifiedComponent(FieldSpecifierNotationParser.QualifiedComponentContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
visitQualifyComponent(FieldSpecifierNotationParser.QualifyComponentContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
Visit a parse tree produced by the qualifyComponent labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
visitQualifyComponent(FieldSpecifierNotationParser.QualifyComponentContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
Visit a parse tree produced by the qualifyComponent labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
visitSimpleIdentifier(FieldSpecifierNotationParser.SimpleIdentifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
Visit a parse tree produced by the simpleIdentifier labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
visitSimpleIdentifier(FieldSpecifierNotationParser.SimpleIdentifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
Visit a parse tree produced by the simpleIdentifier labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
visitTerminal(TerminalNode) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
visitValue(PValue, TransformHierarchy.Node) - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
 
visitValue(PValue, TransformHierarchy.Node) - Method in interface org.apache.beam.sdk.Pipeline.PipelineVisitor
Called for each value after the transform that produced the value has been visited.
visitWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
Visit a parse tree produced by the wildcard labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
visitWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
Visit a parse tree produced by the wildcard labeled alternative in FieldSpecifierNotationParser.dotExpressionComponent().
VOCABULARY - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
VOCABULARY - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
VoidCoder - Class in org.apache.beam.sdk.coders
A Coder for Void.
VoidKeyToMultimapMaterialization() - Constructor for class org.apache.beam.sdk.transforms.View.VoidKeyToMultimapMaterialization
 
voids() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
 

W

Wait - Class in org.apache.beam.sdk.transforms
Delays processing of each window in a PCollection until signaled.
Wait() - Constructor for class org.apache.beam.sdk.transforms.Wait
 
Wait.OnSignal<T> - Class in org.apache.beam.sdk.transforms
waitUntilFinish(Duration) - Method in interface org.apache.beam.sdk.PipelineResult
Waits until the pipeline finishes and returns the final status.
waitUntilFinish() - Method in interface org.apache.beam.sdk.PipelineResult
Waits until the pipeline finishes and returns the final status.
WallTime(Instant) - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.WallTime
 
Watch - Class in org.apache.beam.sdk.transforms
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() - Constructor for class org.apache.beam.sdk.transforms.Watch
 
Watch.Growth<InputT,OutputT,KeyT> - Class in org.apache.beam.sdk.transforms
Watch.Growth.PollFn<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
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> - Class in org.apache.beam.sdk.transforms
The result of a single invocation of a Watch.Growth.PollFn.
Watch.Growth.TerminationCondition<InputT,StateT> - Interface in org.apache.beam.sdk.transforms
A strategy for determining whether it is time to stop polling the current input regardless of whether its output is complete or not.
watchForNewFiles(Duration, Watch.Growth.TerminationCondition<String, ?>) - Method in class org.apache.beam.sdk.io.AvroIO.Parse
Like Read#watchForNewFiles.
watchForNewFiles(Duration, Watch.Growth.TerminationCondition<String, ?>) - Method in class org.apache.beam.sdk.io.AvroIO.ParseAll
Deprecated.
Like Read#watchForNewFiles.
watchForNewFiles(Duration, Watch.Growth.TerminationCondition<String, ?>) - Method in class org.apache.beam.sdk.io.AvroIO.Read
Continuously watches for new files matching the filepattern, polling it at the given interval, until the given termination condition is reached.
watchForNewFiles(Duration, Watch.Growth.TerminationCondition<String, ?>) - Method in class org.apache.beam.sdk.io.AvroIO.ReadAll
Deprecated.
Like Read#watchForNewFiles.
watchForNewFiles(Duration, Watch.Growth.TerminationCondition<String, ?>) - Method in class org.apache.beam.sdk.io.TextIO.Read
watchForNewFiles(Duration, Watch.Growth.TerminationCondition<String, ?>) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
Deprecated.
Same as Read#watchForNewFiles(Duration, TerminationCondition).
watermarkEstimator() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
If this is a splittable DoFn, returns the associated WatermarkEstimator with the current call.
watermarkEstimator() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
watermarkEstimator() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
watermarkEstimator(TypeDescriptor<?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
WatermarkEstimator<WatermarkEstimatorStateT> - Interface in org.apache.beam.sdk.transforms.splittabledofn
A WatermarkEstimator which is used for estimating output watermarks of a splittable DoFn.
WatermarkEstimators - Class in org.apache.beam.sdk.transforms.splittabledofn
A set of WatermarkEstimators that users can use to advance the output watermark for their associated splittable DoFns.
WatermarkEstimators.Manual - Class in org.apache.beam.sdk.transforms.splittabledofn
Concrete implementation of a ManualWatermarkEstimator.
WatermarkEstimators.MonotonicallyIncreasing - Class in org.apache.beam.sdk.transforms.splittabledofn
A watermark estimator that observes timestamps of records output from a DoFn reporting the timestamp of the last element seen as the current watermark.
WatermarkEstimators.WallTime - Class in org.apache.beam.sdk.transforms.splittabledofn
A watermark estimator that tracks wall time.
watermarkEstimatorState() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
If this is a splittable DoFn, returns the associated watermark estimator state with the current call.
watermarkEstimatorState() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
watermarkEstimatorState() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
watermarkEstimatorState(TypeDescriptor<?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
watermarkEstimatorStateT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialWatermarkEstimatorStateMethod
Type of the returned watermark estimator state.
watermarkEstimatorT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewWatermarkEstimatorMethod
Type of the returned WatermarkEstimator.
watermarkEstimatorT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
Concrete type of the WatermarkEstimator parameter, if present.
WatermarkEvent() - Constructor for class org.apache.beam.sdk.testing.TestStream.WatermarkEvent
 
WatermarkHoldState - Interface in org.apache.beam.sdk.state
For internal use only; no backwards-compatibility guarantees.
watermarkStateInternal(TimestampCombiner) - Static method in class org.apache.beam.sdk.state.StateSpecs
For internal use only; no backwards-compatibility guarantees.
weeks(int, int) - Static method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows
Returns a WindowFn that windows elements into periods measured by weeks.
Weighted - Interface in org.apache.beam.sdk.util
Interface representing an object that has a weight, in unspecified units.
WeightedValue<T> - Class in org.apache.beam.sdk.util
A T with an accompanying weight.
where(TypeParameter<X>, TypeDescriptor<X>) - Method in class org.apache.beam.sdk.values.TypeDescriptor
Returns a new TypeDescriptor where the type variable represented by typeParameter are substituted by type.
where(Type, Type) - Method in class org.apache.beam.sdk.values.TypeDescriptor
A more general form of TypeDescriptor.where(TypeParameter, TypeDescriptor) that returns a new TypeDescriptor by matching formal against actual to resolve type variables in the current TypeDescriptor.
whereFieldId(int, SerializableFunction<FieldT, Boolean>) - Method in class org.apache.beam.sdk.schemas.transforms.Filter.Inner
Set a predicate based on the value of a field, where the field is specified by id.
whereFieldIds(List<Integer>, SerializableFunction<Row, Boolean>) - Method in class org.apache.beam.sdk.schemas.transforms.Filter.Inner
Set a predicate based on the value of multipled fields, specified by id.
whereFieldName(String, SerializableFunction<FieldT, Boolean>) - Method in class org.apache.beam.sdk.schemas.transforms.Filter.Inner
Set a predicate based on the value of a field, where the field is specified by name.
whereFieldNames(List<String>, SerializableFunction<Row, Boolean>) - Method in class org.apache.beam.sdk.schemas.transforms.Filter.Inner
Set a predicate based on the value of multipled fields, specified by name.
widening(Schema) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
 
Widening() - Constructor for class org.apache.beam.sdk.schemas.transforms.Cast.Widening
 
WILDCARD - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
WILDCARD - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
WILDCARD() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.WildcardContext
 
WildcardContext(FieldSpecifierNotationParser.DotExpressionComponentContext) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.WildcardContext
 
wildcardToRegexp(String) - Static method in class org.apache.beam.sdk.io.FileSystemUtils
Expands glob expressions to regular expressions.
window() - Method in interface org.apache.beam.sdk.state.StateContext
Returns the window corresponding to the state.
window() - Method in class org.apache.beam.sdk.transforms.DoFn.OnTimerContext
Returns the window in which the timer is firing.
window() - Method in class org.apache.beam.sdk.transforms.DoFn.OnWindowExpirationContext
Returns the window in which the window expiration is firing.
window() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
Construct the BoundedWindow to use within a DoFn that needs it.
window() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
 
window() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
 
Window<T> - Class in org.apache.beam.sdk.transforms.windowing
Window logically divides up or groups the elements of a PCollection into finite windows according to a WindowFn.
Window() - Constructor for class org.apache.beam.sdk.transforms.windowing.Window
 
window() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn.AssignContext
Returns the window of the current element prior to this WindowFn being called.
Window.Assign<T> - Class in org.apache.beam.sdk.transforms.windowing
A Primitive PTransform that assigns windows to elements based on a WindowFn.
Window.ClosingBehavior - Enum in org.apache.beam.sdk.transforms.windowing
Specifies the conditions under which a final pane will be created when a window is permanently closed.
Window.OnTimeBehavior - Enum in org.apache.beam.sdk.transforms.windowing
Specifies the conditions under which an on-time pane will be created when a window is closed.
windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
 
windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
 
windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
 
windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
 
windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
 
windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
 
windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
 
windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
Returns the Coder used for serializing the windows used by this windowFn.
windowCoder() - Method in class org.apache.beam.sdk.util.IdentityWindowFn
 
WindowedContext() - Constructor for class org.apache.beam.sdk.transforms.DoFn.WindowedContext
 
windowedFilename(int, int, BoundedWindow, PaneInfo, FileBasedSink.OutputFileHints) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy
 
windowedFilename(int, int, BoundedWindow, PaneInfo, FileBasedSink.OutputFileHints) - Method in class org.apache.beam.sdk.io.FileBasedSink.FilenamePolicy
When a sink has requested windowed or triggered output, this method will be invoked to return the file resource to be created given the base output directory and a FileBasedSink.OutputFileHints containing information about the file, including a suggested extension (e.g.
windowedMultiReceiver(DoFn<?, ?>.WindowedContext, Map<TupleTag<?>, Coder<?>>) - Static method in class org.apache.beam.sdk.transforms.DoFnOutputReceivers
Returns a DoFn.MultiOutputReceiver that delegates to a DoFn.WindowedContext.
windowedMultiReceiver(DoFn<?, ?>.WindowedContext) - Static method in class org.apache.beam.sdk.transforms.DoFnOutputReceivers
Returns a DoFn.MultiOutputReceiver that delegates to a DoFn.WindowedContext.
windowedReceiver(DoFn<?, ?>.WindowedContext, TupleTag<T>) - Static method in class org.apache.beam.sdk.transforms.DoFnOutputReceivers
Returns a DoFn.OutputReceiver that delegates to a DoFn.WindowedContext.
WindowedValue<T> - Class in org.apache.beam.sdk.util
An immutable triple of value, timestamp, and windows.
WindowedValue() - Constructor for class org.apache.beam.sdk.util.WindowedValue
 
WindowedValue.FullWindowedValueCoder<T> - Class in org.apache.beam.sdk.util
Coder for WindowedValue.
WindowedValue.ParamWindowedValueCoder<T> - Class in org.apache.beam.sdk.util
A parameterized coder for WindowedValue.
WindowedValue.SingleWindowedValue - Interface in org.apache.beam.sdk.util
A WindowedValue which holds exactly single window per value.
WindowedValue.ValueOnlyWindowedValueCoder<T> - Class in org.apache.beam.sdk.util
Deprecated.
Use ParamWindowedValueCoder instead, it is a general purpose implementation of the same concept but makes timestamp, windows and pane info configurable.
WindowedValue.WindowedValueCoder<T> - Class in org.apache.beam.sdk.util
Abstract class for WindowedValue coder.
windowedWrites - Variable in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
Whether windowed writes are being used.
WindowFn<T,W extends BoundedWindow> - Class in org.apache.beam.sdk.transforms.windowing
The argument to the Window transform used to assign elements into windows and to determine how windows are merged.
WindowFn() - Constructor for class org.apache.beam.sdk.transforms.windowing.WindowFn
 
WindowFn.AssignContext - Class in org.apache.beam.sdk.transforms.windowing
WindowFn.MergeContext - Class in org.apache.beam.sdk.transforms.windowing
WindowFnTestUtils - Class in org.apache.beam.sdk.testing
A utility class for testing WindowFns.
WindowFnTestUtils() - Constructor for class org.apache.beam.sdk.testing.WindowFnTestUtils
 
WindowingStrategy<T,W extends BoundedWindow> - Class in org.apache.beam.sdk.values
A WindowingStrategy describes the windowing behavior for a specific collection of values.
WindowingStrategy.AccumulationMode - Enum in org.apache.beam.sdk.values
The accumulation modes that can be used with windowing.
WindowMappingFn<TargetWindowT extends BoundedWindow> - Class in org.apache.beam.sdk.transforms.windowing
Experimental! This will be ready for users eventually, but should be considered internal for now.
WindowMappingFn() - Constructor for class org.apache.beam.sdk.transforms.windowing.WindowMappingFn
Create a new WindowMappingFn with zero maximum lookback.
WindowMappingFn(Duration) - Constructor for class org.apache.beam.sdk.transforms.windowing.WindowMappingFn
Create a new WindowMappingFn with the specified maximum lookback.
windowOnlyContext(W) - Static method in class org.apache.beam.sdk.state.StateContexts
 
windows() - Static method in class org.apache.beam.sdk.transforms.Reify
Create a PTransform that will reify information from the processing context into instances of ValueInSingleWindow.
windows() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn.MergeContext
Returns the current set of windows.
windowsInValue() - Static method in class org.apache.beam.sdk.transforms.Reify
Create a PTransform that will output all input KVs with the window pane info inside the value.
windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.BundleMethod
The type of window expected by this method, if any.
windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialRestrictionMethod
The window type used by this method, if any.
windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialWatermarkEstimatorStateMethod
The window type used by this method, if any.
windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetSizeMethod
The window type used by this method, if any.
windowT() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.MethodWithExtraParameters
The type of window expected by this method, if any.
windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewTrackerMethod
The window type used by this method, if any.
windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewWatermarkEstimatorMethod
The window type used by this method, if any.
windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerFamilyMethod
The window type used by this method, if any.
windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerMethod
The window type used by this method, if any.
windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnWindowExpirationMethod
The window type used by this method, if any.
windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.WindowParameter
 
windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
The window type used by this method, if any.
windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.SplitRestrictionMethod
The window type used by this method, if any.
windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TruncateRestrictionMethod
The window type used by this method, if any.
WindowTracing - Class in org.apache.beam.sdk.util
Logging for window operations.
WindowTracing() - Constructor for class org.apache.beam.sdk.util.WindowTracing
 
with(SimpleFunction<DataT, InputT>, Combine.CombineFn<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposeCombineFnBuilder
Returns a CombineFns.ComposedCombineFn that can take additional GlobalCombineFns and apply them as a single combine function.
with(SimpleFunction<DataT, InputT>, Coder, Combine.CombineFn<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposeCombineFnBuilder
Like #with(SimpleFunction, CombineFn, TupleTag) but with an explicit input coder.
with(SimpleFunction<DataT, InputT>, CombineWithContext.CombineFnWithContext<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposeCombineFnBuilder
Returns a CombineFns.ComposedCombineFnWithContext that can take additional GlobalCombineFns and apply them as a single combine function.
with(SimpleFunction<DataT, InputT>, Coder, CombineWithContext.CombineFnWithContext<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposeCombineFnBuilder
Like #with(SimpleFunction, CombineFnWithContext, TupleTag) but with input coder.
with(SimpleFunction<DataT, InputT>, Combine.CombineFn<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
Returns a CombineFns.ComposedCombineFn with an additional Combine.CombineFn.
with(SimpleFunction<DataT, InputT>, CombineWithContext.CombineFnWithContext<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
with(SimpleFunction<DataT, InputT>, Coder, Combine.CombineFn<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
Returns a CombineFns.ComposedCombineFn with an additional Combine.CombineFn.
with(SimpleFunction<DataT, InputT>, Coder, CombineWithContext.CombineFnWithContext<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
with(SimpleFunction<DataT, InputT>, CombineFnBase.GlobalCombineFn<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
with(SimpleFunction<DataT, InputT>, Coder<InputT>, CombineFnBase.GlobalCombineFn<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
withAccumulatorCoder(CombineFnBase.GlobalCombineFn<? super InputT, AccumT, OutputT>, Coder<AccumT>) - Static method in class org.apache.beam.sdk.util.AppliedCombineFn
 
withAccumulatorCoder(CombineFnBase.GlobalCombineFn<? super InputT, AccumT, OutputT>, Coder<AccumT>, Iterable<PCollectionView<?>>, KvCoder<K, InputT>, WindowingStrategy<?, ?>) - Static method in class org.apache.beam.sdk.util.AppliedCombineFn
 
withAllFields() - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
 
withAllowedLateness(Duration) - Method in class org.apache.beam.sdk.transforms.windowing.Window
Override the amount of lateness allowed for data elements in the output PCollection and downstream PCollections until explicitly set again.
withAllowedLateness(Duration, Window.ClosingBehavior) - Method in class org.apache.beam.sdk.transforms.windowing.Window
Override the amount of lateness allowed for data elements in the pipeline.
withAllowedLateness(Duration) - Method in class org.apache.beam.sdk.values.WindowingStrategy
Returns a WindowingStrategy identical to this but with the allowed lateness set to allowedLateness.
withAllowedTimestampSkew(Duration) - Method in class org.apache.beam.sdk.transforms.WithTimestamps
Deprecated.
This method permits a to elements to be emitted behind the watermark. These elements are considered late, and if behind the allowed lateness of a downstream PCollection may be silently dropped. See https://issues.apache.org/jira/browse/BEAM-644 for details on a replacement.
withAlreadyMerged(boolean) - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
withArg(Class<? super ArgT>, ArgT) - Method in class org.apache.beam.sdk.util.InstanceBuilder
Adds an argument to be passed to the factory method.
withBaseFilename(ResourceId) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
Sets the base filename.
withBaseFilename(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
withBeamSchemas(boolean) - Method in class org.apache.beam.sdk.io.AvroIO.Read
If set to true, a Beam schema will be inferred from the AVRO schema.
withBeamSchemas(boolean) - Method in class org.apache.beam.sdk.io.AvroIO.ReadAll
Deprecated.
If set to true, a Beam schema will be inferred from the AVRO schema.
withBeamSchemas(boolean) - Method in class org.apache.beam.sdk.io.AvroIO.ReadFiles
If set to true, a Beam schema will be inferred from the AVRO schema.
withClosingBehavior(Window.ClosingBehavior) - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
withCodec(CodecFactory) - Method in class org.apache.beam.sdk.io.AvroIO.Sink
Specifies to use the given CodecFactory for each generated file.
withCodec(CodecFactory) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Writes to Avro file(s) compressed using specified codec.
withCodec(CodecFactory) - Method in class org.apache.beam.sdk.io.AvroIO.Write
withCoder(Coder<T>) - Method in class org.apache.beam.sdk.io.AvroIO.Parse
Sets a coder for the result of the parse function.
withCoder(Coder<T>) - Method in class org.apache.beam.sdk.io.AvroIO.ParseAll
Deprecated.
Specifies the coder for the result of the parseFn.
withCoder(Coder<T>) - Method in class org.apache.beam.sdk.io.AvroIO.ParseFiles
Specifies the coder for the result of the parseFn.
withCoder(Coder<T>) - Method in class org.apache.beam.sdk.transforms.Create.TimestampedValues
Returns a Create.TimestampedValues PTransform like this one that uses the given Coder<T> to decode each of the objects into a value of type T.
withCoder(Coder<T>) - Method in class org.apache.beam.sdk.transforms.Create.Values
Returns a Create.Values PTransform like this one that uses the given Coder<T> to decode each of the objects into a value of type T.
withCompression(Compression) - Method in class org.apache.beam.sdk.io.CompressedSource
withCompression(Compression) - Method in class org.apache.beam.sdk.io.FileIO.ReadMatches
Reads files using the given Compression.
withCompression(Compression) - Method in class org.apache.beam.sdk.io.FileIO.Write
Specifies to compress all generated shard files using the given Compression and, by default, append the respective extension to the filename.
withCompression(Compression) - Method in class org.apache.beam.sdk.io.TextIO.Read
Reads from input sources using the specified compression type.
withCompression(Compression) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
Deprecated.
Reads from input sources using the specified compression type.
withCompression(Compression) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Returns a transform for writing to text files like this one but that compresses output using the given Compression.
withCompression(Compression) - Method in class org.apache.beam.sdk.io.TextIO.Write
withCompression(Compression) - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
Returns a transform for reading TFRecord files that decompresses all input files using the specified compression type.
withCompression(Compression) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
Writes to output files using the specified compression type.
withCompressionType(TextIO.CompressionType) - Method in class org.apache.beam.sdk.io.TextIO.Read
withCompressionType(TextIO.CompressionType) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
withCompressionType(TFRecordIO.CompressionType) - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
withCompressionType(TFRecordIO.CompressionType) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
withConfiguration(FileIO.MatchConfiguration) - Method in class org.apache.beam.sdk.io.FileIO.Match
withConfiguration(FileIO.MatchConfiguration) - Method in class org.apache.beam.sdk.io.FileIO.MatchAll
withDatumReaderFactory(AvroSource.DatumReaderFactory<T>) - Method in class org.apache.beam.sdk.io.AvroIO.ReadFiles
 
withDatumReaderFactory(AvroSource.DatumReaderFactory<?>) - Method in class org.apache.beam.sdk.io.AvroSource
 
withDatumWriterFactory(AvroSink.DatumWriterFactory<OutputT>) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Specifies a AvroSink.DatumWriterFactory to use for creating DatumWriter instances.
withDatumWriterFactory(AvroSink.DatumWriterFactory<T>) - Method in class org.apache.beam.sdk.io.AvroIO.Write
withDecompression(CompressedSource.DecompressingChannelFactory) - Method in class org.apache.beam.sdk.io.CompressedSource
Return a CompressedSource that is like this one but will decompress its underlying file with the given CompressedSource.DecompressingChannelFactory.
WithDefault() - Constructor for class org.apache.beam.sdk.state.StateSpec.Cases.WithDefault
 
WithDefault() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
 
withDefaultValue(T) - Method in class org.apache.beam.sdk.transforms.View.AsSingleton
Default value to return for windows with no value in them.
withDelimiter(byte[]) - Method in class org.apache.beam.sdk.io.TextIO.Read
Set the custom delimiter to be used in place of the default ones ('\r', '\n' or '\r\n').
withDelimiter(byte[]) - Method in class org.apache.beam.sdk.io.TextIO.ReadFiles
Like Read#withDelimiter.
withDelimiter(char[]) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Specifies the delimiter after each string written.
withDelimiter(char[]) - Method in class org.apache.beam.sdk.io.TextIO.Write
withDescription(String) - Method in class org.apache.beam.sdk.schemas.Schema.Field
Returns a copy of the Field with the description set.
withDestinationCoder(Coder<DestinationT>) - Method in class org.apache.beam.sdk.io.FileIO.Write
Specifies a Coder for the destination type, if it can not be inferred from FileIO.Write.by(org.apache.beam.sdk.transforms.SerializableFunction<UserT, DestinationT>).
withDirectoryTreatment(FileIO.ReadMatches.DirectoryTreatment) - Method in class org.apache.beam.sdk.io.FileIO.ReadMatches
Controls how to handle directories in the input PCollection.
withDropNullsOnWrite(Boolean) - Method in class org.apache.beam.sdk.util.RowJson.RowJsonSerializer
Serializer drops nulls on write if set to true instead of writing fieldName: null.
withDuration(Duration) - Method in class org.apache.beam.sdk.transforms.Deduplicate.KeyedValues
Returns a KeyedValues PTransform like this one but with the specified duration.
withDuration(Duration) - Method in class org.apache.beam.sdk.transforms.Deduplicate.Values
Returns a Values PTransform like this one but with the specified duration.
withDuration(Duration) - Method in class org.apache.beam.sdk.transforms.Deduplicate.WithRepresentativeValues
Return a WithRepresentativeValues PTransform that is like this one, but with the specified deduplication duration.
withEarlyFirings(Trigger.OnceTrigger) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
 
withEarlyFirings(Trigger.OnceTrigger) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
Creates a new Trigger like the this, except that it fires repeatedly whenever the given Trigger fires before the watermark has passed the end of the window.
withEmptyGlobalWindowDestination(DestinationT) - Method in class org.apache.beam.sdk.io.FileIO.Write
If FileIO.Write.withIgnoreWindowing() is specified, specifies a destination to be used in case the collection is empty, to generate the (only, empty) output file.
withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.AvroIO.Parse
Like Read#withEmptyMatchTreatment.
withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.AvroIO.ParseAll
Deprecated.
Like Read#withEmptyMatchTreatment.
withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.AvroIO.Read
Configures whether or not a filepattern matching no files is allowed.
withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.AvroIO.ReadAll
Deprecated.
Like Read#withEmptyMatchTreatment.
withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.AvroSource
 
withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.FileIO.Match
withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.FileIO.MatchAll
withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.FileIO.MatchConfiguration
withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.TextIO.Read
withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
Deprecated.
Same as Read#withEmptyMatchTreatment.
withEndKey(ByteKey) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
Returns new ByteKeyRange like this one, but with the specified end key.
withEnvironmentId(String) - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
withEpsilon(double) - Method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
Returns an ApproximateQuantilesCombineFn that's like this one except that it uses the specified epsilon value.
withExceptionReporting(Schema) - Static method in class org.apache.beam.sdk.transforms.JsonToRow
Enable Exception Reporting support.
withExponent(double) - Method in class org.apache.beam.sdk.util.FluentBackoff
Returns a copy of this FluentBackoff that instead uses the specified exponent to control the exponential growth of delay.
withExtendedErrorInfo() - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
Adds the error message to the returned error Row.
WithFailures - Class in org.apache.beam.sdk.transforms
A collection of utilities for writing transforms that can handle exceptions raised during processing of elements.
WithFailures() - Constructor for class org.apache.beam.sdk.transforms.WithFailures
 
WithFailures.ExceptionAsMapHandler<T> - Class in org.apache.beam.sdk.transforms
A simple handler that extracts information from an exception to a Map<String, String> and returns a KV where the key is the input element that failed processing, and the value is the map of exception attributes.
WithFailures.ExceptionElement<T> - Class in org.apache.beam.sdk.transforms
The value type passed as input to exception handlers.
WithFailures.Result<OutputT extends POutput,FailureElementT> - Class in org.apache.beam.sdk.transforms
An intermediate output type for PTransforms that allows an output collection to live alongside a collection of elements that failed the transform.
withFanout(int) - Method in class org.apache.beam.sdk.transforms.Combine.Globally
Returns a PTransform identical to this, but that uses an intermediate node to combine parts of the data to reduce load on the final global combine step.
withFieldAccessDescriptors(Map<FieldAccessDescriptor, Object>) - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
Sets field values using the FieldAccessDescriptors.
withFieldIds(FieldAccessDescriptor, Integer...) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return a descriptor that accesses the specified field ids as nested subfields of the baseDescriptor.
withFieldIds(FieldAccessDescriptor, Iterable<Integer>) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return a descriptor that accesses the specified field ids as nested subfields of the baseDescriptor.
withFieldIds(Integer...) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return a descriptor that access the specified fields.
withFieldIds(Iterable<Integer>) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return a descriptor that access the specified fields.
withFieldNameAs(String, String) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Add a field with a new name.
withFieldNameAs(String, String) - Method in class org.apache.beam.sdk.schemas.transforms.Select.Fields
Add a single field to the selection, along with the name the field should take in the selected schema.
withFieldNameAs(String, String) - Method in class org.apache.beam.sdk.schemas.transforms.Select.Flattened
Allows renaming a specific nested field.
withFieldNames(String...) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return a descriptor that access the specified fields.
withFieldNames(Iterable<String>) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return a descriptor that access the specified fields.
withFieldNames(FieldAccessDescriptor, String...) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return a descriptor that accesses the specified field names as nested subfields of the baseDescriptor.
withFieldNames(FieldAccessDescriptor, Iterable<String>) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return a descriptor that accesses the specified field names as nested subfields of the baseDescriptor.
withFieldNamesAs(Map<String, String>) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return a descriptor that accesses the specified fields, renaming those fields.
withFields(FieldAccessDescriptor.FieldDescriptor...) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Returns a FieldAccessDescriptor that accesses the specified fields.
withFields(Iterable<FieldAccessDescriptor.FieldDescriptor>) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Returns a FieldAccessDescriptor that accesses the specified fields.
withFieldValue(String, Object) - Method in class org.apache.beam.sdk.values.Row.Builder
Set a field value using the field name.
withFieldValue(Integer, Object) - Method in class org.apache.beam.sdk.values.Row.Builder
Set a field value using the field id.
withFieldValue(FieldAccessDescriptor, Object) - Method in class org.apache.beam.sdk.values.Row.Builder
Set a field value using a FieldAccessDescriptor.
withFieldValue(String, Object) - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
Set a field value using the field name.
withFieldValue(Integer, Object) - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
Set a field value using the field id.
withFieldValue(FieldAccessDescriptor, Object) - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
Set a field value using a FieldAccessDescriptor.
withFieldValueGetters(Factory<List<FieldValueGetter>>, Object) - Method in class org.apache.beam.sdk.values.Row.Builder
 
withFieldValues(Map<String, Object>) - Method in class org.apache.beam.sdk.values.Row.Builder
Sets field values using the field names.
withFieldValues(Map<String, Object>) - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
Sets field values using the field names.
withFn(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.util.DoFnInfo
 
withFooter(String) - Method in class org.apache.beam.sdk.io.TextIO.Sink
 
withFooter(String) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Adds a footer string to each file.
withFooter(String) - Method in class org.apache.beam.sdk.io.TextIO.Write
withFormatFunction(SerializableFunction<UserT, OutputT>) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Specifies a format function to convert UserT to the output type.
withFormatFunction(SerializableFunction<UserT, String>) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Deprecated.
withGapDuration(Duration) - Static method in class org.apache.beam.sdk.transforms.windowing.Sessions
Creates a Sessions WindowFn with the specified gap duration.
withHeader(String) - Method in class org.apache.beam.sdk.io.TextIO.Sink
 
withHeader(String) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Adds a header string to each file.
withHeader(String) - Method in class org.apache.beam.sdk.io.TextIO.Write
withHintMatchesManyFiles() - Method in class org.apache.beam.sdk.io.AvroIO.Parse
Like Read#withHintMatchesManyFiles().
withHintMatchesManyFiles() - Method in class org.apache.beam.sdk.io.AvroIO.Read
Hints that the filepattern specified in AvroIO.Read.from(String) matches a very large number of files.
withHintMatchesManyFiles() - Method in class org.apache.beam.sdk.io.TextIO.Read
Hints that the filepattern specified in TextIO.Read.from(String) matches a very large number of files.
withHotKeyFanout(SerializableFunction<? super K, Integer>) - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
If a single key has disproportionately many values, it may become a bottleneck, especially in streaming mode.
withHotKeyFanout(int) - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
Like Combine.PerKey.withHotKeyFanout(SerializableFunction), but returning the given constant value for every key.
withIgnoreWindowing() - Method in class org.apache.beam.sdk.io.FileIO.Write
Deprecated.
Avoid usage of this method: its effects are complex and it will be removed in future versions of Beam. Right now it exists for compatibility with WriteFiles.
withInitialBackoff(Duration) - Method in class org.apache.beam.sdk.util.FluentBackoff
Returns a copy of this FluentBackoff that instead uses the specified initial backoff duration.
withInputCoder(CombineFnBase.GlobalCombineFn<? super InputT, AccumT, OutputT>, CoderRegistry, KvCoder<K, InputT>) - Static method in class org.apache.beam.sdk.util.AppliedCombineFn
 
withInputCoder(CombineFnBase.GlobalCombineFn<? super InputT, AccumT, OutputT>, CoderRegistry, KvCoder<K, InputT>, Iterable<PCollectionView<?>>, WindowingStrategy<?, ?>) - Static method in class org.apache.beam.sdk.util.AppliedCombineFn
 
withInterval(Duration) - Method in class org.apache.beam.sdk.transforms.PeriodicImpulse
 
withKeyField(String) - Method in class org.apache.beam.sdk.schemas.transforms.CoGroup.Impl
 
withKeyField(String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
 
withKeyField(String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
Set the name of the key field in the resulting schema.
WithKeys<K,V> - Class in org.apache.beam.sdk.transforms
WithKeys<K, V> takes a PCollection<V>, and either a constant key of type K or a function from V to K, and returns a PCollection<KV<K, V>>, where each of the values in the input PCollection has been paired with either the constant key or a key computed from the value.
withKeyType(TypeDescriptor<K>) - Method in class org.apache.beam.sdk.transforms.WithKeys
Return a WithKeys that is like this one with the specified key type descriptor.
withLabel(String) - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
Set the item label.
withLateFirings(Trigger.OnceTrigger) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
 
withLateFirings(Trigger.OnceTrigger) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
Creates a new Trigger like the this, except that it fires repeatedly whenever the given Trigger fires after the watermark has passed the end of the window.
withLinkUrl(String) - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
Set the item link url.
withMatchConfiguration(FileIO.MatchConfiguration) - Method in class org.apache.beam.sdk.io.AvroIO.Parse
withMatchConfiguration(FileIO.MatchConfiguration) - Method in class org.apache.beam.sdk.io.AvroIO.ParseAll
Deprecated.
withMatchConfiguration(FileIO.MatchConfiguration) - Method in class org.apache.beam.sdk.io.AvroIO.Read
withMatchConfiguration(FileIO.MatchConfiguration) - Method in class org.apache.beam.sdk.io.AvroIO.ReadAll
Deprecated.
withMatchConfiguration(FileIO.MatchConfiguration) - Method in class org.apache.beam.sdk.io.TextIO.Read
withMatchConfiguration(FileIO.MatchConfiguration) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
Deprecated.
withMaxBackoff(Duration) - Method in class org.apache.beam.sdk.util.FluentBackoff
Returns a copy of this FluentBackoff that limits the maximum backoff of an individual attempt to the specified duration.
withMaxBufferingDuration(Duration) - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches
Sets a time limit (in processing time) on how long an incomplete batch of elements is allowed to be buffered.
withMaxCumulativeBackoff(Duration) - Method in class org.apache.beam.sdk.util.FluentBackoff
Returns a copy of this FluentBackoff that limits the total time spent in backoff returned across all calls to BackOff.nextBackOffMillis().
withMaxInputSize(long) - Method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
Returns an ApproximateQuantilesCombineFn that's like this one except that it uses the specified maxNumElements value.
withMaxNumRecords(long) - Method in class org.apache.beam.sdk.io.BoundedReadFromUnboundedSource
Returns a new BoundedReadFromUnboundedSource that reads a bounded amount of data from the given UnboundedSource.
withMaxNumRecords(long) - Method in class org.apache.beam.sdk.io.Read.Unbounded
Returns a new BoundedReadFromUnboundedSource that reads a bounded amount of data from the given UnboundedSource.
withMaxNumWritersPerBundle(int) - Method in class org.apache.beam.sdk.io.WriteFiles
Set the maximum number of writers created in a bundle before spilling to shuffle.
withMaxReadTime(Duration) - Method in class org.apache.beam.sdk.io.BoundedReadFromUnboundedSource
Returns a new BoundedReadFromUnboundedSource that reads a bounded amount of data from the given UnboundedSource.
withMaxReadTime(Duration) - Method in class org.apache.beam.sdk.io.GenerateSequence
Specifies to stop generating elements after the given time.
withMaxReadTime(Duration) - Method in class org.apache.beam.sdk.io.Read.Unbounded
Returns a new BoundedReadFromUnboundedSource that reads a bounded amount of data from the given UnboundedSource.
withMaxRetries(int) - Method in class org.apache.beam.sdk.util.FluentBackoff
Returns a copy of this FluentBackoff that limits the total number of retries, aka the total number of calls to BackOff.nextBackOffMillis() before returning BackOff.STOP.
withMetadata(Map<String, Object>) - Method in class org.apache.beam.sdk.io.AvroIO.Sink
Specifies to put the given metadata into each generated file.
withMetadata(Map<String, Object>) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Writes to Avro file(s) with the specified metadata.
withMetadata(Map<String, Object>) - Method in class org.apache.beam.sdk.io.AvroIO.Write
withMetadata(Map<String, byte[]>) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
Deprecated.
use schema options instead.
withMetadata(String, byte[]) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
Deprecated.
use schema options instead.
withMetadata(String, String) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
Deprecated.
use schema options instead.
withMinBundleSize(long) - Method in class org.apache.beam.sdk.io.AvroSource
Sets the minimum bundle size.
withMode(WindowingStrategy.AccumulationMode) - Method in class org.apache.beam.sdk.values.WindowingStrategy
Returns a WindowingStrategy identical to this but with the accumulation mode set to mode.
withName(String) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
 
withName(String) - Method in class org.apache.beam.sdk.schemas.Schema.Field
Returns a copy of the Field with the name set.
withNamespace(Class<?>) - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
Set the item namespace from the given Class.
withNaming(FileIO.Write.FileNaming) - Method in class org.apache.beam.sdk.io.FileIO.Write
Specifies a custom strategy for generating filenames.
withNaming(SerializableFunction<DestinationT, FileIO.Write.FileNaming>) - Method in class org.apache.beam.sdk.io.FileIO.Write
Specifies a custom strategy for generating filenames depending on the destination, similar to FileIO.Write.withNaming(FileNaming).
withNaming(Contextful<Contextful.Fn<DestinationT, FileIO.Write.FileNaming>>) - Method in class org.apache.beam.sdk.io.FileIO.Write
Like FileIO.Write.withNaming(SerializableFunction) but allows accessing context, such as side inputs, from the function.
withNestedField(int, FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return a descriptor that access the specified nested field.
withNestedField(String, FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
Return a descriptor that access the specified nested field.
withNestedField(FieldAccessDescriptor.FieldDescriptor, FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
 
withNestedFieldAs(String, String, FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
withNoSpilling() - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
withNoSpilling() - Method in class org.apache.beam.sdk.io.FileIO.Write
withNoSpilling() - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
withNoSpilling() - Method in class org.apache.beam.sdk.io.TextIO.Write
withNoSpilling() - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
withNoSpilling() - Method in class org.apache.beam.sdk.io.WriteFiles
Returns a new WriteFiles that writes all data without spilling, simplifying the pipeline.
withNullable(boolean) - Method in class org.apache.beam.sdk.schemas.Schema.Field
Returns a copy of the Field with isNullable set.
withNullable(boolean) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
 
withNullBehavior(RowJson.RowJsonDeserializer.NullBehavior) - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
Sets the behavior of the deserializer according to RowJson.RowJsonDeserializer.NullBehavior.
withNullBehavior(RowJson.RowJsonDeserializer.NullBehavior) - Method in class org.apache.beam.sdk.util.RowJson.RowJsonDeserializer
Sets the behaviour of the deserializer when retrieving null values in the input JSON.
withNumBuckets(Integer) - Method in class org.apache.beam.sdk.transforms.Reshuffle.ViaRandomKey
Deprecated.
 
withNumShards(int) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Configures the number of output shards produced overall (when using unwindowed writes) or per-window (when using windowed writes).
withNumShards(int) - Method in class org.apache.beam.sdk.io.AvroIO.Write
withNumShards(int) - Method in class org.apache.beam.sdk.io.FileIO.Write
Specifies to use a given fixed number of shards per window.
withNumShards(ValueProvider<Integer>) - Method in class org.apache.beam.sdk.io.FileIO.Write
withNumShards(int) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Configures the number of output shards produced overall (when using unwindowed writes) or per-window (when using windowed writes).
withNumShards(int) - Method in class org.apache.beam.sdk.io.TextIO.Write
withNumShards(int) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
Writes to the provided number of shards.
withNumShards(int) - Method in class org.apache.beam.sdk.io.WriteFiles
Returns a new WriteFiles that will write to the current FileBasedSink using the specified number of shards.
withNumShards(ValueProvider<Integer>) - Method in class org.apache.beam.sdk.io.WriteFiles
Returns a new WriteFiles that will write to the current FileBasedSink using the ValueProvider specified number of shards.
withOffset(Duration) - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
Partitions the timestamp space into half-open intervals of the form [N * size + offset, (N + 1) * size + offset), where 0 is the epoch.
withOffset(Duration) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
Assigns timestamps into half-open intervals of the form [N * period + offset, N * period + offset + size).
withOnTimeBehavior(Window.OnTimeBehavior) - Method in class org.apache.beam.sdk.transforms.windowing.Window
(Experimental) Override the default Window.OnTimeBehavior, to control whether to output an empty on-time pane.
withOnTimeBehavior(Window.OnTimeBehavior) - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
withOptionalParticipation() - Method in class org.apache.beam.sdk.schemas.transforms.CoGroup.By
Means that this field will participate in a join even when not present, similar to SQL outer-join semantics.
withOptions(Schema.Options) - Method in class org.apache.beam.sdk.schemas.Schema.Field
Returns a copy of the Field with the options set.
withOptions(Schema.Options.Builder) - Method in class org.apache.beam.sdk.schemas.Schema.Field
Returns a copy of the Field with the options set.
withOptions(Schema.Options) - Method in class org.apache.beam.sdk.schemas.Schema
Returns a copy of the Schema with the options set.
withOptions(Schema.Options.Builder) - Method in class org.apache.beam.sdk.schemas.Schema
Returns a copy of the Schema with the options set.
withoutDefaults() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
Returns a PTransform identical to this, but that does not attempt to provide a default value in the case of empty input.
withOutputCoder(Coder<OutputT>) - Method in class org.apache.beam.sdk.transforms.Watch.Growth
Specifies a Coder to use for the outputs.
withOutputFilenames() - Method in class org.apache.beam.sdk.io.AvroIO.Write
Specify that output filenames are wanted.
withOutputFilenames() - Method in class org.apache.beam.sdk.io.TextIO.Write
Specify that output filenames are wanted.
withOutputKeyCoder(Coder<KeyT>) - Method in class org.apache.beam.sdk.transforms.Watch.Growth
Specifies the coder for the output key.
withOutputs(List<TimestampedValue<OutputT>>) - Method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
Returns a new Watch.Growth.PollResult like this one with the provided outputs.
withOutputSchema(Schema) - Method in class org.apache.beam.sdk.schemas.transforms.Select.Fields
Rename all output fields to match the specified schema.
withOutputSchema(Schema) - Method in class org.apache.beam.sdk.schemas.transforms.Select.Flattened
Rename all output fields to match the specified schema.
withOutputTags(TupleTag<OutputT>, TupleTagList) - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
Returns a new multi-output ParDo PTransform that's like this PTransform but with the specified output tags.
withOutputTimestamp(Instant) - Method in interface org.apache.beam.sdk.state.Timer
Sets event time timer's output timestamp.
withoutSharding() - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Forces a single file as output and empty shard name template.
withoutSharding() - Method in class org.apache.beam.sdk.io.AvroIO.Write
withoutSharding() - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Forces a single file as output and empty shard name template.
withoutSharding() - Method in class org.apache.beam.sdk.io.TextIO.Write
withoutSharding() - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
Forces a single file as output.
withoutStrictParsing() - Method in class org.apache.beam.sdk.options.PipelineOptionsFactory.Builder
During parsing of the arguments, we will skip over improperly formatted and unknown arguments.
withoutValidation() - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
Returns a transform for reading TFRecord files that has GCS path validation on pipeline creation disabled.
withParent(Schema.TypeName) - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
 
withParseFn(SerializableFunction<GenericRecord, X>, Coder<X>) - Method in class org.apache.beam.sdk.io.AvroSource
Reads GenericRecord of unspecified schema and maps them to instances of a custom type using the given parseFn and encoded using the given coder.
withPathPart(String) - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
 
withPollInterval(Duration) - Method in class org.apache.beam.sdk.transforms.Watch.Growth
Specifies how long to wait after a call to Watch.Growth.PollFn before calling it again (if at all - according to Watch.Growth.PollResult and the Watch.Growth.TerminationCondition).
withPrefix(String) - Method in class org.apache.beam.sdk.io.FileIO.Write
Specifies a common prefix to use for all generated filenames, if using the default file naming.
withPrefix(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.FileIO.Write
withRate(long, Duration) - Method in class org.apache.beam.sdk.io.GenerateSequence
Specifies to generate at most a given number of elements per a given period.
withRepresentativeCoder(Coder<IdT>) - Method in class org.apache.beam.sdk.transforms.Deduplicate.WithRepresentativeValues
Return a WithRepresentativeValues PTransform that is like this one, but with the specified id type coder.
withRepresentativeType(TypeDescriptor<IdT>) - Method in class org.apache.beam.sdk.transforms.Deduplicate.WithRepresentativeValues
Return a WithRepresentativeValues PTransform that is like this one, but with the specified id type descriptor.
withRepresentativeType(TypeDescriptor<IdT>) - Method in class org.apache.beam.sdk.transforms.Distinct.WithRepresentativeValues
Return a WithRepresentativeValues PTransform that is like this one, but with the specified output type descriptor.
withRepresentativeValueFn(SerializableFunction<T, IdT>) - Static method in class org.apache.beam.sdk.transforms.Deduplicate
Returns a deduplication transform that deduplicates values using the supplied representative value for up to 10 mins within the processing time domain.
withRepresentativeValueFn(SerializableFunction<T, IdT>) - Static method in class org.apache.beam.sdk.transforms.Distinct
Returns a Distinct<T, IdT> PTransform.
withResumeDelay(Duration) - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContinuation
Builder method to set the value of DoFn.ProcessContinuation.resumeDelay().
withRowSchema(Schema) - Method in class org.apache.beam.sdk.transforms.Create.Values
Returns a Create.Values PTransform like this one that uses the given Schema to represent objects.
withRunnerDeterminedSharding() - Method in class org.apache.beam.sdk.io.WriteFiles
Returns a new WriteFiles that will write to the current FileBasedSink with runner-determined sharding.
withRunnerDeterminedShardingUnboundedInternal() - Method in class org.apache.beam.sdk.io.WriteFiles
Returns a new WriteFiles that will write to the current FileBasedSink with runner-determined sharding for unbounded data specifically.
withSchema(Schema) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Sets the the output schema.
withSchema(Schema) - Method in class org.apache.beam.sdk.io.AvroIO.Write
withSchema(String) - Method in class org.apache.beam.sdk.io.AvroSource
Reads files containing records that conform to the given schema.
withSchema(Schema) - Method in class org.apache.beam.sdk.io.AvroSource
withSchema(Class<X>) - Method in class org.apache.beam.sdk.io.AvroSource
Reads files containing records of the given class.
withSchema(Schema, TypeDescriptor<T>, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Method in class org.apache.beam.sdk.transforms.Create.TimestampedValues
Returns a Create.TimestampedValues PTransform like this one that uses the given Schema to represent objects.
withSchema(Schema, TypeDescriptor<T>, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Method in class org.apache.beam.sdk.transforms.Create.Values
Returns a Create.Values PTransform like this one that uses the given Schema to represent objects.
withSchema(Schema) - Static method in class org.apache.beam.sdk.transforms.JsonToRow
 
withSchema(Schema) - Static method in class org.apache.beam.sdk.values.Row
Creates a row builder with specified Row.getSchema().
withSchemaAndNullBehavior(Schema, RowJson.RowJsonDeserializer.NullBehavior) - Static method in class org.apache.beam.sdk.transforms.JsonToRow
 
withShard(int) - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
 
withShardedKey() - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches
Outputs batched elements associated with sharded input keys.
withSharding(PTransform<PCollection<UserT>, PCollectionView<Integer>>) - Method in class org.apache.beam.sdk.io.FileIO.Write
Specifies a PTransform to use for computing the desired number of shards in each window.
withSharding(PTransform<PCollection<UserT>, PCollectionView<Integer>>) - Method in class org.apache.beam.sdk.io.WriteFiles
Returns a new WriteFiles that will write to the current FileBasedSink using the specified PTransform to compute the number of shards.
withShardingFunction(ShardingFunction<UserT, DestinationT>) - Method in class org.apache.beam.sdk.io.WriteFiles
Returns a new WriteFiles that will write to the current FileBasedSink using the specified sharding function to assign shard for inputs.
withShardNameTemplate(String) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Uses the given ShardNameTemplate for naming output files.
withShardNameTemplate(String) - Method in class org.apache.beam.sdk.io.AvroIO.Write
withShardNameTemplate(String) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Uses the given ShardNameTemplate for naming output files.
withShardNameTemplate(String) - Method in class org.apache.beam.sdk.io.TextIO.Write
withShardNameTemplate(String) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
Uses the given shard name template.
withShardTemplate(String) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
Sets the shard template.
withSideInput() - Method in class org.apache.beam.sdk.schemas.transforms.CoGroup.By
 
withSideInput(String, PCollectionView<?>) - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
Returns a new multi-output ParDo PTransform that's like this PTransform but with the specified additional side inputs.
withSideInput(String, PCollectionView<?>) - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
Returns a new ParDo PTransform that's like this PTransform but with the specified additional side inputs.
withSideInputs(List<PCollectionView<?>>) - Method in class org.apache.beam.sdk.io.WriteFiles
 
withSideInputs(PCollectionView<?>...) - Method in class org.apache.beam.sdk.transforms.Combine.Globally
Returns a PTransform identical to this, but with the specified side inputs to use in CombineWithContext.CombineFnWithContext.
withSideInputs(Iterable<? extends PCollectionView<?>>) - Method in class org.apache.beam.sdk.transforms.Combine.Globally
Returns a PTransform identical to this, but with the specified side inputs to use in CombineWithContext.CombineFnWithContext.
withSideInputs(PCollectionView<?>...) - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
 
withSideInputs(Iterable<? extends PCollectionView<?>>) - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
 
withSideInputs(PCollectionView<?>...) - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
Returns a PTransform identical to this, but with the specified side inputs to use in CombineWithContext.CombineFnWithContext.
withSideInputs(Iterable<? extends PCollectionView<?>>) - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
Returns a PTransform identical to this, but with the specified side inputs to use in CombineWithContext.CombineFnWithContext.
withSideInputs(PCollectionView<?>...) - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
Returns a new multi-output ParDo PTransform that's like this PTransform but with the specified additional side inputs.
withSideInputs(Iterable<? extends PCollectionView<?>>) - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
 
withSideInputs(Map<String, PCollectionView<?>>) - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
Returns a new multi-output ParDo PTransform that's like this PTransform but with the specified additional side inputs.
withSideInputs(PCollectionView<?>...) - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
Returns a new ParDo PTransform that's like this PTransform but with the specified additional side inputs.
withSideInputs(Iterable<? extends PCollectionView<?>>) - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
Returns a new ParDo PTransform that's like this PTransform but with the specified additional side inputs.
withSideInputs(Map<String, PCollectionView<?>>) - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
Returns a new ParDo PTransform that's like this PTransform but with the specified additional side inputs.
withSingletonValues() - Method in class org.apache.beam.sdk.transforms.View.AsMap
Deprecated.
this method simply returns this AsMap unmodified
withSize(int) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils.FixedBytesField
Create a AvroUtils.FixedBytesField with the specified size.
withStartingDay(int, int, int) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
 
withStartingMonth(int, int) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
 
withStartingYear(int) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
 
withStartKey(ByteKey) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
Returns new ByteKeyRange like this one, but with the specified start key.
withSuffix(String) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Configures the filename suffix for written files.
withSuffix(String) - Method in class org.apache.beam.sdk.io.AvroIO.Write
withSuffix(String) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
Sets the suffix.
withSuffix(String) - Method in class org.apache.beam.sdk.io.FileIO.Write
Specifies a common suffix to use for all generated filenames, if using the default file naming.
withSuffix(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.FileIO.Write
withSuffix(String) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Configures the filename suffix for written files.
withSuffix(String) - Method in class org.apache.beam.sdk.io.TextIO.Write
withSuffix(String) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
Writes to the file(s) with the given filename suffix.
withTempDirectory(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Set the base directory used to generate temporary files.
withTempDirectory(ResourceId) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Set the base directory used to generate temporary files.
withTempDirectory(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.AvroIO.Write
withTempDirectory(ResourceId) - Method in class org.apache.beam.sdk.io.AvroIO.Write
withTempDirectory(String) - Method in class org.apache.beam.sdk.io.FileIO.Write
Specifies a directory into which all temporary files will be placed.
withTempDirectory(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.FileIO.Write
withTempDirectory(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Set the base directory used to generate temporary files.
withTempDirectory(ResourceId) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Set the base directory used to generate temporary files.
withTempDirectory(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.TextIO.Write
withTempDirectory(ResourceId) - Method in class org.apache.beam.sdk.io.TextIO.Write
withTerminationPerInput(Watch.Growth.TerminationCondition<InputT, ?>) - Method in class org.apache.beam.sdk.transforms.Watch.Growth
Specifies a Watch.Growth.TerminationCondition that will be independently used for every input.
withTimeDomain(TimeDomain) - Method in class org.apache.beam.sdk.transforms.Deduplicate.KeyedValues
Returns a KeyedValues PTransform like this one but with the specified time domain.
withTimeDomain(TimeDomain) - Method in class org.apache.beam.sdk.transforms.Deduplicate.Values
Returns a Values PTransform like this one but with the specified time domain.
withTimeDomain(TimeDomain) - Method in class org.apache.beam.sdk.transforms.Deduplicate.WithRepresentativeValues
Returns a WithRepresentativeValues PTransform like this one but with the specified time domain.
withTimestampCombiner(TimestampCombiner) - Method in class org.apache.beam.sdk.transforms.windowing.Window
(Experimental) Override the default TimestampCombiner, to control the output timestamp of values output from a GroupByKey operation.
withTimestampCombiner(TimestampCombiner) - Method in class org.apache.beam.sdk.values.WindowingStrategy
 
withTimestampFn(SerializableFunction<Long, Instant>) - Method in class org.apache.beam.sdk.io.GenerateSequence
Specifies the function to use to assign timestamps to the elements.
WithTimestamps<T> - Class in org.apache.beam.sdk.transforms
A PTransform for assigning timestamps to all the elements of a PCollection.
withTimeZone(DateTimeZone) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
 
withTimeZone(DateTimeZone) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
 
withTimeZone(DateTimeZone) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
 
withTrigger(Trigger) - Method in class org.apache.beam.sdk.values.WindowingStrategy
Returns a WindowingStrategy identical to this but with the trigger set to wildcardTrigger.
withType(Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Field
Returns a copy of the Field with the Schema.FieldType set.
withType(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.transforms.Create.TimestampedValues
Returns a Create.TimestampedValues PTransform like this one that uses the given TypeDescriptor<T> to determine the Coder to use to decode each of the objects into a value of type T.
withType(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.transforms.Create.Values
Returns a Create.Values PTransform like this one that uses the given TypeDescriptor<T> to determine the Coder to use to decode each of the objects into a value of type T.
withValidation() - Method in class org.apache.beam.sdk.options.PipelineOptionsFactory.Builder
After creation we will validate that PipelineOptions conforms to all the validation criteria from <T>.
withValidation() - Method in class org.apache.beam.sdk.options.PipelineOptionsFactory
After creation we will validate that <T> conforms to all the validation criteria.
withValue(NewT) - Method in class org.apache.beam.sdk.util.WindowedValue
Returns a new WindowedValue that is a copy of this one, but with a different value, which may have a new type NewT.
withValueCoder(Coder<NewT>) - Method in class org.apache.beam.sdk.util.WindowedValue.FullWindowedValueCoder
 
withValueCoder(Coder<NewT>) - Method in class org.apache.beam.sdk.util.WindowedValue.ParamWindowedValueCoder
 
withValueCoder(Coder<NewT>) - Method in class org.apache.beam.sdk.util.WindowedValue.ValueOnlyWindowedValueCoder
Deprecated.
 
withValueCoder(Coder<NewT>) - Method in class org.apache.beam.sdk.util.WindowedValue.WindowedValueCoder
Returns a new WindowedValueCoder that is a copy of this one, but with a different value coder.
withValueField(String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
 
withWatermark(Instant) - Method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
Returns a new Watch.Growth.PollResult like this one with the provided watermark.
withWindowedWrites() - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
Preserves windowing of input elements and writes them to files based on the element's window.
withWindowedWrites() - Method in class org.apache.beam.sdk.io.AvroIO.Write
withWindowedWrites() - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
Specify that writes are windowed.
withWindowedWrites() - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Preserves windowing of input elements and writes them to files based on the element's window.
withWindowedWrites() - Method in class org.apache.beam.sdk.io.TextIO.Write
withWindowedWrites() - Method in class org.apache.beam.sdk.io.WriteFiles
Returns a new WriteFiles that writes preserves windowing on it's input.
withWindowFn(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.values.WindowingStrategy
Returns a WindowingStrategy identical to this but with the window function set to wildcardWindowFn.
withWritableByteChannelFactory(FileBasedSink.WritableByteChannelFactory) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
Returns a transform for writing to text files like this one but that has the given FileBasedSink.WritableByteChannelFactory to be used by the FileBasedSink during output.
withWritableByteChannelFactory(FileBasedSink.WritableByteChannelFactory) - Method in class org.apache.beam.sdk.io.TextIO.Write
See TypedWrite#withWritableByteChannelFactory(WritableByteChannelFactory).
witValueField(String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
Set the name of the value field in the resulting schema.
wrap(Throwable) - Method in class org.apache.beam.sdk.testing.PAssert.PAssertionSite
 
wrap(String) - Method in class org.apache.beam.sdk.testing.PAssert.PAssertionSite
 
wrap(Throwable) - Static method in exception org.apache.beam.sdk.util.UserCodeException
 
wrapIf(boolean, Throwable) - Static method in exception org.apache.beam.sdk.util.UserCodeException
 
wrapProcessContext(DoFn<InputT, ?>.ProcessContext) - Static method in class org.apache.beam.sdk.transforms.Contextful.Fn.Context
Convenience wrapper for creating a Contextful.Fn.Context from a DoFn.ProcessContext, to support the common case when a PTransform is invoking the closure from inside a DoFn.
write(ElementT) - Method in class org.apache.beam.sdk.io.AvroIO.Sink
 
write(Class<T>) - Static method in class org.apache.beam.sdk.io.AvroIO
Writes a PCollection to an Avro file (or multiple Avro files matching a sharding pattern).
write(OutputT) - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
Called for each value in the bundle.
write(ElementT) - Method in interface org.apache.beam.sdk.io.FileIO.Sink
Appends a single element to the file.
write() - Static method in class org.apache.beam.sdk.io.FileIO
Writes elements to files using a FileIO.Sink.
Write() - Constructor for class org.apache.beam.sdk.io.FileIO.Write
 
write(String) - Method in class org.apache.beam.sdk.io.TextIO.Sink
 
write() - Static method in class org.apache.beam.sdk.io.TextIO
A PTransform that writes a PCollection to a text file (or multiple text files matching a sharding pattern), with each element of the input collection encoded into its own line.
write(byte[]) - Method in class org.apache.beam.sdk.io.TFRecordIO.Sink
 
write() - Static method in class org.apache.beam.sdk.io.TFRecordIO
A PTransform that writes a PCollection to TFRecord file (or multiple TFRecord files matching a sharding pattern), with each element of the input collection encoded into its own record.
Write() - Constructor for class org.apache.beam.sdk.io.TFRecordIO.Write
 
write(T) - Method in interface org.apache.beam.sdk.state.ValueState
Set the value.
write(int) - Method in class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
 
write(byte[], int, int) - Method in class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
 
write(byte[], int, int) - Method in class org.apache.beam.sdk.util.ExposedByteArrayOutputStream
 
write(int) - Method in class org.apache.beam.sdk.util.ExposedByteArrayOutputStream
 
write(ByteBuffer) - Method in class org.apache.beam.sdk.util.ShardingWritableByteChannel
Writes a buffer to all shards.
write(byte[], int, int) - Method in class org.apache.beam.sdk.util.UnownedOutputStream
 
writeAndOwn(byte[]) - Method in class org.apache.beam.sdk.util.ExposedByteArrayOutputStream
Write b to the stream and take the ownership of b.
writeCompressed(WritableByteChannel) - Method in enum org.apache.beam.sdk.io.Compression
 
writeCustomType() - Static method in class org.apache.beam.sdk.io.AvroIO
A PTransform that writes a PCollection to an avro file (or multiple avro files matching a sharding pattern), with each element of the input collection encoded into its own record of type OutputT.
writeCustomType() - Static method in class org.apache.beam.sdk.io.TextIO
A PTransform that writes a PCollection to a text file (or multiple text files matching a sharding pattern), with each element of the input collection encoded into its own line.
writeCustomTypeToGenericRecords() - Static method in class org.apache.beam.sdk.io.AvroIO
Similar to AvroIO.writeCustomType(), but specialized for the case where the output type is GenericRecord.
writeDynamic() - Static method in class org.apache.beam.sdk.io.FileIO
Writes elements to files using a FileIO.Sink and grouping the elements using "dynamic destinations".
WriteFiles<UserT,DestinationT,OutputT> - Class in org.apache.beam.sdk.io
A PTransform that writes to a FileBasedSink.
WriteFiles() - Constructor for class org.apache.beam.sdk.io.WriteFiles
 
WriteFilesResult<DestinationT> - Class in org.apache.beam.sdk.io
The result of a WriteFiles transform.
writeFooter() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
Writes footer at the end of output files.
writeGenericRecords(Schema) - Static method in class org.apache.beam.sdk.io.AvroIO
Writes Avro records of the specified schema.
writeGenericRecords(String) - Static method in class org.apache.beam.sdk.io.AvroIO
Writes Avro records of the specified schema.
writeHeader() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
Writes header at the beginning of output files.
writeMetrics(MetricQueryResults) - Method in interface org.apache.beam.sdk.metrics.MetricsSink
 
WriteOperation(FileBasedSink<?, DestinationT, OutputT>) - Constructor for class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
Constructs a WriteOperation using the default strategy for generating a temporary directory from the base output filename.
WriteOperation(FileBasedSink<?, DestinationT, OutputT>, ResourceId) - Constructor for class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
Create a new WriteOperation.
Writer(FileBasedSink.WriteOperation<DestinationT, OutputT>, String) - Constructor for class org.apache.beam.sdk.io.FileBasedSink.Writer
Construct a new FileBasedSink.Writer that will produce files of the given MIME type.
writeToShard(int, ByteBuffer) - Method in class org.apache.beam.sdk.util.ShardingWritableByteChannel
Writes the buffer to the given shard.
WS - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
WS - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 

Y

years(int) - Static method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows
Returns a WindowFn that windows elements into periods measured by years.

Z

ZERO_BACKOFF - Static variable in interface org.apache.beam.sdk.util.BackOff
Fixed back-off policy whose back-off time is always zero, meaning that the operation is retried immediately without waiting.
zipDirectory(File, File) - Static method in class org.apache.beam.sdk.util.ZipFiles
Zips an entire directory specified by the path.
zipDirectory(File, OutputStream) - Static method in class org.apache.beam.sdk.util.ZipFiles
Zips an entire directory specified by the path.
ZipFiles - Class in org.apache.beam.sdk.util
Functions for zipping a directory (including a subdirectory) into a ZIP-file or unzipping it again.

_

_ATN - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
_ATN - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
_decisionToDFA - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
_decisionToDFA - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
_serializedATN - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
_serializedATN - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
_sharedContextCache - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
 
_sharedContextCache - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
 
A B C D E F G H I J K L M N O P Q R S T U V W Y Z _