- 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
-
- afterTimeSinceNewOutput(SerializableFunction<InputT, ReadableDuration>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
- afterTotalOf(ReadableDuration) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
- afterTotalOf(SerializableFunction<InputT, ReadableDuration>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
- 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
-
- 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
-
- 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
-
- allMatches(Pattern) - Static method in class org.apache.beam.sdk.transforms.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
-
- allOf(SerializableMatcher<T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- allOf(Watch.Growth.TerminationCondition<InputT, FirstStateT>, Watch.Growth.TerminationCondition<InputT, SecondStateT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
- 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
-
- 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
-
- and(Iterable<PCollection<T>>) - Method in class org.apache.beam.sdk.values.PCollectionList
-
- and(TupleTag<T>, PCollection<T>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
- and(String, PCollection<T>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
- and(TupleTag<?>) - Method in class org.apache.beam.sdk.values.TupleTagList
-
- and(List<TupleTag<?>>) - Method in class org.apache.beam.sdk.values.TupleTagList
-
- 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
-
- anyOf(SerializableMatcher<T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- anything() - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- 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
-
- 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
-
- apply(String, PTransform<? super PBegin, OutputT>) - Method in class org.apache.beam.sdk.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
-
- 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
-
- 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
-
- 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
-
- 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
-
- apply(String, PTransform<? super PCollectionTuple, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
- 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
-
PTransform
s 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
-
- 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
-
- 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 KV
s.
- 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
-
- arrayContaining(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- arrayContaining(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- arrayContaining(SerializableMatcher<? super T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- arrayContaining(List<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- arrayContainingInAnyOrder(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- arrayContainingInAnyOrder(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- 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
-
- arrayWithSize(SerializableMatcher<? super Integer>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- 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
-
- asList() - Static method in class org.apache.beam.sdk.transforms.View
-
- asMap() - Method in class org.apache.beam.sdk.transforms.display.DisplayData
-
- asMap() - Static method in class org.apache.beam.sdk.transforms.View
-
- asMultimap() - Static method in class org.apache.beam.sdk.transforms.View
-
- 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 Source
s, 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
-
- 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<Object, W>.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.InvalidWindows
-
- 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
-
- 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
-
- 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
-
- AutoValueSchema() - Constructor for class org.apache.beam.sdk.schemas.AutoValueSchema
-
- AutoValueSchema.AbstractGetterTypeSupplier - Class in org.apache.beam.sdk.schemas
-
- 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
-
- 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
-
- AvroIO.ReadFiles<T> - Class in org.apache.beam.sdk.io
-
- AvroIO.RecordFormatter<ElementT> - Interface in org.apache.beam.sdk.io
-
- 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
-
- 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
-
- AvroRecordSchema() - Constructor for class org.apache.beam.sdk.schemas.AvroRecordSchema
-
- AvroSchemaIOProvider - Class in org.apache.beam.sdk.io
-
- AvroSchemaIOProvider() - Constructor for class org.apache.beam.sdk.io.AvroSchemaIOProvider
-
- AvroSink<UserT,DestinationT,OutputT> - Class in org.apache.beam.sdk.io
-
- 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
-
- 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.
- 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
WindowFn
s 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
-
- 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
-
- 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
-
- 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.
- 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
-
- 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
-
- clearOutputElements(TupleTag<T>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- 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
-
- 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
-
- closeTo(double, double) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- 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
-
- 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
-
- CoderProvider - Class in org.apache.beam.sdk.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
CoderProvider
s.
- CoderRegistry - Class in org.apache.beam.sdk.coders
-
- 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
-
- CoGbkResult(CoGbkResultSchema, Iterable<RawUnionValue>) - Constructor for class org.apache.beam.sdk.transforms.join.CoGbkResult
-
- 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
-
- 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
PCollection
s.
- 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
-
- COLLECTION_TYPES - Static variable in enum org.apache.beam.sdk.schemas.Schema.TypeName
-
- CollectionCoder<T> - Class in org.apache.beam.sdk.coders
-
- CollectionCoder(Coder<T>) - Constructor for class org.apache.beam.sdk.coders.CollectionCoder
-
- Combine - Class in org.apache.beam.sdk.transforms
-
PTransform
s for combining PCollection
elements globally and per-key.
- combine(Iterable<? extends Instant>) - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
-
- 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
-
- 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
double
s.
- 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
int
s
- 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
long
s.
- 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
-
- 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
-
- 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
-
- combineFn() - Static method in class org.apache.beam.sdk.transforms.Latest
-
- 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
-
- CombineFns.ComposedCombineFn<DataT> - Class in org.apache.beam.sdk.transforms
-
- CombineFns.ComposedCombineFnWithContext<DataT> - Class in org.apache.beam.sdk.transforms
-
- CombineFnTester - Class in org.apache.beam.sdk.testing
-
- 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
-
- 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
-
- 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
-
- 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
-
- CompressedSource.CompressionMode - Enum in org.apache.beam.sdk.io
-
- 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.
- 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
-
- 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
-
- constantDestinations(FileBasedSink.FilenamePolicy, Schema, Map<String, Object>, CodecFactory, SerializableFunction<UserT, OutputT>, AvroSink.DatumWriterFactory<OutputT>) - Static method in class org.apache.beam.sdk.io.AvroIO
-
- 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
-
- contains(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- contains(SerializableMatcher<? super T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- contains(List<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- 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
-
- containsInAnyOrder(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- containsInAnyOrder(SerializableMatcher<? super T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- containsInAnyOrder(Collection<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- 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
-
- 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
-
- 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.
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- create(ResourceId, CreateOptions) - Static method in class org.apache.beam.sdk.io.FileSystems
-
- 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
-
- 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
-
- 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
-
- create() - Static method in class org.apache.beam.sdk.Pipeline
-
- create(PipelineOptions) - Static method in class org.apache.beam.sdk.Pipeline
-
- create() - Static method in class org.apache.beam.sdk.PipelineRunner
-
- create(Class<?>, Schema) - Method in interface org.apache.beam.sdk.schemas.Factory
-
- create() - Static method in class org.apache.beam.sdk.schemas.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(List<Schema.Field>) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
- create(List<Schema.Field>, Map<String, Integer>) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
- 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(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
-
- 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() - Static method in class org.apache.beam.sdk.transforms.Impulse
-
- 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
-
- 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
-
- 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
-
- 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
-
- createReader(PipelineOptions) - Method in class org.apache.beam.sdk.io.BoundedSource
-
- createReader(PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSource
-
- createReader(PipelineOptions, CheckpointMarkT) - Method in class org.apache.beam.sdk.io.UnboundedSource
-
- 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
-
- 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
-
- createWriter() - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
-
- 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
-
- CustomCoder() - Constructor for class org.apache.beam.sdk.coders.CustomCoder
-
- 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.
- 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
-
- 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
PTransform
s 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- DefaultFilenamePolicy.Params - Class in org.apache.beam.sdk.io
-
- 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
-
- 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
-
- DefaultSchema.DefaultSchemaProvider - Class in org.apache.beam.sdk.schemas.annotations
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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(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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- DoFn.NewWatermarkEstimator - Annotation Type in org.apache.beam.sdk.transforms
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- DoFn.WatermarkEstimatorState - Annotation Type in org.apache.beam.sdk.transforms
-
- 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
-
- DoFnInvoker.DelegatingArgumentProvider<InputT,OutputT> - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnInvoker.FakeArgumentProvider<InputT,OutputT> - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnInvokers - Class in org.apache.beam.sdk.transforms.reflect
-
- 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
-
- DoFnSignature.Parameter.Cases<ResultT> - Interface in org.apache.beam.sdk.transforms.reflect
-
- 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
-
- DoFnSignature.Parameter.FinishBundleContextParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.KeyParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.OnTimerContextParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.OnWindowExpirationContextParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.OutputReceiverParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.PaneInfoParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.PipelineOptionsParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.ProcessContextParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.RestrictionParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.RestrictionTrackerParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- 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
-
- 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
-
- DoFnSignature.Parameter.StateParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.TaggedOutputReceiverParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.TimeDomainParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.TimerFamilyParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.TimerIdParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.TimerParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.TimestampParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.WatermarkEstimatorParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.WatermarkEstimatorStateParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnSignature.Parameter.WindowParameter - Class in org.apache.beam.sdk.transforms.reflect
-
- 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
-
- DoFnSignatures - Class in org.apache.beam.sdk.transforms.reflect
-
- DoFnTester<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
- DoFnTester.CloningBehavior - Enum in org.apache.beam.sdk.transforms
-
- 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
-
- 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
-
- durationMilliSec - Variable in class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
-
- DynamicAvroDestinations<UserT,DestinationT,OutputT> - Class in org.apache.beam.sdk.io
-
- 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
-
- DynamicFileDestinations() - Constructor for class org.apache.beam.sdk.io.DynamicFileDestinations
-
- eitherOf(Watch.Growth.TerminationCondition<InputT, FirstStateT>, Watch.Growth.TerminationCondition<InputT, SecondStateT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
- 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
-
- 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
-
- 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
-
- empty(Pipeline) - Static method in class org.apache.beam.sdk.values.PCollectionList
-
- empty(Pipeline) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
- empty() - Static method in class org.apache.beam.sdk.values.TupleTagList
-
- emptyArray() - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- emptyIterable() - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- EmptyMatchTreatment - Enum in org.apache.beam.sdk.io.fs
-
- 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
-
- 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
-
- 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
-
- 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
-
- enterArrayQualifier(FieldSpecifierNotationParser.ArrayQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- enterArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
- enterArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- 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
-
- enterDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- 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
-
- enterFieldSpecifier(FieldSpecifierNotationParser.FieldSpecifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- enterMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
- enterMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- enterMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
- enterMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- 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
-
- enterQualifyComponent(FieldSpecifierNotationParser.QualifyComponentContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- 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
-
- enterSimpleIdentifier(FieldSpecifierNotationParser.SimpleIdentifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- enterWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
- enterWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- 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
-
- 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
-
- 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
-
- equalTo(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- 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
-
- exceptionsInto(TypeDescriptor<NewFailureT>) - Method in class org.apache.beam.sdk.transforms.MapElements
-
- 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
-
- exitArrayQualifier(FieldSpecifierNotationParser.ArrayQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- exitArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
- exitArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- exitDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
- exitDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- 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
-
- exitFieldSpecifier(FieldSpecifierNotationParser.FieldSpecifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- exitMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
- exitMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- exitMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
- exitMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- 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
-
- exitQualifyComponent(FieldSpecifierNotationParser.QualifyComponentContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- 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
-
- exitSimpleIdentifier(FieldSpecifierNotationParser.SimpleIdentifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- exitWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
- exitWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
- 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<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
-
- expand() - Method in interface org.apache.beam.sdk.values.PInput
-
- expand() - Method in interface org.apache.beam.sdk.values.POutput
-
- expand() - Method in interface org.apache.beam.sdk.values.PValue
-
- 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
-
- 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
-
- 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
-
- 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.
- 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
-
- 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
-
- 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
-
- 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
TypeDescriptor
s 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
-
- FileBasedSink.DynamicDestinations<UserT,DestinationT,OutputT> - Class in org.apache.beam.sdk.io
-
- 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
-
- 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
-
- 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
-
- FileBasedSource<T> - Class in org.apache.beam.sdk.io
-
A common base class for all file-based
Source
s.
- 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
FileBasedSource
s.
- 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
-
- FileIO.MatchAll - Class in org.apache.beam.sdk.io
-
- 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
-
- 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
-
- FileIO.Write<DestinationT,UserT> - Class in org.apache.beam.sdk.io
-
- 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
-
- 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
-
- FileSystems - Class in org.apache.beam.sdk.io
-
- 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
-
PTransform
s 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
-