A B C D E F G H I J K L M N O P Q R S T U V W Y Z _
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- absolute(String, String...) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
-
Construct a path from an absolute component path hierarchy.
- AbstractGetterTypeSupplier() - Constructor for class org.apache.beam.sdk.schemas.AutoValueSchema.AbstractGetterTypeSupplier
- AbstractReadFileRangesFn(SerializableFunction<String, ? extends FileBasedSource<InT>>, ReadAllViaFileBasedSource.ReadFileRangesFnExceptionHandler) - Constructor for class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform.AbstractReadFileRangesFn
- 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(BeamFnApi.Elements) - Method in class org.apache.beam.sdk.fn.data.BeamFnDataInboundObserver
- 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.
- 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(ByteString) - Method in class org.apache.beam.sdk.fn.data.DecodingFnDataReceiver
- accept(T) - Method in interface org.apache.beam.sdk.fn.data.FnDataReceiver
- accept(T) - Method in interface org.apache.beam.sdk.function.ThrowingConsumer
- accept(T1, T2) - Method in interface org.apache.beam.sdk.function.ThrowingBiConsumer
- ACCEPT_MISSING_OR_NULL - org.apache.beam.sdk.util.RowJson.RowJsonDeserializer.NullBehavior
-
Specifies that a null value may be represented as either a missing field or a null value in the input JSON.
- accumulate(T, T) - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold
-
Accumulate two results together.
- accumulateWeight(long) - Method in class org.apache.beam.sdk.fn.data.WeightedList
- ACCUMULATING_FIRED_PANES - org.apache.beam.sdk.values.WindowingStrategy.AccumulationMode
- 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
WindowPTransformthat uses the registered WindowFn and Triggering behavior, and that accumulates elements in a pane after they are triggered. - activate(MetricsContainer) - Method in class org.apache.beam.sdk.metrics.MetricsEnvironment.MetricsContainerHolder
- activate(MetricsContainer) - Method in interface org.apache.beam.sdk.metrics.MetricsEnvironment.MetricsEnvironmentState
- actuateProjectionPushdown(Map<TupleTag<?>, FieldAccessDescriptor>) - Method in interface org.apache.beam.sdk.schemas.ProjectionProducer
-
Actuate a projection pushdown.
- 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(long, long) - Method in class org.apache.beam.sdk.util.BucketingFunction
-
Add one sample of
value(to bucket) attimeMsSinceEpoch. - add(long, long) - Method in class org.apache.beam.sdk.util.MovingFunction
-
Add
valueatnowMsSinceEpoch. - add(InputT) - Method in interface org.apache.beam.sdk.state.GroupingState
-
Add a value to the buffer.
- add(Iterable<String>) - Method in interface org.apache.beam.sdk.metrics.BoundedTrie
-
Adds a path to the trie.
- add(Iterable<String>) - Method in class org.apache.beam.sdk.metrics.Lineage
-
Adds the given fqn as lineage.
- add(Iterable<TimestampedValue<T>>) - Static method in class org.apache.beam.sdk.testing.TestStream.ElementEvent
-
For internal use only: no backwards compatibility guarantees.
- add(String) - Method in interface org.apache.beam.sdk.metrics.StringSet
-
Add a value to this set.
- add(String...) - Method in interface org.apache.beam.sdk.metrics.BoundedTrie
-
Adds a path to the trie.
- add(String...) - Method in interface org.apache.beam.sdk.metrics.StringSet
-
Add values to this set.
- add(String, String, Iterable<String>, String) - Method in class org.apache.beam.sdk.metrics.Lineage
-
Add a FQN (fully-qualified name) to Lineage.
- add(String, Iterable<String>) - Method in class org.apache.beam.sdk.metrics.Lineage
-
Add a FQN (fully-qualified name) to Lineage.
- add(String, Iterable<String>, String) - Method in class org.apache.beam.sdk.metrics.Lineage
-
Add a FQN (fully-qualified name) to Lineage.
- add(DisplayData.ItemSpec<?>) - Method in interface org.apache.beam.sdk.transforms.display.DisplayData.Builder
-
Register the given display item.
- add(T, long) - Method in class org.apache.beam.sdk.fn.data.WeightedList
- addAccum(AccumT) - Method in interface org.apache.beam.sdk.state.CombiningState
-
Add an accumulator to this state cell.
- addAll(List<T>, long) - Method in class org.apache.beam.sdk.fn.data.WeightedList
- addAll(WeightedList<T>) - Method in class org.apache.beam.sdk.fn.data.WeightedList
- addAnnotation(String, byte[]) - Method in class org.apache.beam.sdk.transforms.PTransform
- addArray(Object...) - Method in class org.apache.beam.sdk.values.Row.Builder
- addArray(Collection<T>) - 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.
- addCoderAndEncodedRecord(Coder<T>, T) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record.Builder
- 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(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.
- 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.
- addErrorCollection(PCollection<ErrorT>) - Method in interface org.apache.beam.sdk.transforms.errorhandling.ErrorHandler
- addErrorCollection(PCollection<ErrorT>) - Method in class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.DefaultErrorHandler
- addErrorCollection(PCollection<ErrorT>) - Method in class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.PTransformErrorHandler
- addExceptionStackTrace(Exception) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Failure.Builder
- addExperiment(ExperimentalOptions, String) - Static method in interface org.apache.beam.sdk.options.ExperimentalOptions
-
Adds experiment to options if not already present.
- addField(String, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addField(Schema.Field) - 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
- AddHarnessIdInterceptor - Class in org.apache.beam.sdk.fn.channel
-
A
ClientInterceptorthat attaches a provided SDK Harness ID to outgoing messages. - addHumanReadableJson(Object) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record.Builder
- addIfAbsent(T) - Method in interface org.apache.beam.sdk.state.SetState
-
Ensures a value is a member of the set, returning
trueif it was added andfalseotherwise. - 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(double[], Double) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
- 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.AccumulatingCombineFn
- 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(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(InputT) - Method in interface org.apache.beam.sdk.transforms.Combine.AccumulatingCombineFn.Accumulator
-
Adds the given input value to this accumulator, modifying this accumulator.
- 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(List<V>, V) - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
- addInput(ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique, T) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
-
Deprecated.
- addInput(Combine.Holder<V>, V) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
- 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
- addLabel(String, String) - Method in class org.apache.beam.sdk.metrics.LabeledMetricNameUtils.MetricNameBuilder
-
Add a metric label KV pair to the metric name.
- 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
- addMetricLabel(String, String) - Method in class org.apache.beam.sdk.metrics.LabeledMetricNameUtils.MetricNameBuilder
-
Add a metric label KV pair to the metric.
- addNameFilter(MetricNameFilter) - Method in class org.apache.beam.sdk.metrics.MetricsFilter.Builder
-
Add a
MetricNameFilter. - addNullableArrayField(String, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableBooleanField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableByteArrayField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableByteField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableDateTimeField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableDecimalField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableDoubleField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableField(String, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableFloatField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableInt16Field(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableInt32Field(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableInt64Field(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableIterableField(String, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableLogicalTypeField(String, Schema.LogicalType<InputT, BaseT>) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableMapField(String, Schema.FieldType, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableRowField(String, Schema) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- addNullableStringField(String) - 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.
- addRequirement(String) - Method in class org.apache.beam.sdk.util.construction.SdkComponents
- 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(Object...) - Method in class org.apache.beam.sdk.values.Row.Builder
- addValues(List<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. - AdvancingPhaser - Class in org.apache.beam.sdk.fn.stream
-
A
Phaserwhich never terminates. - AdvancingPhaser(int) - Constructor for class org.apache.beam.sdk.fn.stream.AdvancingPhaser
- AfterAll - Class in org.apache.beam.sdk.transforms.windowing
-
A composite
Triggerthat 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
Triggerthat executes its sub-triggers in order. - AfterFirst - Class in org.apache.beam.sdk.transforms.windowing
-
A composite
Triggerthat fires once after at least one of its sub-triggers have fired. - afterIterations(int) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
Returns a
Watch.Growth.TerminationConditionthat holds after the given number of polling iterations have occurred per-input. - AfterPane - Class in org.apache.beam.sdk.transforms.windowing
-
A
Triggerthat fires at some point after a specified number of input elements have arrived. - AfterProcessingTime - Class in org.apache.beam.sdk.transforms.windowing
-
A
Triggertrigger 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(SerializableFunction<InputT, ReadableDuration>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
Like
Watch.Growth.afterTimeSinceNewOutput(ReadableDuration), but the duration is input-dependent. - afterTimeSinceNewOutput(ReadableDuration) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
Returns a
Watch.Growth.TerminationConditionthat holds after the given time has elapsed after the last time theWatch.Growth.PollResultfor the current input contained a previously unseen output. - afterTotalOf(SerializableFunction<InputT, ReadableDuration>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
Like
Watch.Growth.afterTotalOf(ReadableDuration), but the duration is input-dependent. - afterTotalOf(ReadableDuration) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
Returns a
Watch.Growth.TerminationConditionthat holds after the given time has elapsed after the current input was seen. - AfterWatermark - Class in org.apache.beam.sdk.transforms.windowing
-
AfterWatermarktriggers fire based on progress of the system watermark. - AfterWatermark.AfterWatermarkEarlyAndLate - Class in org.apache.beam.sdk.transforms.windowing
- AfterWatermark.FromEndOfWindow - Class in org.apache.beam.sdk.transforms.windowing
-
A watermark trigger targeted relative to the end of the window.
- aggregate(Combine.CombineFn<InputT, ?, OutputT>) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
Aggregate the grouped data using the specified
Combine.CombineFn. - AggregateCombiner() - Constructor for class org.apache.beam.sdk.schemas.transforms.Group.AggregateCombiner
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.AggregateCombiner
-
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(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - 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(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(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(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(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.AggregateCombiner
-
Build up an aggregation function over the input elements.
- 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(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(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(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.
- aggregateFieldBaseValue(int, 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.CombineFieldsByFields
- aggregateFieldBaseValue(int, 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.Global
- aggregateFieldBaseValue(int, 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.CombineFieldsByFields
- aggregateFieldBaseValue(int, 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.Global
- aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - 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(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - 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(String, 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>, Schema.Field) - 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.CombineFieldsGlobally
- aggregateFieldBaseValue(String, 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(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(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(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(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(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(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(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>, 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.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.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.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.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.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.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.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>, String) - 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.AggregateCombiner
-
Build up an aggregation function over the input elements by field id.
- 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>, Schema.Field) - 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.Global
- align(Duration) - Method in interface org.apache.beam.sdk.state.Timer
-
Aligns the target timestamp used by
Timer.setRelative()to the next boundary ofperiod. - alignedTo(Duration) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
-
Aligns the time to be the smallest multiple of
periodgreater than the epoch boundary (akanew Instant(0)). - alignedTo(Duration, Instant) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
-
Aligns timestamps to the smallest multiple of
periodsince theoffsetgreater than the timestamp. - alignTo(Duration) - Static method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform
-
For internal use only; no backwards-compatibility guarantees.
- alignTo(Duration, Instant) - 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 - org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.ListQualifier
- ALL - org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.MapQualifier
- 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
-
Like
MoreFutures.allAsList(java.util.Collection<? extends java.util.concurrent.CompletionStage<? extends T>>)but return a list ofMoreFutures.ExceptionOrResultof constituent futures. - allLeavesDescriptor(Schema, SerializableFunction<List<String>, String>) - Static method in class org.apache.beam.sdk.schemas.utils.SelectHelpers
- allMatches(String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.AllMatchesPTransformthat checks if the entire line matches the Regex. - allMatches(Pattern) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.AllMatchesPTransformthat checks if the entire line matches the Regex. - AllMatches(Pattern) - Constructor for class org.apache.beam.sdk.transforms.Regex.AllMatches
- allMetrics() - Method in class org.apache.beam.sdk.metrics.MetricResults
- allocateAddressAndCreate(List<BindableService>, Endpoints.ApiServiceDescriptor.Builder) - Method in class org.apache.beam.sdk.fn.server.InProcessServerFactory
- allocateAddressAndCreate(List<BindableService>, Endpoints.ApiServiceDescriptor.Builder) - Method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Creates an instance of this server using an ephemeral address.
- allocateAddressAndCreate(List<BindableService>, Endpoints.ApiServiceDescriptor.Builder) - Method in class org.apache.beam.sdk.fn.server.ServerFactory.InetSocketAddressServerFactory
- allocatePortAndCreateFor(List<? extends FnService>, ServerFactory) - Static method in class org.apache.beam.sdk.fn.server.GrpcFnServer
-
Create
GrpcFnServers for the providedFnServices running on an arbitrary port. - allocatePortAndCreateFor(ServiceT, ServerFactory) - Static method in class org.apache.beam.sdk.fn.server.GrpcFnServer
-
Create a
GrpcFnServerfor the providedFnServicerunning on an arbitrary port. - allOf(Iterable<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.allOf(Iterable). - allOf(Collection<? extends CompletionStage<? extends T>>) - Static method in class org.apache.beam.sdk.util.MoreFutures
- allOf(SerializableMatcher<T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.allOf(Matcher[]). - allOf(Watch.Growth.TerminationCondition<InputT, FirstStateT>, Watch.Growth.TerminationCondition<InputT, SecondStateT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
Returns a
Watch.Growth.TerminationConditionthat holds when both of the given two conditions hold. - ALLOW - org.apache.beam.sdk.io.fs.EmptyMatchTreatment
-
Filepatterns matching no resources are allowed.
- ALLOW_IF_WILDCARD - org.apache.beam.sdk.io.fs.EmptyMatchTreatment
-
Filepatterns matching no resources are allowed if the filepattern contains a glob wildcard character, and disallowed otherwise (i.e.
- 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.
- allPathsFromRootsToLeaves(Network<NodeT, EdgeT>) - Static method in class org.apache.beam.sdk.util.construction.graph.Networks
-
Returns a list of all distinct paths from roots of the network to leaves.
- 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
- alwaysUseRead() - Method in class org.apache.beam.sdk.transforms.Create.Values
- and(Iterable<PCollection<T>>) - Method in class org.apache.beam.sdk.values.PCollectionList
-
Returns a new
PCollectionListthat has all thePCollectionsof thisPCollectionListplus the givenPCollectionsappended to the end, in order. - and(String, PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
A version of
KeyedPCollectionTuple.and(String, PCollection)that takes in a string instead of a TupleTag. - and(String, PCollection<Row>) - Method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
Returns a new
PCollectionRowTuplethat has eachPCollectionand tag of thisPCollectionRowTupleplus the givenPCollectionassociated with the given tag. - and(String, PCollection<T>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
A version of
PCollectionTuple.and(TupleTag, PCollection)that takes in a String instead of a TupleTag. - and(List<TupleTag<?>>) - Method in class org.apache.beam.sdk.values.TupleTagList
-
Returns a new
TupleTagListthat has all theTupleTagsof thisTupleTagListplus the givenTupleTagsappended to the end, in order. - and(PTransformMatcher) - Method in interface org.apache.beam.sdk.runners.PTransformMatcher
- and(PCollection.IsBounded) - Method in enum org.apache.beam.sdk.values.PCollection.IsBounded
-
Returns the composed IsBounded property.
- and(PCollection<T>) - Method in class org.apache.beam.sdk.values.PCollectionList
-
Returns a new
PCollectionListthat has all thePCollectionsof thisPCollectionListplus the givenPCollectionappended to the end. - and(TupleTag<?>) - Method in class org.apache.beam.sdk.values.TupleTagList
-
Returns a new
TupleTagListthat has all theTupleTagsof thisTupleTagListplus the givenTupleTagappended to the end. - and(TupleTag<T>, PCollection<T>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
Returns a new
PCollectionTuplethat has eachPCollectionandTupleTagof thisPCollectionTupleplus the givenPCollectionassociated with the givenTupleTag. - and(TupleTag<V>, List<V>) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
Returns a new
CoGbkResultbased 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. - annotations - Variable in class org.apache.beam.sdk.transforms.PTransform
- any(long) - Static method in class org.apache.beam.sdk.transforms.Sample
-
Sample#any(long)takes aPCollection<T>and a limit, and produces a newPCollection<T>containing up to limit elements of the inputPCollection. - anyCombineFn(int) - Static method in class org.apache.beam.sdk.transforms.Sample
-
Returns a
Combine.CombineFnthat computes a fixed-sized potentially non-uniform sample of its inputs. - anyOf(Iterable<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.anyOf(Iterable). - anyOf(SerializableMatcher<T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.anyOf(Matcher[]). - anything() - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.anything(). - anyValueCombineFn() - Static method in class org.apache.beam.sdk.transforms.Sample
-
Returns a
Combine.CombineFnthat 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.
- append(char) - Method in class org.apache.beam.sdk.util.ByteStringOutputStream
- append(CharSequence) - Method in class org.apache.beam.sdk.util.ByteStringOutputStream
- append(CharSequence, int, int) - Method in class org.apache.beam.sdk.util.ByteStringOutputStream
- applicableTo(PCollection<?>) - Static method in class org.apache.beam.sdk.transforms.GroupByKey
- ApplicationNameOptions - Interface in org.apache.beam.sdk.options
-
Options that allow setting the application name.
- AppliedCombineFn<K,InputT,AccumT,OutputT> - Class in org.apache.beam.sdk.util
-
A
CombineFnBase.GlobalCombineFnwith a fixed accumulator coder. - AppliedPTransform<InputT extends PInput,OutputT extends POutput,TransformT extends PTransform<? super InputT,OutputT>> - Class in org.apache.beam.sdk.runners
-
For internal use only; no backwards-compatibility guarantees.
- apply(double, double) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
-
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(InputT) - Method in interface org.apache.beam.sdk.coders.DelegateCoder.CodingFunction
- apply(InputT) - Method in class org.apache.beam.sdk.transforms.InferableFunction
- 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(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(Iterable<? extends InputT>) - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
-
Applies this
CombineFnto 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
CombineFnWithContextto a collection of input values to produce a combined output value. - apply(String, 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.values.PBegin
-
Applies the given
PTransformto thisPBegin, usingnameto identify this specific application of the transform. - apply(String, PTransform<? super PCollection<T>, OutputT>) - Method in class org.apache.beam.sdk.values.PCollection
-
Applies the given
PTransformto this inputPCollection, usingnameto identify this specific application of the transform. - apply(String, PTransform<? super PCollectionRowTuple, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
Applies the given
PTransformto this inputPCollectionRowTuple, usingnameto identify this specific application of the transform. - apply(String, PTransform<? super PCollectionTuple, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
Applies the given
PTransformto this inputPCollectionTuple, usingnameto identify this specific application of the transform. - apply(String, PTransform<KeyedPCollectionTuple<K>, OutputT>) - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
- apply(String, PTransform<PCollectionList<T>, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionList
-
Applies the given
PTransformto this inputPCollectionList, usingnameto identify this specific application of the transform. - apply(NodeT) - Method in class org.apache.beam.sdk.util.construction.graph.Networks.TypeSafeNodeFunction
- apply(FileIO.ReadableFile, OffsetRange, Exception) - Method in class org.apache.beam.sdk.io.ReadAllViaFileBasedSource.ReadFileRangesFnExceptionHandler
- 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(Materializations.IterableView<KV<K, V>>) - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMapViewFn
- apply(Materializations.IterableView<KV<K, V>>) - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMultimapViewFn
- apply(Materializations.IterableView<T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryListViewFn
- apply(Materializations.IterableView<T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableBackedListViewFn
- apply(Materializations.IterableView<T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn2
- apply(Materializations.IterableView<T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn2
- apply(Materializations.MultimapView<Long, PCollectionViews.ValueOrMetadata<T, OffsetRange>>) - Method in class org.apache.beam.sdk.values.PCollectionViews.ListViewFn2
- apply(Materializations.MultimapView<Void, KV<K, V>>) - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMapFromVoidKeyViewFn
- apply(Materializations.MultimapView<Void, KV<K, V>>) - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMultimapFromVoidKeyViewFn
- 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.InMemoryListFromMultimapViewFn
- 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, T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
-
Deprecated.
- apply(Materializations.MultimapView<K, V>) - Method in class org.apache.beam.sdk.values.PCollectionViews.MapViewFn2
- apply(Materializations.MultimapView<K, V>) - Method in class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn2
- apply(PTransform<? super PBegin, OutputT>) - Method in class org.apache.beam.sdk.Pipeline
-
Like
Pipeline.apply(String, PTransform)but the transform node in thePipelinegraph will be named according toPTransform.getName(). - apply(PTransform<? super PBegin, OutputT>) - Method in class org.apache.beam.sdk.values.PBegin
-
Like
PBegin.apply(String, PTransform)but defaulting to the name of thePTransform. - apply(PTransform<? super PCollection<T>, OutputT>) - Method in class org.apache.beam.sdk.values.PCollection
-
of the
PTransform. - apply(PTransform<? super PCollectionRowTuple, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
Like
PCollectionRowTuple.apply(String, PTransform)but defaulting to the name of thePTransform. - apply(PTransform<? super PCollectionTuple, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
Like
PCollectionTuple.apply(String, PTransform)but defaulting to the name of thePTransform. - apply(PTransform<KeyedPCollectionTuple<K>, OutputT>) - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
Like
KeyedPCollectionTuple.apply(String, PTransform)but defaulting to the name provided by thePTransform. - apply(PTransform<PCollectionList<T>, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionList
-
Like
PCollectionList.apply(String, PTransform)but defaulting to the name of thePTransform. - apply(WithFailures.ExceptionElement<T>) - Method in class org.apache.beam.sdk.transforms.WithFailures.ExceptionAsMapHandler
- apply(WithFailures.ExceptionElement<T>) - Method in class org.apache.beam.sdk.transforms.WithFailures.ThrowableHandler
- apply(Statement, Description) - Method in class org.apache.beam.sdk.testing.TestPipeline
- 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(T) - Method in class org.apache.beam.sdk.testing.PAssert.MatcherCheckerFn
- apply(T1) - Method in interface org.apache.beam.sdk.function.ThrowingFunction
- apply(T1, T2) - Method in interface org.apache.beam.sdk.function.ThrowingBiFunction
- apply(V, V) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
-
Applies the binary operation to the two operands, returning the result.
- applyTransform(InputT, PTransform<? super InputT, OutputT>) - Static method in class org.apache.beam.sdk.Pipeline
-
For internal use only; no backwards-compatibility guarantees.
- applyTransform(String, InputT, PTransform<? super InputT, OutputT>) - Static method in class org.apache.beam.sdk.Pipeline
-
For internal use only; no backwards-compatibility guarantees.
- applyWindowing() - Method in class org.apache.beam.sdk.transforms.PeriodicImpulse
- approximatePTransformName(Class<?>) - Static method in class org.apache.beam.sdk.util.NameUtils
-
Returns a name for a PTransform class.
- ApproximateQuantiles - Class in org.apache.beam.sdk.transforms
-
PTransforms for getting an idea of aPCollection's data distribution using approximateN-tiles (e.g. - ApproximateQuantiles.ApproximateQuantilesCombineFn<T,ComparatorT extends java.util.Comparator<T> & java.io.Serializable> - Class in org.apache.beam.sdk.transforms
-
The
ApproximateQuantilesCombineFncombiner gives an idea of the distribution of a collection of values using approximateN-tiles. - approximateSimpleName(Object) - Static method in class org.apache.beam.sdk.util.NameUtils
-
As
NameUtils.approximateSimpleName(Object, String)but returning"Anonymous"whenobjectis an instance of anonymous class. - approximateSimpleName(Object, String) - Static method in class org.apache.beam.sdk.util.NameUtils
-
Returns a simple name describing a class that is being used as a function (eg., a
DoFnorCombine.CombineFn, etc.). - ApproximateUnique - Class in org.apache.beam.sdk.transforms
-
Deprecated.
Consider using
ApproximateCountDistinctin thezetasketchextension module, which makes use of theHllCountimplementation.If
ApproximateCountDistinctdoes not meet your needs then you can directly useHllCount. Direct usage will also give you access to save intermediate aggregation result into a sketch for later processing.For example, to estimate the number of distinct elements in a
PCollection<String>:
For more details about usingPCollection<String> input = ...; PCollection<Long> countDistinct = input.apply(HllCount.Init.forStrings().globally()).apply(HllCount.Extract.globally());HllCountand thezetasketchextension module, see https://s.apache.org/hll-in-beam#bookmark=id.v6chsij1ixo7. - ApproximateUnique() - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique
-
Deprecated.
- ApproximateUnique.ApproximateUniqueCombineFn<T> - Class in org.apache.beam.sdk.transforms
-
Deprecated.
CombineFnthat 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.
PTransformfor estimating the number of distinct elements in aPCollection. - ApproximateUnique.PerKey<K,V> - Class in org.apache.beam.sdk.transforms
-
Deprecated.
PTransformfor estimating the number of distinct values associated with each key in aPCollectionofKVs. - ApproximateUniqueCombineFn(long, Coder<T>) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
-
Deprecated.
- arbitrarily() - Static method in class org.apache.beam.sdk.transforms.Redistribute
- array(Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Create an array type for the given field type.
- array(Schema.FieldType, boolean) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Deprecated.Set the nullability on the elementType instead
- ARRAY - org.apache.beam.sdk.schemas.Schema.TypeName
- arrayContaining(List<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.arrayContaining(List). - arrayContaining(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.arrayContaining(Object[]). - arrayContaining(SerializableMatcher<? super T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.arrayContaining(Matcher[]). - arrayContaining(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.arrayContaining(Object[]). - arrayContainingInAnyOrder(Collection<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.arrayContainingInAnyOrder(Collection). - arrayContainingInAnyOrder(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.arrayContainingInAnyOrder(Object[]). - arrayContainingInAnyOrder(SerializableMatcher<? super T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.arrayContainingInAnyOrder(Matcher[]). - arrayContainingInAnyOrder(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.arrayContainingInAnyOrder(Object[]). - 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
- arrayToNewlines(Object[], int) - Static method in class org.apache.beam.sdk.util.StringUtils
-
Convert Array to new lined String.
- arrayWithSize(int) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.arrayWithSize(int). - arrayWithSize(SerializableMatcher<? super Integer>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.arrayWithSize(Matcher). - ArtifactResolver - Interface in org.apache.beam.sdk.util.construction
-
An interface for artifact resolvers.
- ArtifactResolver.ResolutionFn - Interface in org.apache.beam.sdk.util.construction
-
A lazy transformer for resolving
RunnerApi.ArtifactInformation. - as(Class<T>) - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
Transforms this object into an object of type
<T>saving each property that has been manipulated. - as(Class<T>) - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
-
Creates and returns an object that implements
<T>. - as(Class<T>) - Method in class org.apache.beam.sdk.options.PipelineOptionsFactory.Builder
-
Creates and returns an object that implements
<T>using the values configured on this builder during construction. - asIterable() - Static method in class org.apache.beam.sdk.transforms.View
-
Returns a
View.AsIterabletransform that takes aPCollectionas input and produces aPCollectionViewmapping each window to anIterableof the values in that window. - asList() - Static method in class org.apache.beam.sdk.transforms.View
-
Returns a
View.AsListtransform that takes aPCollectionand returns aPCollectionViewmapping each window to aListcontaining all of the elements in the window. - asMap() - Method in class org.apache.beam.sdk.transforms.display.DisplayData
- asMap() - Static method in class org.apache.beam.sdk.transforms.View
-
Returns a
View.AsMaptransform that takes aPCollection<KV<K, V>>as input and produces aPCollectionViewmapping each window to aMap<K, V>. - asMultimap() - Static method in class org.apache.beam.sdk.transforms.View
-
Returns a
View.AsMultimaptransform that takes aPCollection<KV<K, V>>as input and produces aPCollectionViewmapping each window to its contents as aMap<K, Iterable<V>>for use as a side input. - assertionError() - Method in class org.apache.beam.sdk.testing.SuccessOrFailure
- assertSourcesEqualReferenceSource(BoundedSource<T>, List<? extends BoundedSource<T>>, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Given a reference
Sourceand a list ofSources, assert that the union of the records read from the list of sources is equal to the records read from the reference source. - assertSplitAtFractionBehavior(BoundedSource<T>, int, double, SourceTestUtils.ExpectedSplitOutcome, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Asserts that the
source's reader either fails tosplitAtFraction(fraction)after readingnumItemsToReadBeforeSplititems, or succeeds in a way that is consistent according toSourceTestUtils.assertSplitAtFractionSucceedsAndConsistent(org.apache.beam.sdk.io.BoundedSource<T>, int, double, org.apache.beam.sdk.options.PipelineOptions). - assertSplitAtFractionExhaustive(BoundedSource<T>, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Asserts that for each possible start position,
BoundedSource.BoundedReader.splitAtFraction(double)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 tosplitAtFraction(fraction)after readingnumItemsToReadBeforeSplititems. - assertSplitAtFractionSucceedsAndConsistent(BoundedSource<T>, int, double, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Verifies some consistency properties of
BoundedSource.BoundedReader.splitAtFraction(double)on the given source. - assertUnstartedReaderReadsSameAsItsSource(BoundedSource.BoundedReader<T>, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Assert that a
Readerreturns aSourcethat, when read from, produces the same records as the reader. - assign(BoundedWindow, Instant) - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
-
Shorthand for
TimestampCombiner.merge(org.apache.beam.sdk.transforms.windowing.BoundedWindow, java.lang.Iterable<? extends org.joda.time.Instant>)with just one element, to place it into the context of a window. - ASSIGN_WINDOWS_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- 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
- AssignShardFn(Integer) - Constructor for class org.apache.beam.sdk.transforms.Reshuffle.AssignShardFn
- 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
WindowFnalways 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.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
- assignWindows(WindowFn.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
- assignWindows(WindowFn.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
- assignWindows(WindowFn.AssignContext) - Method in class org.apache.beam.sdk.util.IdentityWindowFn
- assignWindows(WindowFn.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn
- assignWindows(WindowFn.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(Instant) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
- asSingleton() - Static method in class org.apache.beam.sdk.transforms.View
-
Returns a
View.AsSingletontransform that takes aPCollectionwith a single value per window as input and produces aPCollectionViewthat returns the value in the main input window when read as a side input. - asSingletonView() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
Returns a
PTransformthat produces aPCollectionViewwhose elements are the result of combining elements per-window in the inputPCollection. - atMinimumTimestamp(V) - Static method in class org.apache.beam.sdk.values.TimestampedValue
-
Returns a new
TimestampedValuewith theminimum timestamp. - AtomicCoder<T> - Class in org.apache.beam.sdk.coders
- AtomicCoder() - Constructor for class org.apache.beam.sdk.coders.AtomicCoder
- AtomicLongFactory() - Constructor for class org.apache.beam.sdk.options.PipelineOptions.AtomicLongFactory
- attachValues(Object...) - Method in class org.apache.beam.sdk.values.Row.Builder
- attachValues(List<Object>) - Method in class org.apache.beam.sdk.values.Row.Builder
- attempted(MetricKey, T) - Static method in class org.apache.beam.sdk.metrics.MetricResult
- AUTO - org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.
- AUTO - org.apache.beam.sdk.io.Compression
-
When reading a file, automatically determine the compression type based on filename extension.
- AUTO - org.apache.beam.sdk.io.TextIO.CompressionType
-
Deprecated.
- AUTO - org.apache.beam.sdk.io.TFRecordIO.CompressionType
-
Deprecated.
- AutoValueSchema - Class in org.apache.beam.sdk.schemas
-
A
SchemaProviderfor AutoValue classes. - AutoValueSchema() - Constructor for class org.apache.beam.sdk.schemas.AutoValueSchema
- AutoValueSchema.AbstractGetterTypeSupplier - Class in org.apache.beam.sdk.schemas
-
FieldValueTypeSupplierthat's based on AutoValue getters. - AutoValueUtils - Class in org.apache.beam.sdk.schemas.utils
-
Utilities for managing AutoValue schemas.
- AutoValueUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.AutoValueUtils
- awaitCompletion() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataInboundObserver
-
Uses the callers thread to process all elements received until we receive the end of the stream from the upstream producer for all endpoints specified.
- awaitTermination(long, TimeUnit) - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
B
- BACKLOG_UNKNOWN - Static variable in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
-
Constant representing an unknown amount of backlog.
- backlogBytes() - Static method in class org.apache.beam.sdk.metrics.SourceMetrics
-
Gauge for source backlog in bytes.
- backlogBytesOfSplit(String) - Static method in class org.apache.beam.sdk.metrics.SourceMetrics
-
Gauge for source split backlog in bytes.
- backlogElements() - Static method in class org.apache.beam.sdk.metrics.SourceMetrics
-
Gauge for source backlog in elements.
- backlogElementsOfSplit(String) - Static method in class org.apache.beam.sdk.metrics.SourceMetrics
-
Gauge for source split backlog in elements.
- backoff() - Method in class org.apache.beam.sdk.util.FluentBackoff
-
Instantiates a
BackOffthat will obey the current configuration. - BackOff - Interface in org.apache.beam.sdk.util
-
Back-off policy when retrying an operation.
- BackOffUtils - Class in org.apache.beam.sdk.util
-
Utilities for
BackOff. - BAD_RECORD_TAG - Static variable in interface org.apache.beam.sdk.transforms.errorhandling.BadRecordRouter
- BadRecord - Class in org.apache.beam.sdk.transforms.errorhandling
- BadRecord() - Constructor for class org.apache.beam.sdk.transforms.errorhandling.BadRecord
- BadRecord.Builder - Class in org.apache.beam.sdk.transforms.errorhandling
- BadRecord.Failure - Class in org.apache.beam.sdk.transforms.errorhandling
- BadRecord.Failure.Builder - Class in org.apache.beam.sdk.transforms.errorhandling
- BadRecord.Record - Class in org.apache.beam.sdk.transforms.errorhandling
- BadRecord.Record.Builder - Class in org.apache.beam.sdk.transforms.errorhandling
- BadRecordErrorHandler(PTransform<PCollection<BadRecord>, OutputT>, Pipeline) - Constructor for class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.BadRecordErrorHandler
-
Constructs a new ErrorHandler for handling BadRecords.
- BadRecordRouter - Interface in org.apache.beam.sdk.transforms.errorhandling
- BadRecordRouter.RecordingBadRecordRouter - Class in org.apache.beam.sdk.transforms.errorhandling
- BadRecordRouter.ThrowingBadRecordRouter - Class in org.apache.beam.sdk.transforms.errorhandling
- bag() - Static method in class org.apache.beam.sdk.state.StateSpecs
- bag(Coder<T>) - Static method in class org.apache.beam.sdk.state.StateSpecs
-
Identical to
StateSpecs.bag(), but with an element coder explicitly supplied. - BAG_USER_STATE - Static variable in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
Represents a user state specification that supports a bag.
- BagState<T> - Interface in org.apache.beam.sdk.state
-
A
ReadableStatecell containing a bag of values. - BASE_IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.FixedPrecisionNumeric
-
Identifier of the unspecified precision numeric type.
- BaseArgumentProvider() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- baseNameBuilder(String) - Static method in class org.apache.beam.sdk.metrics.LabeledMetricNameUtils.MetricNameBuilder
- BatchingParams() - Constructor for class org.apache.beam.sdk.transforms.GroupIntoBatches.BatchingParams
- BeamFnDataGrpcMultiplexer - Class in org.apache.beam.sdk.fn.data
-
A gRPC multiplexer for a specific
Endpoints.ApiServiceDescriptor. - BeamFnDataGrpcMultiplexer(Endpoints.ApiServiceDescriptor, OutboundObserverFactory, OutboundObserverFactory.BasicFactory<BeamFnApi.Elements, BeamFnApi.Elements>) - Constructor for class org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer
- BeamFnDataInboundObserver - Class in org.apache.beam.sdk.fn.data
- BeamFnDataInboundObserver.CloseException - Exception in org.apache.beam.sdk.fn.data
- BeamFnDataOutboundAggregator - Class in org.apache.beam.sdk.fn.data
-
An outbound data buffering aggregator with size-based buffer and time-based buffer if corresponding options are set.
- BeamFnDataOutboundAggregator(PipelineOptions, Supplier<String>, StreamObserver<BeamFnApi.Elements>, boolean) - Constructor for class org.apache.beam.sdk.fn.data.BeamFnDataOutboundAggregator
- beamSchemaFromJsonSchema(String) - Static method in class org.apache.beam.sdk.schemas.utils.JsonUtils
- BeamUrns - Class in org.apache.beam.sdk.util.construction
-
Returns the standard URN of a given enum annotated with [(standard_urn)].
- BeamUrns() - Constructor for class org.apache.beam.sdk.util.construction.BeamUrns
- beforeProcessing(PipelineOptions) - Method in interface org.apache.beam.sdk.harness.JvmInitializer
-
Implement beforeProcessing to run some custom initialization after basic services such as logging, but before data processing begins.
- beforeStart(ClientCallStreamObserver<RespT>) - Method in class org.apache.beam.sdk.fn.stream.ForwardingClientResponseObserver
- begin() - Method in class org.apache.beam.sdk.Pipeline
-
Returns a
PBeginowned by this Pipeline. - beginningOnDay(int) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
- beginningOnDay(int, int) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
- BigDecimalCoder - Class in org.apache.beam.sdk.coders
-
A
BigDecimalCoderencodes aBigDecimalas an integer scale encoded withVarIntCoderand aBigIntegerencoded usingBigIntegerCoder. - bigdecimals() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorfor BigDecimal. - BigEndianIntegerCoder - Class in org.apache.beam.sdk.coders
-
A
BigEndianIntegerCoderencodesIntegersin 4 bytes, big-endian. - BigEndianLongCoder - Class in org.apache.beam.sdk.coders
-
A
BigEndianLongCoderencodesLongsin 8 bytes, big-endian. - BigEndianShortCoder - Class in org.apache.beam.sdk.coders
-
A
BigEndianShortCoderencodesShortsin 2 bytes, big-endian. - BigIntegerCoder - Class in org.apache.beam.sdk.coders
-
A
BigIntegerCoderencodes aBigIntegeras a byte array containing the big endian two's-complement representation, encoded viaByteArrayCoder. - bigintegers() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorfor BigInteger. - BINARY - Static variable in class org.apache.beam.sdk.util.MimeTypes
- BinaryCombineDoubleFn() - Constructor for class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
- BinaryCombineFn() - Constructor for class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
- BinaryCombineIntegerFn() - Constructor for class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
- BinaryCombineLongFn() - Constructor for class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
- bind(String, StateBinder) - Method in interface org.apache.beam.sdk.state.StateSpec
-
For internal use only; no backwards-compatibility guarantees.
- bindBag(String, StateSpec<BagState<T>>, Coder<T>) - Method in interface org.apache.beam.sdk.state.StateBinder
- bindCombining(String, StateSpec<CombiningState<InputT, AccumT, OutputT>>, Coder<AccumT>, Combine.CombineFn<InputT, AccumT, OutputT>) - Method in interface org.apache.beam.sdk.state.StateBinder
- bindCombiningWithContext(String, StateSpec<CombiningState<InputT, AccumT, OutputT>>, Coder<AccumT>, CombineWithContext.CombineFnWithContext<InputT, AccumT, OutputT>) - Method in interface org.apache.beam.sdk.state.StateBinder
- bindContext(CombineWithContext.CombineFnWithContext<InputT, AccumT, OutputT>, StateContext<?>) - Static method in class org.apache.beam.sdk.util.CombineFnUtil
-
Returns the partial application of the
CombineWithContext.CombineFnWithContextto a specific context to produce aCombine.CombineFn. - bindMap(String, StateSpec<MapState<KeyT, ValueT>>, Coder<KeyT>, Coder<ValueT>) - Method in interface org.apache.beam.sdk.state.StateBinder
- bindMultimap(String, StateSpec<MultimapState<KeyT, ValueT>>, Coder<KeyT>, Coder<ValueT>) - Method in interface org.apache.beam.sdk.state.StateBinder
- bindOrderedList(String, StateSpec<OrderedListState<T>>, Coder<T>) - Method in interface org.apache.beam.sdk.state.StateBinder
- bindSet(String, StateSpec<SetState<T>>, Coder<T>) - Method in interface org.apache.beam.sdk.state.StateBinder
- bindValue(String, StateSpec<ValueState<T>>, Coder<T>) - Method in interface org.apache.beam.sdk.state.StateBinder
- bindWatermark(String, StateSpec<WatermarkHoldState>, TimestampCombiner) - Method in interface org.apache.beam.sdk.state.StateBinder
-
Bind to a watermark
StateSpec. - BitSetCoder - Class in org.apache.beam.sdk.coders
-
Coder for
BitSet. - BitSetCoder - Class in org.apache.beam.sdk.util
-
Deprecated.use
BitSetCoderinstead - Block() - Constructor for class org.apache.beam.sdk.io.BlockBasedSource.Block
- BlockBasedReader(BlockBasedSource<T>) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
- BlockBasedSource<T> - Class in org.apache.beam.sdk.io
-
A
BlockBasedSourceis aFileBasedSourcewhere a file consists of blocks of records. - BlockBasedSource(String, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
-
Like
BlockBasedSource(String, EmptyMatchTreatment, long)but with a defaultEmptyMatchTreatmentofEmptyMatchTreatment.DISALLOW. - BlockBasedSource(String, EmptyMatchTreatment, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
-
Creates a
BlockBasedSourcebased on a file name or pattern. - BlockBasedSource(MatchResult.Metadata, long, long, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
-
Creates a
BlockBasedSourcefor a single file. - BlockBasedSource(ValueProvider<String>, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
- BlockBasedSource(ValueProvider<String>, EmptyMatchTreatment, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
- BlockBasedSource.Block<T> - Class in org.apache.beam.sdk.io
-
A
Blockrepresents a block of records that can be read. - BlockBasedSource.BlockBasedReader<T> - Class in org.apache.beam.sdk.io
-
A
Readerthat reads records from aBlockBasedSource. - BOOL_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- BOOLEAN - org.apache.beam.sdk.schemas.Schema.TypeName
- BOOLEAN - org.apache.beam.sdk.transforms.display.DisplayData.Type
- BOOLEAN - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
-
The type of boolean fields.
- BooleanCoder - Class in org.apache.beam.sdk.coders
-
A
CoderforBoolean. - BooleanCoder() - Constructor for class org.apache.beam.sdk.coders.BooleanCoder
- booleans() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorfor Boolean. - BOUNDED - org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.IsBounded
-
Indicates that a
Restrictionrepresents a bounded amount of work. - BOUNDED - org.apache.beam.sdk.values.PCollection.IsBounded
-
Indicates that a
PCollectioncontains a bounded number of elements. - BoundedReader() - Constructor for class org.apache.beam.sdk.io.BoundedSource.BoundedReader
- BoundedReadFromUnboundedSource<T> - Class in org.apache.beam.sdk.io
-
PTransformthat reads a bounded amount of data from anUnboundedSource, specified as one or both of a maximum number of elements or a maximum period of time to read. - BoundedSource<T> - Class in org.apache.beam.sdk.io
-
A
Sourcethat reads a finite amount of input and, because of that, supports some additional operations. - BoundedSource() - Constructor for class org.apache.beam.sdk.io.BoundedSource
- BoundedSource.BoundedReader<T> - Class in org.apache.beam.sdk.io
-
A
Readerthat reads a bounded amount of input and supports some additional operations, such as progress estimation and dynamic work rebalancing. - boundedSourceFromProto(RunnerApi.ReadPayload) - Static method in class org.apache.beam.sdk.util.construction.ReadTranslation
- boundedSourceFromTransform(AppliedPTransform<PBegin, PCollection<T>, PTransform<PBegin, PCollection<T>>>) - Static method in class org.apache.beam.sdk.util.construction.ReadTranslation
- BoundedToUnboundedSourceAdapter(BoundedSource<T>) - Constructor for class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter
- boundedTrie(Class<?>, String) - Static method in class org.apache.beam.sdk.metrics.Metrics
-
Create a metric that accumulates and reports set of unique string values bounded to a max limit.
- boundedTrie(String, String) - Static method in class org.apache.beam.sdk.metrics.Metrics
-
Create a metric that accumulates and reports set of unique string values bounded to a max limit.
- BoundedTrie - Interface in org.apache.beam.sdk.metrics
-
Internal: For internal use only and not for public consumption.
- BoundedTrieResult - Class in org.apache.beam.sdk.metrics
-
Internal: For internal use only and not for public consumption.
- BoundedTrieResult() - Constructor for class org.apache.beam.sdk.metrics.BoundedTrieResult
- boundedWindow(TypeDescriptor<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
-
Returns a
DoFnSignature.Parameter.WindowParameter. - BoundedWindow - Class in org.apache.beam.sdk.transforms.windowing
-
A
BoundedWindowrepresents window information assigned to data elements. - BoundedWindow() - Constructor for class org.apache.beam.sdk.transforms.windowing.BoundedWindow
- boxIfPrimitive(TypeDescriptor) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
- BucketingFunction - Class in org.apache.beam.sdk.util
-
Keep track of the minimum/maximum/sum of a set of timestamped long values.
- BucketingFunction(long, int, int, Combine.BinaryCombineLongFn) - Constructor for class org.apache.beam.sdk.util.BucketingFunction
- BufferedElementCountingOutputStream - Class in org.apache.beam.sdk.util
-
Provides an efficient encoding for
Iterables containing small values by buffering up tobufferSizebytes of data before prefixing the count. - BufferedElementCountingOutputStream(OutputStream) - Constructor for class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
-
Creates an output stream which encodes the number of elements output to it in a streaming manner.
- BufferedElementCountingOutputStream(OutputStream, long) - Constructor for class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
- BufferingStreamObserver<T extends @NonNull java.lang.Object> - Class in org.apache.beam.sdk.fn.stream
-
A thread safe
StreamObserverwhich uses a bounded queue to pass elements to a processing thread responsible for interacting with the underlyingCallStreamObserver. - BufferingStreamObserver(Phaser, CallStreamObserver<T>, ExecutorService, int) - Constructor for class org.apache.beam.sdk.fn.stream.BufferingStreamObserver
- build() - Method in class org.apache.beam.sdk.fn.test.TestStreams.Builder
- build() - Method in class org.apache.beam.sdk.io.fs.CreateOptions.StandardCreateOptions.Builder
- build() - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
- build() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
- build() - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformConfiguration.Builder
-
Builds the
TFRecordReadSchemaTransformConfigurationconfiguration. - build() - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration.Builder
-
Builds the
TFRecordWriteSchemaTransformConfigurationconfiguration. - build() - Method in class org.apache.beam.sdk.metrics.MetricsFilter.Builder
- build() - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Builder
- build() - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate.Builder
- build() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Builder
- build() - Method in class org.apache.beam.sdk.schemas.io.Failure.Builder
- build() - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- build() - Method in class org.apache.beam.sdk.schemas.Schema.Field.Builder
- build() - Method in class org.apache.beam.sdk.schemas.Schema.Options.Builder
- build() - Method in class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling.Builder
- build() - Method in class org.apache.beam.sdk.schemas.transforms.providers.FlattenTransformProvider.Configuration.Builder
- build() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider.Configuration.Builder
- build() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider.Configuration.Builder
- build() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration.Builder
- build() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration.Builder
- build() - Method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider.Configuration.Builder
- build() - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Builder
- build() - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Failure.Builder
- build() - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record.Builder
- build() - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError.Builder
- build() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter.Builder
- build() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SideInputParameter.Builder
- build() - Method in class org.apache.beam.sdk.util.InstanceBuilder
-
Creates the instance by calling the factory method with the given arguments.
- build() - Method in class org.apache.beam.sdk.values.Row.Builder
- build() - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
- build() - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- build(String) - Method in class org.apache.beam.sdk.metrics.LabeledMetricNameUtils.MetricNameBuilder
- builder() - Static method in class org.apache.beam.sdk.io.fs.CreateOptions.StandardCreateOptions
-
Returns a
CreateOptions.StandardCreateOptions.Builder. - builder() - Static method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata
- builder() - Static method in class org.apache.beam.sdk.io.TextRowCountEstimator
- builder() - Static method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformConfiguration
-
Instantiates a
TFRecordReadSchemaTransformConfiguration.Builderinstance. - builder() - Static method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration
-
Instantiates a
TFRecordWriteSchemaTransformConfiguration.Builderinstance. - builder() - Static method in class org.apache.beam.sdk.metrics.MetricsFilter
- builder() - Static method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration
- builder() - Static method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate
- builder() - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
- builder() - Static method in class org.apache.beam.sdk.schemas.Schema
- builder() - Static method in class org.apache.beam.sdk.schemas.Schema.Options
- builder() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling
- builder() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.FlattenTransformProvider.Configuration
- builder() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider.Configuration
- builder() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider.Configuration
- builder() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration
- builder() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration
- builder() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider.Configuration
- builder() - Static method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord
- builder() - Static method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Failure
- builder() - Static method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record
- builder() - Static method in class org.apache.beam.sdk.values.WindowedValues
- builder(WindowedValue<T>) - Static method in class org.apache.beam.sdk.values.WindowedValues
-
Create a Builder that takes element metadata from the provideed delegate.
- builder(OutputT) - Method in interface org.apache.beam.sdk.util.OutputBuilderSupplier
- builder(T) - Method in class org.apache.beam.sdk.testing.TestOutputReceiver
- builder(T) - Method in interface org.apache.beam.sdk.transforms.DoFn.OutputReceiver
- Builder() - Constructor for class org.apache.beam.sdk.io.fs.CreateOptions.Builder
- Builder() - Constructor for class org.apache.beam.sdk.io.fs.CreateOptions.StandardCreateOptions.Builder
- Builder() - Constructor for class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
- Builder() - Constructor for class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
- Builder() - Constructor for class org.apache.beam.sdk.io.TFRecordReadSchemaTransformConfiguration.Builder
- Builder() - Constructor for class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration.Builder
- Builder() - Constructor for class org.apache.beam.sdk.metrics.MetricsFilter.Builder
- Builder() - Constructor for class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Builder
- Builder() - Constructor for class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate.Builder
- Builder() - Constructor for class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Builder
- Builder() - Constructor for class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
- Builder() - Constructor for class org.apache.beam.sdk.schemas.io.Failure.Builder
- Builder() - Constructor for class org.apache.beam.sdk.schemas.Schema.Builder
- Builder() - Constructor for class org.apache.beam.sdk.schemas.Schema.Field.Builder
- Builder() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling.Builder
- Builder() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.FlattenTransformProvider.Configuration.Builder
- Builder() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider.Configuration.Builder
- Builder() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider.Configuration.Builder
- Builder() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration.Builder
- Builder() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration.Builder
- Builder() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider.Configuration.Builder
- Builder() - Constructor for class org.apache.beam.sdk.transforms.DoFnSchemaInformation.Builder
- Builder() - Constructor for class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Builder
- Builder() - Constructor for class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Failure.Builder
- Builder() - Constructor for class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record.Builder
- Builder() - Constructor for class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.Builder
- Builder() - Constructor for class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError.Builder
- Builder() - Constructor for class org.apache.beam.sdk.transforms.JsonToRow.ParseResult.Builder
- Builder() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter.Builder
- Builder() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SideInputParameter.Builder
- Builder() - Constructor for class org.apache.beam.sdk.values.WindowedValues.Builder
- buildExternal(ConfigT) - Method in interface org.apache.beam.sdk.transforms.ExternalTransformBuilder
-
Builds the transform after it has been configured.
- buildReader() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIO
-
Returns a schema aware reader.
- buildTemporaryFilename(ResourceId, String) - Static method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
-
Constructs a temporary file resource given the temporary directory and a filename.
- buildWriter() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIO
-
Returns a schema aware writer.
- bundleFinalizer() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provide a
DoFn.BundleFinalizerfor being able to register a callback after the bundle has been successfully persisted by the runner. - bundleFinalizer() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- bundleFinalizer() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- bundleFinalizer() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- BundleMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.BundleMethod
- BundleProcessorCacheTimeoutFactory() - Constructor for class org.apache.beam.sdk.options.SdkHarnessOptions.BundleProcessorCacheTimeoutFactory
- by(Contextful<Contextful.Fn<UserT, DestinationT>>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Like
FileIO.Write.by(org.apache.beam.sdk.transforms.SerializableFunction<UserT, DestinationT>), but with access to context such as side inputs. - by(SerializableFunction<UserT, DestinationT>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Specifies how to partition elements into groups ("destinations").
- by(PredicateT) - Static method in class org.apache.beam.sdk.transforms.Filter
-
Returns a
PTransformthat takes an inputPCollection<T>and returns aPCollection<T>with elements that satisfy the given predicate. - By() - Constructor for class org.apache.beam.sdk.schemas.transforms.CoGroup.By
- byFieldAccessDescriptor(FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
-
Returns a transform that groups all elements in the input
PCollectionkeyed by the fields specified. - byFieldIds(Integer...) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
-
Returns a transform that groups all elements in the input
PCollectionkeyed by the list of fields specified. - byFieldIds(Iterable<Integer>) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
-
Same as
Group.byFieldIds(Integer...). - byFieldNames(Iterable<String>) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
-
Same as
Group.byFieldNames(String...). - byFieldNames(String...) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
-
Returns a transform that groups all elements in the input
PCollectionkeyed by the list of fields specified. - ByFields() - Constructor for class org.apache.beam.sdk.schemas.transforms.Group.ByFields
- byKey() - Static method in class org.apache.beam.sdk.transforms.Redistribute
- BYTE - org.apache.beam.sdk.schemas.Schema.TypeName
- BYTE - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
-
The type of byte fields.
- ByteArrayCoder - Class in org.apache.beam.sdk.coders
-
A
Coderforbyte[]. - byteArrayToJsonString(byte[]) - Static method in class org.apache.beam.sdk.util.StringUtils
-
Converts the given array of bytes into a legal JSON string.
- ByteBuddyUtils - Class in org.apache.beam.sdk.schemas.utils
- ByteBuddyUtils - Class in org.apache.beam.sdk.util
-
Utilities for working with Byte Buddy.
- ByteBuddyUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils
- ByteBuddyUtils.ConvertType - Class in org.apache.beam.sdk.schemas.utils
-
Give a Java type, returns the Java type expected for use with Row.
- ByteBuddyUtils.ConvertValueForGetter - Class in org.apache.beam.sdk.schemas.utils
-
Takes a
StackManipulationthat returns a value. - ByteBuddyUtils.ConvertValueForSetter - Class in org.apache.beam.sdk.schemas.utils
-
Row is going to call the setter with its internal Java type, however the user object being set might have a different type internally.
- ByteBuddyUtils.DefaultTypeConversionsFactory - Class in org.apache.beam.sdk.schemas.utils
- ByteBuddyUtils.InjectPackageStrategy - Class in org.apache.beam.sdk.schemas.utils
-
A naming strategy for ByteBuddy classes.
- ByteBuddyUtils.TransformingMap<K1,V1,K2,V2> - Class in org.apache.beam.sdk.schemas.utils
- ByteBuddyUtils.TypeConversion<T> - Class in org.apache.beam.sdk.schemas.utils
- ByteBuddyUtils.TypeConversionsFactory - Interface in org.apache.beam.sdk.schemas.utils
- ByteCoder - Class in org.apache.beam.sdk.coders
-
A
ByteCoderencodesBytevalues in 1 byte using Java serialization. - ByteKey - Class in org.apache.beam.sdk.io.range
-
A class representing a key consisting of an array of bytes.
- ByteKeyRange - Class in org.apache.beam.sdk.io.range
-
A class representing a range of
ByteKeys. - ByteKeyRangeTracker - Class in org.apache.beam.sdk.io.range
- ByteKeyRangeTracker - Class in org.apache.beam.sdk.transforms.splittabledofn
- bytes() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorfor Byte. - BYTES - org.apache.beam.sdk.schemas.Schema.TypeName
- BYTES - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
-
The type of bytes fields.
- BYTES_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- bytesRead() - Static method in class org.apache.beam.sdk.metrics.SourceMetrics
-
Counter of bytes read by a source.
- bytesReadBySplit(String) - Static method in class org.apache.beam.sdk.metrics.SourceMetrics
-
Counter of bytes read by a source split.
- bytesToRowFn(SchemaProvider, TypeDescriptor<T>, Coder<? extends T>) - Static method in class org.apache.beam.sdk.schemas.RowMessages
- bytesToRowFn(SchemaProvider, TypeDescriptor<T>, ProcessFunction<byte[], ? extends T>) - Static method in class org.apache.beam.sdk.schemas.RowMessages
- ByteStringOutputStream - Class in org.apache.beam.sdk.util
-
An
OutputStreamthat producesByteStrings. - ByteStringOutputStream() - Constructor for class org.apache.beam.sdk.util.ByteStringOutputStream
-
Creates a new output stream with a default capacity.
- ByteStringOutputStream(int) - Constructor for class org.apache.beam.sdk.util.ByteStringOutputStream
-
Creates a new output stream with the specified initial capacity.
- bytesWritten() - Static method in class org.apache.beam.sdk.metrics.SinkMetrics
-
Counter of bytes written to a sink.
- BZIP2 - org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.
- BZIP2 - org.apache.beam.sdk.io.Compression
-
BZip compression.
- BZIP2 - org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.
- BZIP2 - org.apache.beam.sdk.io.TextIO.CompressionType
-
Deprecated.
C
- CACHED_CREATORS - Static variable in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
- CACHED_CREATORS - Static variable in class org.apache.beam.sdk.schemas.utils.POJOUtils
- CachingFactory<CreatedT extends @NonNull java.lang.Object> - Class in org.apache.beam.sdk.schemas
-
A wrapper around a
Factorythat assumes the schema parameter never changes. - CachingFactory(Factory<CreatedT>) - Constructor for class org.apache.beam.sdk.schemas.CachingFactory
- CalendarWindows - Class in org.apache.beam.sdk.transforms.windowing
-
A collection of
WindowFns that windows values into calendar-based windows such as spans of days, months, or years. - CalendarWindows() - Constructor for class org.apache.beam.sdk.transforms.windowing.CalendarWindows
- CalendarWindows.DaysWindows - Class in org.apache.beam.sdk.transforms.windowing
-
A
WindowFnthat windows elements into periods measured by days. - CalendarWindows.MonthsWindows - Class in org.apache.beam.sdk.transforms.windowing
-
A
WindowFnthat windows elements into periods measured by months. - CalendarWindows.YearsWindows - Class in org.apache.beam.sdk.transforms.windowing
-
A
WindowFnthat windows elements into periods measured by years. - cancel() - Method in interface org.apache.beam.sdk.PipelineResult
-
Cancels the pipeline execution.
- cancel(Exception) - Method in class org.apache.beam.sdk.fn.CancellableQueue
-
Causes any pending and future
CancellableQueue.put(T)andCancellableQueue.take()invocations to throw an exception. - CancellableQueue<T extends @NonNull java.lang.Object> - Class in org.apache.beam.sdk.fn
-
A simplified
ThreadSafeblocking queue that can be cancelled freeing any blockedThreads and preventing futureThreads from blocking. - CancellableQueue(int) - Constructor for class org.apache.beam.sdk.fn.CancellableQueue
-
Creates a
ThreadSafeblocking queue with a maximum capacity. - CANCELLED - org.apache.beam.sdk.PipelineResult.State
-
The job has been explicitly cancelled.
- CannotProvideCoderException - Exception in org.apache.beam.sdk.coders
-
The exception thrown when a
CoderRegistryorCoderProvidercannot provide aCoderthat has been requested. - CannotProvideCoderException(String) - 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(String, 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
Coderinference failed. - canStopPolling(Instant, StateT) - Method in interface org.apache.beam.sdk.transforms.Watch.Growth.TerminationCondition
-
Called by the
Watchtransform to determine whether the given termination state signals thatWatchshould stop callingWatch.Growth.PollFnfor the current input, regardless of whether the lastWatch.Growth.PollResultwas complete or incomplete. - canTranslate(PTransform<?, ?>) - Method in class org.apache.beam.sdk.util.construction.ExternalTranslation.ExternalTranslator
- canTranslate(PTransform<?, ?>) - Method in class org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoTranslator
- canTranslate(PTransform<?, ?>) - Method in interface org.apache.beam.sdk.util.construction.PTransformTranslation.TransformTranslator
- 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
- catchUpToNow - Variable in class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
- catchUpToNow(boolean) - Method in class org.apache.beam.sdk.transforms.PeriodicImpulse
-
For internal use only; no backwards-compatibility guarantees.
- channelNames - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- characters() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorfor Character. - checkArgumentNotNull(T) - Static method in class org.apache.beam.sdk.util.Preconditions
-
Ensures that an object reference passed as a parameter to the calling method is not null.
- checkArgumentNotNull(T, Object) - Static method in class org.apache.beam.sdk.util.Preconditions
-
Ensures that an object reference passed as a parameter to the calling method is not null.
- checkArgumentNotNull(T, String, 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, 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) - 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) - 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) - 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, 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.
- Checkpoint(List<TimestampedValue<T>>, BoundedSource<T>) - Constructor for class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter.Checkpoint
- checkStateNotNull(T) - Static method in class org.apache.beam.sdk.util.Preconditions
-
Ensures that a piece of state is not null.
- checkStateNotNull(T, Object) - Static method in class org.apache.beam.sdk.util.Preconditions
-
Ensures that a piece of state passed as a parameter to the calling method is not null.
- checkStateNotNull(T, String, Object) - Static method in class org.apache.beam.sdk.util.Preconditions
-
Ensures that a piece of state is not null.
- checkStateNotNull(T, String, Object...) - Static method in class org.apache.beam.sdk.util.Preconditions
-
Ensures that a piece of state passed as a parameter to the calling method is not null.
- checkStateNotNull(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.
- checksum() - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata
-
An optional checksum to identify the contents of a file.
- classEqualTo(Class<? extends PTransform>) - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
Returns a
PTransformMatcherthat matches aPTransformif the class of thePTransformis equal to theClassprovided ot this matcher. - classesInPackage(String) - Static method in class org.apache.beam.sdk.util.ApiSurface
-
A factory method to create a
Classmatcher for classes residing in a given package. - ClassLoaderFileSystem - Class in org.apache.beam.sdk.io
-
A read-only
FileSystemimplementation looking up resources using a ClassLoader. - ClassLoaderFileSystem.ClassLoaderFileSystemRegistrar - Class in org.apache.beam.sdk.io
-
AutoServiceregistrar for theClassLoaderFileSystem. - ClassLoaderFileSystem.ClassLoaderResourceId - Class in org.apache.beam.sdk.io
- ClassLoaderFileSystemRegistrar() - Constructor for class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderFileSystemRegistrar
- ClasspathScanningResourcesDetector - Class in org.apache.beam.sdk.util.construction.resources
-
Attempts to detect all the resources to be staged using classgraph library.
- ClasspathScanningResourcesDetector(ClassGraph) - Constructor for class org.apache.beam.sdk.util.construction.resources.ClasspathScanningResourcesDetector
- ClasspathScanningResourcesDetectorFactory() - Constructor for class org.apache.beam.sdk.util.construction.resources.PipelineResourcesOptions.ClasspathScanningResourcesDetectorFactory
- 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 interface org.apache.beam.sdk.state.Timer
-
Clears a timer.
- clear() - Method in class org.apache.beam.sdk.util.HistogramData
- cleared(K, String, Collection<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.util.construction.Timer
-
Returns a cleared timer for the given
userKey,dynamicTimerTagandwindows. - clearOutputElements() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - clearOutputElements(TupleTag<T>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - clearRange(Instant, Instant) - Method in interface org.apache.beam.sdk.state.OrderedListState
-
Clear a timestamp-limited subrange of the list.
- clientBuffered(ExecutorService) - Static method in class org.apache.beam.sdk.fn.stream.OutboundObserverFactory
-
Create a buffering
OutboundObserverFactoryfor client-side RPCs with the specifiedExecutorServiceand the default buffer size. - clientBuffered(ExecutorService, int) - Static method in class org.apache.beam.sdk.fn.stream.OutboundObserverFactory
-
Create a buffering
OutboundObserverFactoryfor client-side RPCs with the specifiedExecutorServiceand buffer size. - clientDirect() - Static method in class org.apache.beam.sdk.fn.stream.OutboundObserverFactory
-
Create the default
OutboundObserverFactoryfor client-side RPCs, which uses basic unbuffered flow control. - 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
- CLONE_ONCE - org.apache.beam.sdk.transforms.DoFnTester.CloningBehavior
-
Deprecated.
- CLONE_PER_BUNDLE - org.apache.beam.sdk.transforms.DoFnTester.CloningBehavior
-
Deprecated.Clone the
DoFnand callDoFn.Setupevery time a bundle starts; callDoFn.Teardownevery time a bundle finishes. - clonesOf(OutT) - Static method in class org.apache.beam.sdk.transforms.SerializableFunctions
- close() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer
- close() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataInboundObserver
- close() - Method in interface org.apache.beam.sdk.fn.data.CloseableFnDataReceiver
-
.
- close() - Method in interface org.apache.beam.sdk.fn.server.FnService
-
.
- close() - Method in class org.apache.beam.sdk.fn.server.GrpcFnServer
- close() - Method in class org.apache.beam.sdk.fn.stream.DataStreams.ElementDelimitedOutputStream
- 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
ReadableByteChannelcreated for the current reader. - close() - Method in class org.apache.beam.sdk.io.Source.Reader
-
Closes the reader.
- close() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - close() - Method in class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.DefaultErrorHandler
- close() - Method in class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.PTransformErrorHandler
- close() - Method in class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
- close() - Method in class org.apache.beam.sdk.util.construction.DefaultExpansionServiceClientFactory
- close() - Method in class org.apache.beam.sdk.util.construction.TransformUpgrader
- 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
- CloseableFnDataReceiver<T> - Interface in org.apache.beam.sdk.fn.data
-
A receiver of streamed data that can be closed.
- CloseableThrowingConsumer<ExceptionT extends java.lang.Exception,T> - Interface in org.apache.beam.sdk.function
-
A
ThrowingConsumerthat can be closed. - closeTo(double, double) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.closeTo(double,double). - coder - Variable in class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform
- Coder<T> - Class in org.apache.beam.sdk.coders
-
A
Coder<T>defines how to encode and decode values of typeTinto byte streams. - Coder() - Constructor for class org.apache.beam.sdk.coders.Coder
- Coder() - Constructor for class org.apache.beam.sdk.io.range.OffsetRange.Coder
- Coder.Context - Class in org.apache.beam.sdk.coders
-
Deprecated.To implement a coder, do not use any
Coder.Context. Just implement only those abstract methods which do not accept aCoder.Contextand leave the default implementations for methods accepting aCoder.Context. - Coder.NonDeterministicException - Exception in org.apache.beam.sdk.coders
-
Exception thrown by
Coder.verifyDeterministic()if the encoding is not deterministic, including details of why the encoding is not deterministic. - coderConsistentWithEquals(Coder<T>, T, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
-
Verifies that for the given
Coder<T>and values of typeT, 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 typeT, the values are equal if and only if the encoded bytes are equal, in anyCoder.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 typeCollection<T>, encoding followed by decoding yields an equal value of typeCollection<T>, in anyCoder.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 typeCollection<T>, encoding followed by decoding yields an equal value of typeCollection<T>, in the givenCoder.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 typeCollection<T>, encoding followed by decoding yields an equal value of typeCollection<T>, in anyCoder.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 typeIterable<T>, encoding followed by decoding yields an equal value of typeCollection<T>, in the givenCoder.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 typeT, encoding followed by decoding yields an equal value of typeT, in anyCoder.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 typeT, encoding followed by decoding yields an equal value of typeT. - 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 typeT, encoding followed by decoding yields a value of typeTand 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 typeT, if the values are equal then the encoded bytes are equal, in anyCoder.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 typeT, if the values are equal then the encoded bytes are equal. - coderEncodesBase64(Coder<T>, List<T>, List<String>) - Static method in class org.apache.beam.sdk.testing.CoderProperties
- coderEncodesBase64(Coder<T>, T, String) - Static method in class org.apache.beam.sdk.testing.CoderProperties
- CoderException - Exception in org.apache.beam.sdk.coders
-
An
Exceptionthrown 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. - coderFor(TypeDescriptor<T>, List<? extends Coder<?>>) - Method in class org.apache.beam.sdk.coders.DefaultCoder.DefaultCoderProviderRegistrar.DefaultCoderProvider
-
Returns the
Coderreturned according to theCoderProviderfrom anyDefaultCoderannotation on the given class. - 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
Codertests. - CoderProperties() - Constructor for class org.apache.beam.sdk.testing.CoderProperties
- CoderProperties.TestElementByteSizeObserver - Class in org.apache.beam.sdk.testing
-
An
ElementByteSizeObserverthat records the observed element sizes for testing purposes. - CoderProvider - Class in org.apache.beam.sdk.coders
-
A
CoderProviderprovidesCoders. - CoderProvider() - Constructor for class org.apache.beam.sdk.coders.CoderProvider
- CoderProviderRegistrar - Interface in org.apache.beam.sdk.coders
- CoderProviders - Class in org.apache.beam.sdk.coders
-
Static utility methods for creating and working with
CoderProviders. - CoderRegistry - Class in org.apache.beam.sdk.coders
- 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. - CoderTranslation - Class in org.apache.beam.sdk.util.construction
-
Converts to and from Beam Runner API representations of
Coders. - CoderTranslation() - Constructor for class org.apache.beam.sdk.util.construction.CoderTranslation
- CoderTranslation.TranslationContext - Interface in org.apache.beam.sdk.util.construction
-
Pass through additional parameters beyond the components and payload to be able to translate specific coders.
- CoderTranslator<T extends Coder<?>> - Interface in org.apache.beam.sdk.util.construction
-
An interface that translates coders to components and back.
- CoderTranslatorRegistrar - Interface in org.apache.beam.sdk.util.construction
-
A registrar of
CoderURNs to the associatedCoderTranslator. - CoderUtils - Class in org.apache.beam.sdk.util
-
Utilities for working with Coders.
- CoGbkResult - Class in org.apache.beam.sdk.transforms.join
-
A row result of a
CoGroupByKey. - CoGbkResult(CoGbkResultSchema, Iterable<RawUnionValue>) - Constructor for class org.apache.beam.sdk.transforms.join.CoGbkResult
-
A row in the
PCollectionresulting from aCoGroupByKeytransform. - CoGbkResult(CoGbkResultSchema, Iterable<RawUnionValue>, int, int) - Constructor for class org.apache.beam.sdk.transforms.join.CoGbkResult
- CoGbkResult.CoGbkResultCoder - Class in org.apache.beam.sdk.transforms.join
-
A
CoderforCoGbkResults. - CoGbkResultSchema - Class in org.apache.beam.sdk.transforms.join
-
A schema for the results of a
CoGroupByKey. - CoGbkResultSchema(TupleTagList) - Constructor for class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
-
Builds a schema from a tuple of
TupleTag<?>s. - CoGroup - Class in org.apache.beam.sdk.schemas.transforms
-
A transform that performs equijoins across multiple schema
PCollections. - CoGroup() - Constructor for class org.apache.beam.sdk.schemas.transforms.CoGroup
- CoGroup.By - Class in org.apache.beam.sdk.schemas.transforms
-
Defines the set of fields to extract for the join key, as well as other per-input join options.
- CoGroup.ExpandCrossProduct - Class in org.apache.beam.sdk.schemas.transforms
-
A
PTransformthat calculates the cross-product join. - CoGroup.Impl - Class in org.apache.beam.sdk.schemas.transforms
-
The implementing PTransform.
- CoGroup.Result - Class in org.apache.beam.sdk.schemas.transforms
- CoGroupByKey<K> - Class in org.apache.beam.sdk.transforms.join
-
A
PTransformthat performs aCoGroupByKeyon a tuple of tables. - collection() - Method in class org.apache.beam.sdk.util.construction.graph.SideInputReference
-
The PCollection that backs this side input.
- collection() - Method in class org.apache.beam.sdk.util.construction.graph.UserStateReference
-
The PCollection that represents the input to the PTransform.
- 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(Iterable<? extends Instant>) - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
-
Combines the given times, which must be from the same window and must have been passed through
TimestampCombiner.merge(org.apache.beam.sdk.transforms.windowing.BoundedWindow, java.lang.Iterable<? extends org.joda.time.Instant>). - combine(HistogramData) - Method in class org.apache.beam.sdk.util.HistogramData
- combine(Instant...) - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
-
Varargs variant of
TimestampCombiner.combine(java.lang.Iterable<? extends org.joda.time.Instant>). - Combine - Class in org.apache.beam.sdk.transforms
-
PTransforms for combiningPCollectionelements globally and per-key. - COMBINE_GLOBALLY_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- COMBINE_GROUPED_VALUES_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- COMBINE_PER_KEY_CONVERT_TO_ACCUMULATORS_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- COMBINE_PER_KEY_EXTRACT_OUTPUTS_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- COMBINE_PER_KEY_MERGE_ACCUMULATORS_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- COMBINE_PER_KEY_PRECOMBINE_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- COMBINE_PER_KEY_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- Combine.AccumulatingCombineFn<InputT,AccumT extends Combine.AccumulatingCombineFn.Accumulator<InputT,AccumT,OutputT>,OutputT> - Class in org.apache.beam.sdk.transforms
-
A
CombineFnthat uses a subclass ofCombine.AccumulatingCombineFn.Accumulatoras its accumulator type. - Combine.AccumulatingCombineFn.Accumulator<InputT,AccumT,OutputT> - Interface in org.apache.beam.sdk.transforms
-
The type of mutable accumulator values used by this
AccumulatingCombineFn. - Combine.BinaryCombineDoubleFn - Class in org.apache.beam.sdk.transforms
-
An abstract subclass of
Combine.CombineFnfor implementing combiners that are more easily and efficiently expressed as binary operations ondoubles. - Combine.BinaryCombineFn<V> - Class in org.apache.beam.sdk.transforms
-
An abstract subclass of
Combine.CombineFnfor implementing combiners that are more easily expressed as binary operations. - Combine.BinaryCombineIntegerFn - Class in org.apache.beam.sdk.transforms
-
An abstract subclass of
Combine.CombineFnfor implementing combiners that are more easily and efficiently expressed as binary operations onints - Combine.BinaryCombineLongFn - Class in org.apache.beam.sdk.transforms
-
An abstract subclass of
Combine.CombineFnfor implementing combiners that are more easily and efficiently expressed as binary operations onlongs. - Combine.CombineFn<InputT extends @Nullable java.lang.Object,AccumT extends @Nullable java.lang.Object,OutputT extends @Nullable java.lang.Object> - Class in org.apache.beam.sdk.transforms
-
A
CombineFn<InputT, AccumT, OutputT>specifies how to combine a collection of input values of typeInputTinto a single output value of typeOutputT. - Combine.Globally<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
Combine.Globally<InputT, OutputT>takes aPCollection<InputT>and returns aPCollection<OutputT>whose elements are the result of combining all the elements in each window of the inputPCollection, using a specifiedCombineFn<InputT, AccumT, OutputT>. - Combine.GloballyAsSingletonView<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
Combine.GloballyAsSingletonView<InputT, OutputT>takes aPCollection<InputT>and returns aPCollectionView<OutputT>whose elements are the result of combining all the elements in each window of the inputPCollection, using a specifiedCombineFn<InputT, AccumT, OutputT>. - Combine.GroupedValues<K,InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
GroupedValues<K, InputT, OutputT>takes aPCollection<KV<K, Iterable<InputT>>>, such as the result ofGroupByKey, applies a specifiedCombineFn<InputT, AccumT, OutputT>to each of the inputKV<K, Iterable<InputT>>elements to produce a combined outputKV<K, OutputT>element, and returns aPCollection<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
Vwhich 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 aPCollection<KV<K, InputT>>, groups it by key, applies a combining function to theInputTvalues associated with each key to produce a combinedOutputTvalue, and returns aPCollection<KV<K, OutputT>>representing a map from each distinct key of the inputPCollectionto the corresponding combined value. - Combine.PerKeyWithHotKeyFanout<K,InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
Like
Combine.PerKey, but sharding the combining of hot keys. - Combine.SimpleCombineFn<V> - Class in org.apache.beam.sdk.transforms
-
Deprecated.
- CombineContextFactory - Class in org.apache.beam.sdk.util
-
Factory that produces
Combine.Contextbased 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() - Static method in class org.apache.beam.sdk.transforms.Count
-
Returns a
Combine.CombineFnthat counts the number of its inputs. - combineFn() - Static method in class org.apache.beam.sdk.transforms.Latest
-
Returns a
Combine.CombineFnthat selects the latest element among its inputs. - combineFn(int) - Static method in class org.apache.beam.sdk.transforms.Sample
-
Returns a
Combine.CombineFnthat computes a fixed-sized uniform sample of its inputs. - CombineFn() - Constructor for class org.apache.beam.sdk.transforms.Combine.CombineFn
- CombineFnBase - Class in org.apache.beam.sdk.transforms
-
For internal use only; no backwards-compatibility guarantees.
- CombineFnBase() - Constructor for class org.apache.beam.sdk.transforms.CombineFnBase
- CombineFnBase.GlobalCombineFn<InputT,AccumT,OutputT> - Interface in org.apache.beam.sdk.transforms
-
For internal use only; no backwards-compatibility guarantees.
- CombineFns - Class in org.apache.beam.sdk.transforms
-
Static utility methods that create combine function instances.
- CombineFns() - Constructor for class org.apache.beam.sdk.transforms.CombineFns
- CombineFns.CoCombineResult - Class in org.apache.beam.sdk.transforms
-
A tuple of outputs produced by a composed combine functions.
- CombineFns.ComposeCombineFnBuilder - Class in org.apache.beam.sdk.transforms
-
A builder class to construct a composed
CombineFnBase.GlobalCombineFn. - CombineFns.ComposedCombineFn<DataT> - Class in org.apache.beam.sdk.transforms
-
A composed
Combine.CombineFnthat applies multipleCombineFns. - CombineFns.ComposedCombineFnWithContext<DataT> - Class in org.apache.beam.sdk.transforms
-
A composed
CombineWithContext.CombineFnWithContextthat applies multipleCombineFnWithContexts. - CombineFnTester - Class in org.apache.beam.sdk.testing
-
Utilities for testing
CombineFns. - CombineFnTester() - Constructor for class org.apache.beam.sdk.testing.CombineFnTester
- CombineFnUtil - Class in org.apache.beam.sdk.util
-
Static utility methods that create combine function instances.
- CombineFnUtil() - Constructor for class org.apache.beam.sdk.util.CombineFnUtil
- CombineFnWithContext() - Constructor for class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
- CombineTranslation - Class in org.apache.beam.sdk.util.construction
- CombineTranslation() - Constructor for class org.apache.beam.sdk.util.construction.CombineTranslation
- CombineTranslation.CombineGloballyPayloadTranslator - Class in org.apache.beam.sdk.util.construction
- CombineTranslation.CombineGroupedValuesPayloadTranslator - Class in org.apache.beam.sdk.util.construction
- CombineTranslation.CombinePerKeyPayloadTranslator - Class in org.apache.beam.sdk.util.construction
- CombineTranslation.Registrar - Class in org.apache.beam.sdk.util.construction
-
Registers
TransformPayloadTranslatorsforCombines. - CombineWithContext - Class in org.apache.beam.sdk.transforms
-
This class contains combine functions that have access to
PipelineOptionsand side inputs throughCombineWithContext.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
PipelineOptionsand side inputs throughCombineWithContext.Context. - CombineWithContext.Context - Class in org.apache.beam.sdk.transforms
-
Information accessible to all methods in
CombineFnWithContextandKeyedCombineFnWithContext. - CombineWithContext.RequiresContextInternal - Interface in org.apache.beam.sdk.transforms
-
An internal interface for signaling that a
GloballyCombineFnor aPerKeyCombineFnneeds to accessCombineWithContext.Context. - combining(Coder<AccumT>, Combine.CombineFn<InputT, AccumT, OutputT>) - Static method in class org.apache.beam.sdk.state.StateSpecs
-
Identical to
StateSpecs.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
- combining(Combine.CombineFn<InputT, AccumT, OutputT>) - Static method in class org.apache.beam.sdk.state.StateSpecs
-
Create a
StateSpecfor aCombiningStatewhich uses aCombine.CombineFnto automatically merge multiple values of typeInputTinto a single resultingOutputT. - combining(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
ReadableStatecell defined by aCombine.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(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.
- 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(List<V>) - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
- 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
- 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.
- compareTo(ByteKey) - Method in class org.apache.beam.sdk.io.range.ByteKey
-
ByteKeyimplementsComparable<ByteKey>by comparing the arrays in lexicographic order. - compareTo(IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
- compareVersions(String, String) - Static method in class org.apache.beam.sdk.util.construction.TransformUpgrader
-
Compares two Beam versions.
- comparing(SerializableFunction<? super T, ? extends V>) - Static method in interface org.apache.beam.sdk.transforms.SerializableComparator
-
Analogous to
Comparator.comparing(Function), except that it takes in aSerializableFunctionas the key extractor and returns aSerializableComparator. - comparingNullFirst(Function<? super T, ? extends K>) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
- CompatibilityError() - Constructor for class org.apache.beam.sdk.schemas.transforms.Cast.CompatibilityError
- CompileException(DiagnosticCollector<?>) - Constructor for exception org.apache.beam.sdk.schemas.transforms.providers.StringCompiler.CompileException
- complete(List<TimestampedValue<OutputT>>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
-
Constructs a
Watch.Growth.PollResultwith the given outputs and declares that there will be no new outputs for the current input. - complete(Instant, List<OutputT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
-
Like
Watch.Growth.PollResult.complete(List), but assigns the same timestamp to all new outputs. - compose() - Static method in class org.apache.beam.sdk.transforms.CombineFns
-
Returns a
CombineFns.ComposeCombineFnBuilderto construct a composedCombineFnBase.GlobalCombineFn. - compose(String, SerializableFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.PTransform
-
Like
PTransform.compose(SerializableFunction), but with a custom name. - compose(SerializableFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.PTransform
-
For a
SerializableFunction<InputT, OutputT>fn, returns aPTransformgiven by applyingfn.apply(v)to the inputPCollection<InputT>. - 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
CompressedReaderfrom aCompressedSourceand delegate reader. - CompressedSource<T> - Class in org.apache.beam.sdk.io
-
A Source that reads from compressed files.
- CompressedSource.CompressedReader<T> - Class in org.apache.beam.sdk.io
-
Reader for a
CompressedSource. - CompressedSource.CompressionMode - Enum in org.apache.beam.sdk.io
-
Deprecated.Use
Compressioninstead - CompressedSource.DecompressingChannelFactory - Interface in org.apache.beam.sdk.io
-
Factory interface for creating channels that decompress the content of an underlying channel.
- Compression - Enum in org.apache.beam.sdk.io
-
Various compression types for reading/writing files.
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in interface org.apache.beam.sdk.state.MapState
-
A deferred read-followed-by-write.
- concat(Iterable<T>...) - Static method in class org.apache.beam.sdk.fn.stream.PrefetchableIterables
-
Concatentates the
Iterables. - concat(Iterator<T>...) - Static method in class org.apache.beam.sdk.fn.stream.PrefetchableIterators
-
Concatentates the
Iterators. - 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.
- concatIterators(Iterator<Iterator<T>>) - Static method in class org.apache.beam.sdk.fn.stream.PrefetchableIterators
- CONCRETE_CLASS - Static variable in class org.apache.beam.sdk.io.WriteFiles
-
For internal use by runners.
- Configuration() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.FlattenTransformProvider.Configuration
- Configuration() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider.Configuration
- Configuration() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider.Configuration
- Configuration() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration
- Configuration() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration
- Configuration() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider.Configuration
- configurationClass() - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider
- configurationClass() - Method in class org.apache.beam.sdk.schemas.transforms.providers.FlattenTransformProvider
- configurationClass() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider
- configurationClass() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider
- configurationClass() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider
- configurationClass() - Method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider
- configurationClass() - Method in class org.apache.beam.sdk.schemas.transforms.TypedSchemaTransformProvider
- configurationSchema() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIOProvider
-
Returns the expected schema of the configuration object.
- configurationSchema() - Method in interface org.apache.beam.sdk.schemas.transforms.SchemaTransformProvider
-
Returns the expected schema of the configuration object.
- configurationSchema() - Method in class org.apache.beam.sdk.schemas.transforms.TypedSchemaTransformProvider
- configure() - Static method in class org.apache.beam.sdk.transforms.windowing.Window
-
Returns a new builder for a
Windowtransform for setting windowing parameters other than the windowing function. - consistentWithEquals() - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
- 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
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.Coder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.DequeCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.DoubleCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.DurationCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.FloatCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.InstantCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.KvCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
-
LengthPrefixCoderis consistent with equals if the nestedCoderis. - 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
-
NullableCoderis consistent with equals if the nestedCoderis. - consistentWithEquals() - Method in class org.apache.beam.sdk.coders.OptionalCoder
-
OptionalCoderis consistent with equals if the nestedCoderis. - consistentWithEquals() - Method in class org.apache.beam.sdk.coders.SerializableCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.SortedMapCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.TimestampPrefixingWindowCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.VarIntCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.VarLongCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.coders.ZstdCoder
- consistentWithEquals() - Method in class org.apache.beam.sdk.fn.windowing.EncodedBoundedWindow.Coder
- 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) - Static method in class org.apache.beam.sdk.io.DynamicFileDestinations
-
A specialization of
DynamicFileDestinations.constant(FilenamePolicy, SerializableFunction)for the case where UserT and OutputT are the same type and the format function is the identity. - constant(FileBasedSink.FilenamePolicy, SerializableFunction<UserT, OutputT>) - Static method in class org.apache.beam.sdk.io.DynamicFileDestinations
-
Returns a
FileBasedSink.DynamicDestinationsthat always returns the sameFileBasedSink.FilenamePolicy. - constant(OutT) - Static method in class org.apache.beam.sdk.transforms.SerializableFunctions
- constructName(ResourceId, String, String, int, int, String, String) - Static method in class org.apache.beam.sdk.io.DefaultFilenamePolicy
-
Constructs a fully qualified name from components.
- consumePrefixToByteString(int) - Method in class org.apache.beam.sdk.util.ByteStringOutputStream
-
Creates a byte string with the given size containing the prefix of the contents of this output stream.
- consumesProjection() - Method in interface org.apache.beam.sdk.schemas.ProjectionConsumer
-
Returns a map from input
TupleTagid to aFieldAccessDescriptordescribing which Schema fieldsthismust access from the corresponding inputPCollectionto complete successfully. - contains(List<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.contains(List). - contains(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.contains(Object[]). - contains(SerializableMatcher<? super T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.contains(Matcher[]). - contains(IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
-
Returns whether this window contains the given window.
- contains(T) - Method in interface org.apache.beam.sdk.state.SetState
-
Returns a
ReadableStatewhoseReadableState.read()method will return true if this set contains the specified element at the point when thatReadableState.read()call returns. - contains(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.contains(Object[]). - containsInAnyOrder() - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Deprecated.Prefer
PAssert.IterableAssert.empty()to this method. - containsInAnyOrder() - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
- containsInAnyOrder(Iterable<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 class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
-
Checks that the
Iterablecontains the expected elements, in any order. - containsInAnyOrder(Collection<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.containsInAnyOrder(Collection). - containsInAnyOrder(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.containsInAnyOrder(Object[]). - containsInAnyOrder(SerializableMatcher<? super T>...) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Asserts that the iterable in question matches the provided elements.
- containsInAnyOrder(SerializableMatcher<? super T>...) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
-
Checks that the
Iterablecontains elements that match the provided matchers, in any order. - containsInAnyOrder(SerializableMatcher<? super T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.containsInAnyOrder(Matcher[]). - containsInAnyOrder(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
Iterablecontains the expected elements, in any order. - containsInAnyOrder(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.containsInAnyOrder(Object[]). - containsKey(Object) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- containsKey(K) - Method in interface org.apache.beam.sdk.state.MultimapState
-
Returns a
ReadableStatewhoseReadableState.read()method will return true if this multimap contains the specified key at the point when thatReadableState.read()call returns. - containsKey(ByteKey) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
-
Returns
trueif the specifiedByteKeyis contained within this range. - containsOnlyClassesMatching(Set<Matcher<Class<?>>>) - Static method in class org.apache.beam.sdk.util.ApiSurface
-
A factory method to create an
ApiSurfacematcher, 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
ApiSurfacematcher, producing a positive match if the queried api surface contains classes ONLY from specified package names. - containsString(String) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.containsString(java.lang.String). - containsValue(Object) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- 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
- Context(boolean) - Constructor for class org.apache.beam.sdk.coders.Coder.Context
-
Deprecated.
- Contextful<ClosureT> - Class in org.apache.beam.sdk.transforms
-
Pair of a bit of user code (a "closure") and the
Requirementsneeded 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.Contextwhen computing the result. - Contextful.Fn.Context - Class in org.apache.beam.sdk.transforms
-
An accessor for additional capabilities available in
Contextful.Fn.apply(InputT, org.apache.beam.sdk.transforms.Contextful.Fn.Context). - continuously(Duration, Watch.Growth.TerminationCondition<String, ?>) - Method in class org.apache.beam.sdk.io.FileIO.Match
- continuously(Duration, Watch.Growth.TerminationCondition<String, ?>) - Method in class org.apache.beam.sdk.io.FileIO.MatchAll
- continuously(Duration, Watch.Growth.TerminationCondition<String, ?>) - Method in class org.apache.beam.sdk.io.FileIO.MatchConfiguration
-
Continuously watches for new files at the given interval until the given termination condition is reached, where the input to the condition is the filepattern.
- continuously(Duration, Watch.Growth.TerminationCondition<String, ?>, boolean) - Method in class org.apache.beam.sdk.io.FileIO.Match
- continuously(Duration, Watch.Growth.TerminationCondition<String, ?>, boolean) - Method in class org.apache.beam.sdk.io.FileIO.MatchAll
- continuously(Duration, Watch.Growth.TerminationCondition<String, ?>, boolean) - 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(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
- 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
- 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
- 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.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
- convertReadBasedSplittableDoFnsToPrimitiveReads(Pipeline) - Static method in class org.apache.beam.sdk.util.construction.SplittableParDo
-
Converts
Readbased Splittable DoFn expansions to primitive reads implemented bySplittableParDo.PrimitiveBoundedReadandSplittableParDo.PrimitiveUnboundedRead. - convertReadBasedSplittableDoFnsToPrimitiveReadsIfNecessary(Pipeline) - Static method in class org.apache.beam.sdk.util.construction.SplittableParDo
-
Converts
Readbased Splittable DoFn expansions to primitive reads implemented bySplittableParDo.PrimitiveBoundedReadandSplittableParDo.PrimitiveUnboundedReadif either the experimentuse_deprecated_readorbeam_fn_api_use_deprecated_readare specified. - 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
ResourceIdfor writing output files. - convertToMapSpecInternal(StateSpec<SetState<KeyT>>) - Static method in class org.apache.beam.sdk.state.StateSpecs
-
For internal use only; no backwards-compatibility guarantees.
- convertToMultimapSpecInternal(StateSpec<MapState<KeyT, ValueT>>) - Static method in class org.apache.beam.sdk.state.StateSpecs
-
For internal use only; no backwards-compatibility guarantees.
- ConvertType(boolean) - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertType
- ConvertValueForGetter(StackManipulation) - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
- ConvertValueForSetter(StackManipulation) - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
- copy() - Method in interface org.apache.beam.sdk.util.common.Reiterator
-
Returns a copy of the current
Reiterator. - copy(List<ClassLoaderFileSystem.ClassLoaderResourceId>, List<ClassLoaderFileSystem.ClassLoaderResourceId>) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
- copy(List<ResourceId>, List<ResourceId>, MoveOptions...) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Copies a
Listof file-like resources from one location to another. - copy(List<ResourceIdT>, List<ResourceIdT>) - Method in class org.apache.beam.sdk.io.FileSystem
-
Copies a
Listof file-like resources from one location to another. - copyFrom(byte[]) - Static method in class org.apache.beam.sdk.io.range.ByteKey
-
Creates a new
ByteKeybacked by a copy of the specifiedbyte[]. - copyFrom(ByteBuffer) - Static method in class org.apache.beam.sdk.io.range.ByteKey
-
Creates a new
ByteKeybacked by a copy of the data remaining in the specifiedByteBuffer. - 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
-
PTransformsto count the elements in aPCollection. - countAsserts(Pipeline) - Static method in class org.apache.beam.sdk.testing.PAssert
- 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.
- 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 - Interface in org.apache.beam.sdk.metrics
-
A metric that reports a single long value and can be incremented or decremented.
- CounterMark(long, Instant) - Constructor for class org.apache.beam.sdk.io.CountingSource.CounterMark
-
Creates a checkpoint mark reflecting the last emitted value.
- CounterMarkCoder() - Constructor for class org.apache.beam.sdk.io.CountingSource.CounterMarkCoder
- CountErrors(Counter) - Constructor for class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.PTransformErrorHandler.WriteErrorMetrics.CountErrors
- CountingSource - Class in org.apache.beam.sdk.io
-
Most users should use
GenerateSequenceinstead. - CountingSource.CounterMark - Class in org.apache.beam.sdk.io
-
The checkpoint for an unbounded
CountingSourceis simply the last value produced. - CountingSource.CounterMarkCoder - Class in org.apache.beam.sdk.io
-
A custom coder for
CounterMark. - CrashingRunner - Class in org.apache.beam.sdk.testing
-
A
PipelineRunnerthat applies no overrides and throws an exception on calls toPipeline.run(). - CrashingRunner() - Constructor for class org.apache.beam.sdk.testing.CrashingRunner
- create() - Static method in class org.apache.beam.sdk.fn.server.InProcessServerFactory
- create() - Method in class org.apache.beam.sdk.options.PipelineOptionsFactory.Builder
-
Creates and returns an object that implements
PipelineOptionsusing the values configured on this builder during construction. - create() - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
-
Creates and returns an object that implements
PipelineOptions. - create() - Static method in class org.apache.beam.sdk.Pipeline
-
Constructs a pipeline from default
PipelineOptions. - create() - Static method in class org.apache.beam.sdk.PipelineRunner
-
Creates a runner from the default app
PipelineOptions. - create() - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Return an empty
FieldAccessDescriptor. - create() - Static method in class org.apache.beam.sdk.schemas.transforms.AddFields
- create() - Static method in class org.apache.beam.sdk.schemas.transforms.Filter
- create() - Static method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
Returns a transform that does a global combine using an aggregation built up by calls to aggregateField and aggregateFields.
- 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() - Static method in class org.apache.beam.sdk.testing.TestPipeline
-
Creates and returns a new test pipeline.
- 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 a new
ImpulsePTransform. - create() - Static method in class org.apache.beam.sdk.transforms.join.CoGroupByKey
-
Returns a
CoGroupByKey<K>PTransform. - 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.resourcehints.ResourceHints
-
Creates a
ResourceHintsinstance with no hints. - create() - Static method in class org.apache.beam.sdk.transforms.Values
-
Returns a
Values<V>PTransform. - create() - Static method in class org.apache.beam.sdk.util.construction.DeduplicatedFlattenFactory
- create() - Static method in class org.apache.beam.sdk.util.construction.ExternalTranslation.ExternalTranslator
- create() - Static method in class org.apache.beam.sdk.util.construction.FlattenTranslator
- create() - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoTranslator
- create() - Static method in class org.apache.beam.sdk.util.construction.ReadTranslation.BoundedReadPayloadTranslator
- create() - Static method in class org.apache.beam.sdk.util.construction.ReadTranslation.UnboundedReadPayloadTranslator
- create() - Static method in class org.apache.beam.sdk.util.construction.resources.PipelineResourcesOptions.ClasspathScanningResourcesDetectorFactory
- create() - Static method in class org.apache.beam.sdk.util.construction.SdkComponents
-
Create a new
SdkComponentswith no components. - create() - Static method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElementsTranslator
- create() - Static method in class org.apache.beam.sdk.util.construction.WindowIntoTranslation.WindowIntoPayloadTranslator
- create(int) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
-
Like
ApproximateQuantiles.ApproximateQuantilesCombineFn.create(int, Comparator), but sorts values using their natural ordering. - create(int, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
-
Returns an approximate quantiles combiner with the given
compareFnand desired number of quantiles. - create(int, ComparatorT, long, double) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
-
Creates an approximate quantiles combiner with the given
compareFnand desired number of quantiles. - create(long, long, long, long) - Static method in class org.apache.beam.sdk.metrics.DistributionResult
- create(long, long, SerializableFunction<InputT, Long>, Duration) - Static method in class org.apache.beam.sdk.transforms.GroupIntoBatches.BatchingParams
- 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(Class<?>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils.ClassWithSchema
- create(Iterable<MetricResult<Long>>, Iterable<MetricResult<DistributionResult>>, Iterable<MetricResult<GaugeResult>>, Iterable<MetricResult<StringSetResult>>, Iterable<MetricResult<BoundedTrieResult>>, Iterable<MetricResult<HistogramData>>) - Static method in class org.apache.beam.sdk.metrics.MetricQueryResults
- create(Object...) - Method in interface org.apache.beam.sdk.schemas.SchemaUserTypeCreator
- create(String) - Static method in class org.apache.beam.sdk.fn.channel.AddHarnessIdInterceptor
- create(String) - Static method in class org.apache.beam.sdk.metrics.LabeledMetricNameUtils.ParsedMetricName
- 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(String, String, Coder<T>, FnDataReceiver<T>) - Static method in class org.apache.beam.sdk.fn.data.TimerEndpoint
- create(String, Map<String, String>) - Static method in class org.apache.beam.sdk.metrics.LabeledMetricNameUtils.ParsedMetricName
- create(String, Coder<T>, FnDataReceiver<T>) - Static method in class org.apache.beam.sdk.fn.data.DataEndpoint
- 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(Function<Endpoints.ApiServiceDescriptor, ManagedChannel>) - Static method in class org.apache.beam.sdk.util.construction.DefaultExpansionServiceClientFactory
- create(List<? extends FnService>, Endpoints.ApiServiceDescriptor, ServerFactory) - Static method in class org.apache.beam.sdk.fn.server.GrpcFnServer
-
Create
GrpcFnServers for the providedFnServices running on a specified port. - 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(List<String>, String) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast.CompatibilityError
- create(List<String>, Optional<Schema.TypeName>) - Static method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
- create(List<Schema.Field>) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
Create an
OneOfTypelogical type. - create(List<Schema.Field>, Map<String, Integer>) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
Create an
OneOfTypelogical type. - create(List<BindableService>, Endpoints.ApiServiceDescriptor) - Method in class org.apache.beam.sdk.fn.server.InProcessServerFactory
- create(List<BindableService>, Endpoints.ApiServiceDescriptor) - Method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Creates an instance of this server at the address specified by the given service descriptor and bound to multiple services.
- create(List<BindableService>, Endpoints.ApiServiceDescriptor) - Method in class org.apache.beam.sdk.fn.server.ServerFactory.InetSocketAddressServerFactory
- 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(Map<String, RunnerApi.TimerFamilySpec>, String) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoLikeTimerFamilySpecs
- create(Set<String>) - Static method in class org.apache.beam.sdk.metrics.StringSetResult
-
Creates a
StringSetResultfrom the givenSetby making an immutable copy. - create(Set<List<String>>) - Static method in class org.apache.beam.sdk.metrics.BoundedTrieResult
-
Creates a
BoundedTrieResultfrom the givenSetby making an immutable copy. - create(RunnerApi.Components, Collection<String>) - Static method in class org.apache.beam.sdk.util.construction.SdkComponents
-
Create new
SdkComponentsimporting all items from providedRunnerApi.Componentsobject. - create(Coder<T>) - Static method in class org.apache.beam.sdk.testing.TestStream
-
Create a new
TestStream.Builderwith no elements and watermark equal toBoundedWindow.TIMESTAMP_MIN_VALUE. - create(Coder<T>, Coder<MetaT>) - Static method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadataCoder
- create(Coder<T>, FnDataReceiver<T>) - Static method in class org.apache.beam.sdk.fn.data.DecodingFnDataReceiver
- create(ClassLoaderFileSystem.ClassLoaderResourceId, CreateOptions) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
- create(EmptyMatchTreatment) - Static method in class org.apache.beam.sdk.io.FileIO.MatchConfiguration
-
Creates a
FileIO.MatchConfigurationwith the givenEmptyMatchTreatment. - create(MatchResult.Status, IOException) - Static method in class org.apache.beam.sdk.io.fs.MatchResult
- create(MatchResult.Status, List<MatchResult.Metadata>) - Static method in class org.apache.beam.sdk.io.fs.MatchResult
- create(ResourceId, String) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Returns a write channel for the given
ResourceId. - create(ResourceId, CreateOptions) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Returns a write channel for the given
ResourceIdwithCreateOptions. - create(MetricKey, T, T) - Static method in class org.apache.beam.sdk.metrics.MetricResult
- create(MetricKey, Boolean, T) - Static method in class org.apache.beam.sdk.metrics.MetricResult
- create(PipelineOptions) - Method in class org.apache.beam.sdk.metrics.MetricsOptions.NoOpMetricsSink
- create(PipelineOptions) - Method in interface org.apache.beam.sdk.options.DefaultValueFactory
-
Creates a default value for a getter marked with
Default.InstanceFactory. - create(PipelineOptions) - Method in class org.apache.beam.sdk.options.ExecutorOptions.ScheduledExecutorServiceFactory
- 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(PipelineOptions) - Method in class org.apache.beam.sdk.options.SdkHarnessOptions.BundleProcessorCacheTimeoutFactory
- create(PipelineOptions) - Method in class org.apache.beam.sdk.options.SdkHarnessOptions.DefaultMaxCacheMemoryUsageMbFactory
- create(PipelineOptions) - Static method in class org.apache.beam.sdk.Pipeline
-
Constructs a pipeline from the provided
PipelineOptions. - create(PipelineOptions) - Method in class org.apache.beam.sdk.testing.TestPipelineOptions.AlwaysPassMatcherFactory
- create(PipelineOptions) - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHintsOptions.EmptyListDefault
- create(PipelineOptions) - Method in class org.apache.beam.sdk.util.construction.resources.PipelineResourcesOptions.PipelineResourcesDetectorFactory
- create(PipelineOptions) - Static method in class org.apache.beam.sdk.util.construction.SdkComponents
- create(Schema) - Static method in class org.apache.beam.sdk.testing.TestStream
- create(Schema.Field...) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
Create an
OneOfTypelogical type. - create(Schema, TypeDescriptor<T>, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Static method in class org.apache.beam.sdk.testing.TestStream
- create(JsonToRow.JsonToRowWithErrFn) - Static method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError
- create(Secret) - Static method in class org.apache.beam.sdk.transforms.GroupByEncryptedKey
-
Creates a
GroupByEncryptedKeytransform. - create(TypeDescriptor<?>, Schema) - Method in class org.apache.beam.sdk.schemas.CachingFactory
- create(TypeDescriptor<?>, Schema) - Method in interface org.apache.beam.sdk.schemas.Factory
- create(TypeDescriptor<T>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils.TypeDescriptorWithSchema
- create(StreamObserver<ReqT>, Runnable) - Static method in class org.apache.beam.sdk.fn.stream.ForwardingClientResponseObserver
- create(StreamObserver<ReqT>, Runnable, Runnable) - Static method in class org.apache.beam.sdk.fn.stream.ForwardingClientResponseObserver
- create(ResourceIdT, CreateOptions) - Method in class org.apache.beam.sdk.io.FileSystem
-
Returns a write channel for the given
FileSystem. - create(ServiceT, Endpoints.ApiServiceDescriptor) - Static method in class org.apache.beam.sdk.fn.server.GrpcFnServer
-
Deprecated.This create function is used for Dataflow migration purpose only.
- create(ServiceT, Endpoints.ApiServiceDescriptor, ServerFactory) - Static method in class org.apache.beam.sdk.fn.server.GrpcFnServer
-
Create a
GrpcFnServerfor the providedFnServicewhich will run at the endpoint specified in theEndpoints.ApiServiceDescriptor. - create(T) - Static method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadata
- Create<T> - Class in org.apache.beam.sdk.transforms
-
Create<T>takes a collection of elements of typeTknown when the pipeline is constructed and returns aPCollection<T>containing the elements. - Create() - Constructor for class org.apache.beam.sdk.transforms.Create
- CREATE_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- CREATE_VIEW_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
-
Deprecated.runners should move away from translating `CreatePCollectionView` and treat this as part of the translation for a `ParDo` side input.
- Create.OfValueProvider<T> - Class in org.apache.beam.sdk.transforms
- Create.TimestampedValues<T> - Class in org.apache.beam.sdk.transforms
-
A
PTransformthat creates aPCollectionwhose elements have associated timestamps. - Create.Values<T> - Class in org.apache.beam.sdk.transforms
-
A
PTransformthat creates aPCollectionfrom a set of in-memory objects. - Create.WindowedValues<T> - Class in org.apache.beam.sdk.transforms
-
A
PTransformthat creates aPCollectionwhose elements have associated windowing metadata. - 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() - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
- createAccumulator() - Method in class org.apache.beam.sdk.transforms.Top.TopCombineFn
- 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.
- createAnyOfEnvironment(RunnerApi.Environment...) - Static method in class org.apache.beam.sdk.util.construction.Environments
- createConstructorCreator(Class<? super T>, Constructor<T>, Schema, List<FieldValueTypeInformation>, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
- createConstructorCreator(Class<T>, Constructor<T>, Schema, List<FieldValueTypeInformation>, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
- 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.fn.channel.ManagedChannelFactory
-
Creates a
ManagedChannelrelying on theManagedChannelBuilderto choose the channel type. - createDefault() - Static method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Create a default
ServerFactory.InetSocketAddressServerFactory. - createDefault() - Static method in interface org.apache.beam.sdk.fn.server.ServerFactory.UrlFactory
- createDefault() - Static method in class org.apache.beam.sdk.schemas.SchemaRegistry
- createDefault() - Static method in class org.apache.beam.sdk.transforms.GroupIntoBatches.BatchingParams
- createDockerEnvironment(String) - Static method in class org.apache.beam.sdk.util.construction.Environments
- createEpoll() - Static method in class org.apache.beam.sdk.fn.channel.ManagedChannelFactory
-
Creates a
ManagedChannelFactorybacked by anEpollDomainSocketChannelif the address is aDomainSocketAddress. - createEpollDomainSocket() - Static method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Create a
ServerFactory.EpollDomainSocket. - createEpollSocket() - Static method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Create a
ServerFactory.EpollSocket. - createForSubrangeOfFile(MatchResult.Metadata, long, long) - Method in class org.apache.beam.sdk.io.BlockBasedSource
-
Creates a
BlockBasedSourcefor the specified range in a single file. - createForSubrangeOfFile(MatchResult.Metadata, long, long) - Method in class org.apache.beam.sdk.io.CompressedSource
-
Creates a
CompressedSourcefor a subrange of a file. - createForSubrangeOfFile(MatchResult.Metadata, long, long) - Method in class org.apache.beam.sdk.io.FileBasedSource
-
Creates and returns a new
FileBasedSourceof the same type as the currentFileBasedSourcebacked by a given file and an offset range. - createForSubrangeOfFile(MatchResult.Metadata, long, long) - Method in class org.apache.beam.sdk.io.TextSource
- createFrom(String) - Static method in class org.apache.beam.sdk.fn.channel.SocketAddressFactory
-
Parse a
SocketAddressfrom the given string. - createFromStateContext(StateContext<?>) - Static method in class org.apache.beam.sdk.util.CombineContextFactory
-
Returns a
Combine.Contextthat wraps aStateContext. - 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
- createHaver(Class<ObjectT>, Method) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
- createInProcess() - Static method in class org.apache.beam.sdk.fn.channel.ManagedChannelFactory
-
Creates a
ManagedChannelusing an in-process channel. - createInternal(WindowingStrategy) - Static method in class org.apache.beam.sdk.transforms.windowing.Window.Assign
- createIterator() - Method in class org.apache.beam.sdk.fn.stream.PrefetchableIterables.Default
- createIterator() - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObservableIterable
-
Derived classes override this method to return an iterator for this iterable.
- createJsonFactory(int) - Static method in class org.apache.beam.sdk.util.RowJsonUtils
-
Creates a thread-safe JsonFactory with custom stream read constraints.
- createLzoInputStream(InputStream) - Static method in class org.apache.beam.sdk.util.LzoCompression
-
Create an
InputStreamthat will read from the givenInputStreamusingLzoCodec. - createLzoOutputStream(OutputStream) - Static method in class org.apache.beam.sdk.util.LzoCompression
-
Create an
OutputStreamthat will write to the givenOutputStream. - createLzopInputStream(InputStream) - Static method in class org.apache.beam.sdk.util.LzoCompression
-
Create an
InputStreamthat will read from the givenInputStreamusingLzopCodec. - createLzopOutputStream(OutputStream) - Static method in class org.apache.beam.sdk.util.LzoCompression
-
Create a
OutputStreamthat will write to the givenOutputStream. - createMetadata(MetaT) - Static method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadata
- CreateOptions - Class in org.apache.beam.sdk.io.fs
-
An abstract class that contains common configuration options for creating resources.
- CreateOptions() - Constructor for class org.apache.beam.sdk.io.fs.CreateOptions
- CreateOptions.Builder<BuilderT extends CreateOptions.Builder<BuilderT>> - Class in org.apache.beam.sdk.io.fs
-
An abstract builder for
CreateOptions. - CreateOptions.StandardCreateOptions - Class in org.apache.beam.sdk.io.fs
-
A standard configuration options with builder.
- CreateOptions.StandardCreateOptions.Builder - Class in org.apache.beam.sdk.io.fs
-
Builder for
CreateOptions.StandardCreateOptions. - createOrGetDefaultEnvironment(PortablePipelineOptions) - Static method in class org.apache.beam.sdk.util.construction.Environments
- 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
PaneInfowith the specified parameters. - createPane(boolean, boolean, PaneInfo.Timing, long, long, boolean) - Static method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
Factory method to create a
PaneInfowith the specified parameters. - CreatePCollectionViewTranslation - Class in org.apache.beam.sdk.util.construction
-
Deprecated.this should generally be done as part of
ParDotranslation, or moved into a dedicated runners-core-construction auxiliary class - CreatePCollectionViewTranslation() - Constructor for class org.apache.beam.sdk.util.construction.CreatePCollectionViewTranslation
-
Deprecated.
- CreatePCollectionViewTranslation.Registrar - Class in org.apache.beam.sdk.util.construction
-
Deprecated.runners should move away from translating `CreatePCollectionView` and treat this as part of the translation for a `ParDo` side input.
- createPrimitiveOutputFor(PCollection<?>, DoFn<?, OutputT>, TupleTag<OutputT>, TupleTagList, Map<TupleTag<?>, Coder<?>>, WindowingStrategy<?, ?>) - Static method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElements
- createPrimitiveOutputInternal(Pipeline, WindowingStrategy<?, ?>, PCollection.IsBounded, Coder<T>) - Static method in class org.apache.beam.sdk.values.PCollection
-
For internal use only; no backwards-compatibility guarantees.
- createPrimitiveOutputInternal(Pipeline, WindowingStrategy<?, ?>, PCollection.IsBounded, Coder<T>, TupleTag<?>) - Static method in class org.apache.beam.sdk.values.PCollection
-
For internal use only; no backwards-compatibility guarantees.
- createProcessContext(ValueInSingleWindow<InputT>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - createProcessEnvironment(String, String, String, Map<String, String>) - Static method in class org.apache.beam.sdk.util.construction.Environments
- createReader(PipelineOptions) - Method in class org.apache.beam.sdk.io.BoundedSource
-
Returns a new
BoundedSource.BoundedReaderthat reads from this source. - createReader(PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSource
- createReader(PipelineOptions, CheckpointMarkT) - Method in class org.apache.beam.sdk.io.UnboundedSource
-
Create a new
UnboundedSource.UnboundedReaderto read from this source, resuming from the given checkpoint if present. - createReader(PipelineOptions, UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter.Checkpoint<T>) - Method in class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter
- 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.BlockBasedSource
-
Creates a
BlockBasedReader. - createSingleFileReader(PipelineOptions) - Method in class org.apache.beam.sdk.io.CompressedSource
-
Creates a
FileBasedReaderto read a single file. - createSingleFileReader(PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSource
-
Creates and returns an instance of a
FileBasedReaderimplementation for the current source assuming the source represents a single file. - createSingleFileReader(PipelineOptions) - Method in class org.apache.beam.sdk.io.TextSource
- createSizedReplacement() - Static method in class org.apache.beam.sdk.util.construction.graph.SplittableParDoExpander
-
Returns a transform replacement which expands a splittable ParDo from:
- createSource - Variable in class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform
- createSourceForSubrange(long, long) - Method in class org.apache.beam.sdk.io.FileBasedSource
- createSourceForSubrange(long, long) - Method in class org.apache.beam.sdk.io.OffsetBasedSource
-
Returns an
OffsetBasedSourcefor a subrange of the current source. - createStagingFileName(File, HashCode) - Static method in class org.apache.beam.sdk.util.construction.Environments
- 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.
- createTruncateReplacement() - Static method in class org.apache.beam.sdk.util.construction.graph.SplittableParDoExpander
-
Returns a transform replacement in drain mode which expands a splittable ParDo from:
- 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
- createUrl(String, int) - Method in interface org.apache.beam.sdk.fn.server.ServerFactory.UrlFactory
- createValue(int, T) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
Create a
OneOfType.Valuespecifying which field to set and the value to set. - createValue(String, T) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
Create a
OneOfType.Valuespecifying 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.Valuespecifying which field to set and the value to set. - createViewWithViewFn(Class<? extends ViewFn>) - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
- createWithCustomGbk(Secret, PTransform<PCollection<KV<byte[], KV<byte[], byte[]>>>, PCollection<KV<byte[], Iterable<KV<byte[], byte[]>>>>>) - Static method in class org.apache.beam.sdk.transforms.GroupByEncryptedKey
-
Creates a
GroupByEncryptedKeytransform with a custom GBK in the middle. - createWithPortSupplier(Supplier<Integer>) - Static method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Create a
ServerFactory.InetSocketAddressServerFactorythat uses ports from a supplier. - createWithUrlFactory(ServerFactory.UrlFactory) - Static method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Create a
ServerFactory.InetSocketAddressServerFactorythat uses the given url factory. - createWithUrlFactoryAndPortSupplier(ServerFactory.UrlFactory, Supplier<Integer>) - Static method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Create a
ServerFactory.InetSocketAddressServerFactorythat uses the given url factory and ports from a supplier. - createWriteOperation() - Method in class org.apache.beam.sdk.io.FileBasedSink
-
Return a subclass of
FileBasedSink.WriteOperationthat will manage the write to the sink. - createWriter() - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
-
Clients must implement to return a subclass of
FileBasedSink.Writer. - crossProductJoin() - Method in class org.apache.beam.sdk.schemas.transforms.CoGroup.Impl
-
Expand the join into individual rows, similar to SQL joins.
- currentEventTime() - Method in interface org.apache.beam.sdk.state.Timers
-
Returns the current event time.
- currentProcessingTime() - Method in interface org.apache.beam.sdk.state.Timers
-
Returns the current processing time.
- currentRecordId() - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContext
- currentRecordOffset() - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContext
- 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.ProcessElementcall will do, including already completed work. - currentSynchronizedProcessingTime() - Method in interface org.apache.beam.sdk.state.Timers
-
Returns the current synchronized processing time or
nullif 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
- CUSTOM_JAVA_DO_FN_URN - Static variable in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
The URN for an unknown Java
DoFn. - CUSTOM_JAVA_FILE_BASED_SINK_URN - Static variable in class org.apache.beam.sdk.util.construction.WriteFilesTranslation
-
The URN for an unknown Java
FileBasedSink. - CUSTOM_JAVA_VIEW_FN_URN - Static variable in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
The URN for an unknown Java
ViewFn. - CUSTOM_JAVA_WINDOW_MAPPING_FN_URN - Static variable in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
The URN for an unknown Java
WindowMappingFn. - CUSTOM_WINDOW_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- CustomCoder<T> - Class in org.apache.beam.sdk.coders
-
An abstract base class that implements all methods of
CoderexceptCoder.encode(T, java.io.OutputStream)andCoder.decode(java.io.InputStream). - CustomCoder() - Constructor for class org.apache.beam.sdk.coders.CustomCoder
D
- data(String, String) - Static method in class org.apache.beam.sdk.fn.data.LogicalEndpoint
- DATA_BUFFER_SIZE_LIMIT - Static variable in class org.apache.beam.sdk.fn.data.BeamFnDataOutboundAggregator
- DATA_BUFFER_TIME_LIMIT_MS - Static variable in class org.apache.beam.sdk.fn.data.BeamFnDataOutboundAggregator
- DataEndpoint<T> - Class in org.apache.beam.sdk.fn.data
- DataEndpoint() - Constructor for class org.apache.beam.sdk.fn.data.DataEndpoint
- DataStreamDecoder(Coder<T>, PrefetchableIterator<ByteString>) - Constructor for class org.apache.beam.sdk.fn.stream.DataStreams.DataStreamDecoder
- DataStreams - Class in org.apache.beam.sdk.fn.stream
-
DataStreams.DataStreamDecodertreats multipleByteStrings as a single input stream decoding values with the supplied iterator. - DataStreams() - Constructor for class org.apache.beam.sdk.fn.stream.DataStreams
- DataStreams.DataStreamDecoder<T> - Class in org.apache.beam.sdk.fn.stream
-
An adapter which converts an
InputStreamto aPrefetchableIteratorofTvalues using the specifiedCoder. - DataStreams.ElementDelimitedOutputStream - Class in org.apache.beam.sdk.fn.stream
-
An adapter which wraps an
DataStreams.OutputChunkConsumeras anOutputStream. - DataStreams.OutputChunkConsumer<T> - Interface in org.apache.beam.sdk.fn.stream
-
A callback which is invoked whenever the
DataStreams.outbound(org.apache.beam.sdk.fn.stream.DataStreams.OutputChunkConsumer<org.apache.beam.vendor.grpc.v1p69p0.com.google.protobuf.ByteString>)OutputStreambecomes full. - 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 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 - org.apache.beam.sdk.schemas.Schema.TypeName
- DATETIME - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.SqlTypes
-
Beam LogicalType corresponding to 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
WindowFnthat windows elements into periods measured by days. - DD - Static variable in class org.apache.beam.sdk.util.RowStringInterpolator
- DeadLetteredTransform<InputT,OutputT> - Class in org.apache.beam.sdk.schemas.io
- DeadLetteredTransform(SimpleFunction<InputT, OutputT>, String) - Constructor for class org.apache.beam.sdk.schemas.io.DeadLetteredTransform
- debug(String, Object...) - Static method in class org.apache.beam.sdk.util.WindowTracing
- DEBUG - org.apache.beam.sdk.options.SdkHarnessOptions.LogLevel
-
LogLevel for logging diagnostic messages.
- dec() - Method in interface org.apache.beam.sdk.metrics.Counter
- dec() - Method in class org.apache.beam.sdk.metrics.DelegatingCounter
- dec() - Method in class org.apache.beam.sdk.metrics.NoOpCounter
- dec(long) - Method in interface org.apache.beam.sdk.metrics.Counter
- dec(long) - Method in class org.apache.beam.sdk.metrics.DelegatingCounter
- dec(long) - Method in class org.apache.beam.sdk.metrics.NoOpCounter
- DECIMAL - org.apache.beam.sdk.schemas.Schema.TypeName
- 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.io.ReadableFileCoder
- decode(InputStream) - 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) - 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) - 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
Tfrom the given input stream in the given context. - decode(InputStream) - 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) - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
- decode(InputStream) - Method in class org.apache.beam.sdk.coders.MapCoder
- decode(InputStream) - Method in class org.apache.beam.sdk.coders.NullableCoder
- decode(InputStream) - Method in class org.apache.beam.sdk.coders.OptionalCoder
- 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.SortedMapCoder
- decode(InputStream) - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
- decode(InputStream) - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
- decode(InputStream) - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
- decode(InputStream) - Method in class org.apache.beam.sdk.coders.TimestampPrefixingWindowCoder
- 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.coders.ZstdCoder
- decode(InputStream) - Method in class org.apache.beam.sdk.fn.windowing.EncodedBoundedWindow.Coder
- decode(InputStream) - Method in class org.apache.beam.sdk.io.CountingSource.CounterMarkCoder
- 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.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) - 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) - Method in class org.apache.beam.sdk.util.construction.Timer.Coder
- decode(InputStream) - Method in class org.apache.beam.sdk.util.construction.UnknownCoderWrapper
- decode(InputStream) - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
- decode(InputStream) - 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) - Method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
- decode(InputStream) - Method in class org.apache.beam.sdk.values.WindowedValues.FullWindowedValueCoder
- decode(InputStream) - Method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
- decode(InputStream) - Method in class org.apache.beam.sdk.values.WindowedValues.ValueOnlyWindowedValueCoder
-
Deprecated.
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.BitSetCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.Coder
-
Deprecated.only implement and call
Coder.decode(InputStream) - decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.DelegateCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.KvCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.MapCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.NullableCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.SortedMapCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.util.BitSetCoder
-
Deprecated.
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow.Coder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.WindowedValues.FullWindowedValueCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
- decode(InputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.WindowedValues.ValueOnlyWindowedValueCoder
-
Deprecated.
- 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
- decodeFromByteString(Coder<T>, ByteString) - Static method in class org.apache.beam.sdk.util.CoderUtils
-
Decodes a value from the given ByteString, validating that no bytes are remaining once decoded.
- decodeFromByteString(Coder<T>, ByteString, Coder.Context) - Static method in class org.apache.beam.sdk.util.CoderUtils
-
Decodes a value from the given ByteString using a given context, validating that no bytes are remaining once decoded.
- decodeFromChunkBoundaryToChunkBoundary() - Method in class org.apache.beam.sdk.fn.stream.DataStreams.DataStreamDecoder
-
Skips any remaining bytes in the current
ByteStringmoving to the nextByteStringin the underlyingByteStringiteratorand decoding elements till at the next boundary. - 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 associatedIterable-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 associatedIterable-like subtype, from a list of decoded elements. - 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 associatedIterable-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 associatedIterable-like subtype, from a list of decoded elements with theInputStreamat the position where this coder detected the end of the stream. - DecodingFnDataReceiver<T> - Class in org.apache.beam.sdk.fn.data
-
A receiver of encoded data, decoding it and passing it onto a downstream consumer.
- DecodingFnDataReceiver(Coder<T>, FnDataReceiver<T>) - Constructor for class org.apache.beam.sdk.fn.data.DecodingFnDataReceiver
- decrementingLongs() - Static method in class org.apache.beam.sdk.fn.IdGenerators
-
Returns an
IdGeneratorsthat will provide successive decrementing longs. - Deduplicate - Class in org.apache.beam.sdk.transforms
-
A set of
PTransforms which deduplicate input records over a time domain and threshold. - Deduplicate.KeyedValues<K,V> - Class in org.apache.beam.sdk.transforms
-
Deduplicates keyed values using the key over a specified time domain and threshold.
- Deduplicate.Values<T> - Class in org.apache.beam.sdk.transforms
-
Deduplicates values over a specified time domain and threshold.
- Deduplicate.WithRepresentativeValues<T,IdT> - Class in org.apache.beam.sdk.transforms
-
A
PTransformthat uses aSerializableFunctionto obtain a representative value for each input element used for deduplication. - DeduplicatedFlattenFactory<T> - Class in org.apache.beam.sdk.util.construction
-
A
PTransformOverrideFactorythat will apply a flatten where no element appears in the inputPCollectionListmore than once. - 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
-
Defaultrepresents a set of annotations that can be used to annotate getter properties onPipelineOptionswith information representing the default value to be returned if no value is specified. - Default() - Constructor for class org.apache.beam.sdk.fn.stream.PrefetchableIterables.Default
- DEFAULT - Static variable in interface org.apache.beam.sdk.util.construction.CoderTranslation.TranslationContext
-
The default translation context containing no additional parameters.
- DEFAULT - Static variable in class org.apache.beam.sdk.util.FluentBackoff
-
By default the
BackOffcreated 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_BUFFER_LIMIT_BYTES - Static variable in class org.apache.beam.sdk.fn.data.BeamFnDataOutboundAggregator
- DEFAULT_BUFFER_LIMIT_TIME_MS - Static variable in class org.apache.beam.sdk.fn.data.BeamFnDataOutboundAggregator
- 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_OUTBOUND_BUFFER_LIMIT_BYTES - Static variable in class org.apache.beam.sdk.fn.stream.DataStreams
- DEFAULT_SCHEME - Static variable in class org.apache.beam.sdk.io.FileSystems
- DEFAULT_TIME_DOMAIN - Static variable in class org.apache.beam.sdk.transforms.Deduplicate
-
The default is the
processing time domain. - DEFAULT_UNWINDOWED_SHARD_TEMPLATE - Static variable in class org.apache.beam.sdk.io.DefaultFilenamePolicy
-
The default sharding name template.
- DEFAULT_USES_RESHUFFLE - Static variable in class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform
- 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.
- DEFAULT_WIRE_CODER_SETTINGS - Static variable in interface org.apache.beam.sdk.util.construction.graph.ExecutableStage
-
The default wire coder settings which returns an empty list, i.e., the WireCoder for each PCollection and timer will be a WINDOWED_VALUE coder.
- 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
Classvalue. - Default.Double - Annotation Type in org.apache.beam.sdk.options
-
This represents that the default of the option is the specified double primitive value.
- Default.Enum - Annotation Type in org.apache.beam.sdk.options
-
This represents that the default of the option is the specified enum.
- Default.Float - Annotation Type in org.apache.beam.sdk.options
-
This represents that the default of the option is the specified float primitive value.
- Default.InstanceFactory - Annotation Type in org.apache.beam.sdk.options
-
Value must be of type
DefaultValueFactoryand have a default constructor. - Default.Integer - Annotation Type in org.apache.beam.sdk.options
-
This represents that the default of the option is the specified int primitive value.
- Default.Long - Annotation Type in org.apache.beam.sdk.options
-
This represents that the default of the option is the specified long primitive value.
- Default.Short - Annotation Type in org.apache.beam.sdk.options
-
This represents that the default of the option is the specified short primitive value.
- Default.String - Annotation Type in org.apache.beam.sdk.options
-
This represents that the default of the option is the specified
Stringvalue. - DefaultArtifactResolver - Class in org.apache.beam.sdk.util.construction
-
A default artifact resolver.
- DefaultArtifactResolver() - Constructor for class org.apache.beam.sdk.util.construction.DefaultArtifactResolver
- DefaultCoder - Annotation Type in org.apache.beam.sdk.coders
-
The
DefaultCoderannotation specifies aCoderclass to handle encoding and decoding instances of the annotated class. - DefaultCoder.DefaultCoderProviderRegistrar - Class in org.apache.beam.sdk.coders
-
A
CoderProviderRegistrarthat registers aCoderProviderwhich can use the@DefaultCoderannotation to providecoder providersthat createsCoders. - DefaultCoder.DefaultCoderProviderRegistrar.DefaultCoderProvider - Class in org.apache.beam.sdk.coders
-
A
CoderProviderthat uses the@DefaultCoderannotation to providecoder providersthat createCoders. - DefaultCoderProvider() - Constructor for class org.apache.beam.sdk.coders.DefaultCoder.DefaultCoderProviderRegistrar.DefaultCoderProvider
- DefaultCoderProviderRegistrar() - Constructor for class org.apache.beam.sdk.coders.DefaultCoder.DefaultCoderProviderRegistrar
- DefaultConcludeTransform() - Constructor for class org.apache.beam.sdk.testing.PAssert.DefaultConcludeTransform
- DefaultErrorHandler() - Constructor for class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.DefaultErrorHandler
- DefaultExpansionServiceClientFactory - Class in org.apache.beam.sdk.util.construction
-
Default factory for ExpansionServiceClient used by External transform.
- DefaultFilenamePolicy - Class in org.apache.beam.sdk.io
-
A default
FileBasedSink.FilenamePolicyfor windowed and unwindowed files. - DefaultFilenamePolicy.Params - Class in org.apache.beam.sdk.io
-
Encapsulates constructor parameters to
DefaultFilenamePolicy. - DefaultFilenamePolicy.ParamsCoder - Class in org.apache.beam.sdk.io
-
A Coder for
DefaultFilenamePolicy.Params. - DefaultMaxCacheMemoryUsageMb() - Constructor for class org.apache.beam.sdk.options.SdkHarnessOptions.DefaultMaxCacheMemoryUsageMb
- DefaultMaxCacheMemoryUsageMbFactory() - Constructor for class org.apache.beam.sdk.options.SdkHarnessOptions.DefaultMaxCacheMemoryUsageMbFactory
- 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.FileNamingwhich will use the prefix and suffix supplied to create a name based on the window, pane, number of shards, shard index, and compression. - DefaultPipelineOptionsRegistrar - Class in org.apache.beam.sdk.options
-
A
PipelineOptionsRegistrarcontaining thePipelineOptionssubclasses available by default. - DefaultPipelineOptionsRegistrar() - Constructor for class org.apache.beam.sdk.options.DefaultPipelineOptionsRegistrar
- Defaults() - Constructor for class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
- DefaultSchema - Annotation Type in org.apache.beam.sdk.schemas.annotations
-
The
DefaultSchemaannotation specifies aSchemaProviderclass to handle obtaining a schema and row for the specified class. - DefaultSchema.DefaultSchemaProvider - Class in org.apache.beam.sdk.schemas.annotations
-
SchemaProviderfor default schemas. - DefaultSchema.DefaultSchemaProviderRegistrar - Class in org.apache.beam.sdk.schemas.annotations
-
Registrar for default schemas.
- DefaultSchemaProvider() - Constructor for class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProvider
- DefaultSchemaProviderRegistrar() - Constructor for class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProviderRegistrar
- DefaultTrigger - Class in org.apache.beam.sdk.transforms.windowing
-
A trigger that is equivalent to
Repeatedly.forever(AfterWatermark.pastEndOfWindow()). - DefaultTypeConversionsFactory() - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.DefaultTypeConversionsFactory
- defaultValue() - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
-
Returns the default value when there are no values added to the accumulator.
- defaultValue() - Method in interface org.apache.beam.sdk.transforms.CombineFnBase.GlobalCombineFn
-
Returns the default value when there are no values added to the accumulator.
- defaultValue() - Method in class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
- defaultValue() - Method in class org.apache.beam.sdk.transforms.View.AsSingleton
-
Returns the default value of this transform, or null if there isn't one.
- DefaultValueFactory<T> - Interface in org.apache.beam.sdk.options
-
An interface used with the
Default.InstanceFactoryannotation to specify the class that will be an instance factory to produce default values for a given getter onPipelineOptions. - DEFLATE - org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.
- DEFLATE - org.apache.beam.sdk.io.Compression
-
Deflate compression.
- DEFLATE - org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.
- DEFLATE - org.apache.beam.sdk.io.TextIO.CompressionType
-
Deprecated.
- 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() - Method in class org.apache.beam.sdk.util.construction.ForwardingPTransform
- 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 aCoderforIntermediateTand encodes/decodes values of typeTby converting to/fromIntermediateTand then encoding/decoding using the underlyingCoder<IntermediateT>. - DelegateCoder(Coder<IntermediateT>, DelegateCoder.CodingFunction<T, IntermediateT>, DelegateCoder.CodingFunction<IntermediateT, T>, TypeDescriptor<T>) - Constructor for class org.apache.beam.sdk.coders.DelegateCoder
- DelegateCoder.CodingFunction<InputT,OutputT> - Interface in org.apache.beam.sdk.coders
-
A
CodingFunction<InputT, OutputT>is a serializable function fromInputTtoOutputTthat may throw anyException. - 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
Counterthat delegates to the instance for the current context. - DelegatingCounter(MetricName) - Constructor for class org.apache.beam.sdk.metrics.DelegatingCounter
-
Create a
DelegatingCounterwithperWorkerCounterandprocessWideContainerset to false. - DelegatingCounter(MetricName, boolean) - Constructor for class org.apache.beam.sdk.metrics.DelegatingCounter
-
Create a
DelegatingCounterwithperWorkerCounterset to false. - DelegatingCounter(MetricName, boolean, boolean) - Constructor for class org.apache.beam.sdk.metrics.DelegatingCounter
- DelegatingDistribution - Class in org.apache.beam.sdk.metrics
-
Implementation of
Distributionthat delegates to the instance for the current context. - DelegatingDistribution(MetricName) - Constructor for class org.apache.beam.sdk.metrics.DelegatingDistribution
- DelegatingDistribution(MetricName, boolean) - Constructor for class org.apache.beam.sdk.metrics.DelegatingDistribution
- DelegatingGauge - Class in org.apache.beam.sdk.metrics
-
Implementation of
Gaugethat delegates to the instance for the current context. - DelegatingGauge(MetricName) - Constructor for class org.apache.beam.sdk.metrics.DelegatingGauge
-
Create a
DelegatingGaugewithperWorkerGaugeandprocessWideContainerset to false. - DelegatingGauge(MetricName, boolean) - Constructor for class org.apache.beam.sdk.metrics.DelegatingGauge
- DelegatingHistogram - Class in org.apache.beam.sdk.metrics
-
Implementation of
Histogramthat 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<ResourceId>, MoveOptions...) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Deletes a collection of resources.
- delete(Collection<ResourceIdT>) - Method in class org.apache.beam.sdk.io.FileSystem
-
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
timestampandtimeDomain. - delimitElement() - Method in class org.apache.beam.sdk.fn.stream.DataStreams.ElementDelimitedOutputStream
- dependencies(Row, PipelineOptions) - Method in interface org.apache.beam.sdk.schemas.transforms.SchemaTransformProvider
-
List the dependencies needed for this transform.
- dependencies(Row, PipelineOptions) - Method in class org.apache.beam.sdk.schemas.transforms.TypedSchemaTransformProvider
- dependsOnlyOnEarliestTimestamp() - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
-
Returns
trueif 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
trueif the result does not depend on what outputs were combined but only the window they are in. - DequeCoder<T extends @NonNull java.lang.Object> - 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
PipelineOptionsinterfaces. - 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() - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider
- description() - Method in interface org.apache.beam.sdk.schemas.transforms.SchemaTransformProvider
-
Returns a description regarding the
SchemaTransformrepresented by theSchemaTransformProvider. - Description - Annotation Type in org.apache.beam.sdk.options
-
Descriptions are used to generate human readable output when the
--helpcommand is specified. - deserialize(byte[]) - Method in interface org.apache.beam.sdk.schemas.io.payloads.PayloadSerializer
- 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
-
Deserializes an object from the given array of bytes, e.g., as serialized using
SerializableUtils.serializeToByteArray(java.io.Serializable), and returns it. - desiredBundleSizeBytes - Variable in class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform
- detect(ClassLoader) - Method in class org.apache.beam.sdk.util.construction.resources.ClasspathScanningResourcesDetector
-
Detects classpath resources and returns a list of absolute paths to them.
- detect(ClassLoader) - Method in interface org.apache.beam.sdk.util.construction.resources.PipelineResourcesDetector
- detect(String) - Static method in enum org.apache.beam.sdk.io.Compression
- detectClassPathResourcesToStage(ClassLoader, PipelineOptions) - Static method in class org.apache.beam.sdk.util.construction.resources.PipelineResources
-
Uses algorithm provided via
PipelineResourcesOptionsto detect classpath resources. - 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
- DirectStreamObserver<T> - Class in org.apache.beam.sdk.fn.stream
-
A
StreamObserverwhich uses synchronization on the underlyingCallStreamObserverto provide thread safety. - DirectStreamObserver(Phaser, CallStreamObserver<T>) - Constructor for class org.apache.beam.sdk.fn.stream.DirectStreamObserver
- DISALLOW - org.apache.beam.sdk.io.fs.EmptyMatchTreatment
-
Filepatterns matching no resources are disallowed.
- discard() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataOutboundAggregator
- DISCARDING_FIRED_PANES - org.apache.beam.sdk.values.WindowingStrategy.AccumulationMode
- discardingFiredPanes() - Method in class org.apache.beam.sdk.transforms.windowing.Window
-
Returns a new
WindowPTransformthat uses the registered WindowFn and Triggering behavior, and that discards elements in a pane after they are triggered. - discover(ExpansionApi.DiscoverSchemaTransformRequest) - Method in interface org.apache.beam.sdk.util.construction.ExpansionServiceClient
- dispatch(DoFnSignature.Parameter.BundleFinalizerParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.BundleFinalizerParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.ElementParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.ElementParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.FinishBundleContextParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.FinishBundleContextParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.KeyParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.KeyParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.OnTimerContextParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.OnTimerContextParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.OutputReceiverParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.OutputReceiverParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.PaneInfoParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.PaneInfoParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.PipelineOptionsParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.PipelineOptionsParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.ProcessContextParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.ProcessContextParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.RestrictionParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.RestrictionParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.RestrictionTrackerParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.RestrictionTrackerParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.SchemaElementParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.SchemaElementParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.SideInputParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.SideInputParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.StartBundleContextParameter) - 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.StateParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.StateParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.TaggedOutputReceiverParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.TaggedOutputReceiverParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.TimeDomainParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.TimeDomainParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.TimerFamilyParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.TimerFamilyParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.TimerIdParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.TimerIdParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.TimerParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.TimerParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.TimestampParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.TimestampParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.WatermarkEstimatorParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.WatermarkEstimatorParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.WatermarkEstimatorStateParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.WatermarkEstimatorStateParameter) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- dispatch(DoFnSignature.Parameter.WindowParameter) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases
- dispatch(DoFnSignature.Parameter.WindowParameter) - 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
- dispatchMultimap(Coder<?>, Coder<?>) - Method in interface org.apache.beam.sdk.state.StateSpec.Cases
- dispatchMultimap(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 - Variable in class org.apache.beam.sdk.transforms.PTransform
- 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
-
Itemsare the unit of display data. - DisplayData.ItemSpec<T> - Class in org.apache.beam.sdk.transforms.display
-
Specifies an
DisplayData.Itemto register as display data. - DisplayData.Path - Class in org.apache.beam.sdk.transforms.display
-
Structured path of registered display data within a component hierarchy.
- DisplayData.Type - Enum in org.apache.beam.sdk.transforms.display
-
Display data type.
- DisplayDataTranslation - Class in org.apache.beam.sdk.util.construction
-
Utilities for going to/from DisplayData protos.
- DisplayDataTranslation() - Constructor for class org.apache.beam.sdk.util.construction.DisplayDataTranslation
- Distinct<T> - Class in org.apache.beam.sdk.transforms
-
Distinct<T>takes aPCollection<T>and returns aPCollection<T>that has all distinct elements of the input. - Distinct() - Constructor for class org.apache.beam.sdk.transforms.Distinct
- Distinct.WithRepresentativeValues<T,IdT> - Class in org.apache.beam.sdk.transforms
-
A
DistinctPTransformthat uses aSerializableFunctionto obtain a representative value for each input element. - 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.
- 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 - Interface in org.apache.beam.sdk.metrics
-
A metric that reports information about the distribution of reported values.
- DistributionResult - Class in org.apache.beam.sdk.metrics
-
The result of a
Distributionmetric. - DistributionResult() - Constructor for class org.apache.beam.sdk.metrics.DistributionResult
- DO_NOT_CLONE - org.apache.beam.sdk.transforms.DoFnTester.CloningBehavior
-
Deprecated.
- DO_NOT_ENTER_TRANSFORM - org.apache.beam.sdk.Pipeline.PipelineVisitor.CompositeBehavior
- doChecks(PAssert.PAssertionSite, ActualT, SerializableFunction<ActualT, Void>) - Static method in class org.apache.beam.sdk.testing.PAssert
- DoFn<InputT extends @Nullable java.lang.Object,OutputT extends @Nullable java.lang.Object> - Class in org.apache.beam.sdk.transforms
-
The argument to
ParDoproviding the code to use to process elements of the inputPCollection. - DoFn() - Constructor for class org.apache.beam.sdk.transforms.DoFn
- DoFn.AlwaysFetched - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation for declaring that a state parameter is always fetched.
- DoFn.BoundedPerElement - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation on a splittable
DoFnspecifying that theDoFnperforms a bounded amount of work per input element, so applying it to a boundedPCollectionwill produce also a boundedPCollection. - DoFn.BundleFinalizer - Interface in org.apache.beam.sdk.transforms
-
A parameter that is accessible during
@StartBundle,@ProcessElementand@FinishBundlethat 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
-
Parameter annotation for the input element for
DoFn.ProcessElement,DoFn.GetInitialRestriction,DoFn.GetSize,DoFn.SplitRestriction,DoFn.GetInitialWatermarkEstimatorState,DoFn.NewWatermarkEstimator, andDoFn.NewTrackermethods. - DoFn.FieldAccess - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation for specifying specific fields that are accessed in a Schema PCollection.
- DoFn.FinishBundle - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation for the method to use to finish processing a batch of elements.
- DoFn.FinishBundleContext - Class in org.apache.beam.sdk.transforms
-
Information accessible while within the
DoFn.FinishBundlemethod. - 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
KVpair. - DoFn.MultiOutputReceiver - Interface in org.apache.beam.sdk.transforms
-
Receives tagged output for a multi-output function.
- DoFn.NewTracker - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation for the method that creates a new
RestrictionTrackerfor the restriction of a splittableDoFn. - DoFn.NewWatermarkEstimator - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation for the method that creates a new
WatermarkEstimatorfor the watermark state of a splittableDoFn. - DoFn.OnTimer - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation for registering a callback for a timer.
- DoFn.OnTimerContext - Class in org.apache.beam.sdk.transforms
-
Information accessible when running a
DoFn.OnTimermethod. - DoFn.OnTimerFamily - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation for registering a callback for a timerFamily.
- DoFn.OnWindowExpiration - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation for the method to use for performing actions on window expiration.
- DoFn.OnWindowExpirationContext - Class in org.apache.beam.sdk.transforms
- DoFn.OutputReceiver<T> - Interface in org.apache.beam.sdk.transforms
-
Receives values of the given type.
- DoFn.ProcessContext - Class in org.apache.beam.sdk.transforms
-
Information accessible when running a
DoFn.ProcessElementmethod. - 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
-
Annotation that may be added to a
DoFn.ProcessElement,DoFn.OnTimer, orDoFn.OnWindowExpirationmethod to indicate that the runner must ensure that the observable contents of the inputPCollectionor mutable state must be stable upon retries. - DoFn.RequiresTimeSortedInput - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation that may be added to a
DoFn.ProcessElementmethod to indicate that the runner must ensure that the observable contents of the inputPCollectionis sorted by time, in ascending order. - DoFn.Restriction - Annotation Type in org.apache.beam.sdk.transforms
-
Parameter annotation for the restriction for
DoFn.GetSize,DoFn.SplitRestriction,DoFn.GetInitialWatermarkEstimatorState,DoFn.NewWatermarkEstimator, andDoFn.NewTrackermethods. - DoFn.Setup - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation for the method to use to prepare an instance for processing bundles of elements.
- DoFn.SideInput - Annotation Type in org.apache.beam.sdk.transforms
-
Parameter annotation for the SideInput for a
DoFn.ProcessElementmethod. - DoFn.SplitRestriction - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation for the method that splits restriction of a splittable
DoFninto multiple parts to be processed in parallel. - DoFn.StartBundle - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation for the method to use to prepare an instance for processing a batch of elements.
- DoFn.StartBundleContext - Class in org.apache.beam.sdk.transforms
-
Information accessible while within the
DoFn.StartBundlemethod. - DoFn.StateId - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation for declaring and dereferencing state cells.
- DoFn.Teardown - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation for the method to use to clean up this instance before it is discarded.
- DoFn.TimerFamily - Annotation Type in org.apache.beam.sdk.transforms
-
Parameter annotation for the TimerMap for a
DoFn.ProcessElementmethod. - 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
-
Parameter annotation for the input element timestamp for
DoFn.ProcessElement,DoFn.GetInitialRestriction,DoFn.GetSize,DoFn.SplitRestriction,DoFn.GetInitialWatermarkEstimatorState,DoFn.NewWatermarkEstimator, andDoFn.NewTrackermethods. - DoFn.TruncateRestriction - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation for the method that truncates the restriction of a splittable
DoFninto a bounded one. - DoFn.UnboundedPerElement - Annotation Type in org.apache.beam.sdk.transforms
-
Annotation on a splittable
DoFnspecifying that theDoFnperforms an unbounded amount of work per input element, so applying it to a boundedPCollectionwill produce an unboundedPCollection. - DoFn.WatermarkEstimatorState - Annotation Type in org.apache.beam.sdk.transforms
-
Parameter annotation for the watermark estimator state for the
DoFn.NewWatermarkEstimatormethod. - DoFn.WindowedContext - Class in org.apache.beam.sdk.transforms
-
Information accessible to all methods in this
DoFnwhere 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
DoFnprocessing methods. - DoFnInvoker.ArgumentProvider<InputT,OutputT> - Interface in org.apache.beam.sdk.transforms.reflect
-
Interface for runner implementors to provide implementations of extra context information.
- DoFnInvoker.BaseArgumentProvider<InputT,OutputT> - Class in org.apache.beam.sdk.transforms.reflect
-
This
DoFnInvoker.ArgumentProviderthrowsUnsupportedOperationExceptionfor all parameters. - DoFnInvoker.DelegatingArgumentProvider<InputT,OutputT> - Class in org.apache.beam.sdk.transforms.reflect
-
An
DoFnInvoker.ArgumentProviderthat forwards all calls to the supplieddelegate. - DoFnInvoker.FakeArgumentProvider<InputT,OutputT> - Class in org.apache.beam.sdk.transforms.reflect
-
A fake
DoFnInvoker.ArgumentProviderused during testing. - DoFnInvokers - Class in org.apache.beam.sdk.transforms.reflect
-
Static utilities for working with
DoFnInvoker. - DoFnOutputReceivers - Class in org.apache.beam.sdk.transforms
-
Common
DoFn.OutputReceiverandDoFn.MultiOutputReceiverclasses. - 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.StartBundleorDoFn.FinishBundlemethod. - 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.GetInitialRestrictionmethod. - DoFnSignature.GetInitialWatermarkEstimatorStateMethod - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a
DoFn.GetInitialWatermarkEstimatorStatemethod. - DoFnSignature.GetRestrictionCoderMethod - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a
DoFn.GetRestrictionCodermethod. - DoFnSignature.GetSizeMethod - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a
DoFn.GetSizemethod. - DoFnSignature.GetWatermarkEstimatorStateCoderMethod - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a
DoFn.GetRestrictionCodermethod. - DoFnSignature.LifecycleMethod - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a
DoFn.SetuporDoFn.Teardownmethod. - DoFnSignature.MethodWithExtraParameters - Interface in org.apache.beam.sdk.transforms.reflect
-
A method delegated to an annotated method of an underlying
DoFnthat accepts a dynamic list of parameters. - DoFnSignature.NewTrackerMethod - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a
DoFn.NewTrackermethod. - DoFnSignature.NewWatermarkEstimatorMethod - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a
DoFn.NewWatermarkEstimatormethod. - DoFnSignature.OnTimerFamilyMethod - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a
DoFn.OnTimerFamilymethod. - DoFnSignature.OnTimerMethod - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a
DoFn.OnTimermethod. - DoFnSignature.OnWindowExpirationMethod - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a
DoFn.OnWindowExpirationmethod. - DoFnSignature.Parameter - Class in org.apache.beam.sdk.transforms.reflect
-
A descriptor for an optional parameter of the
DoFn.ProcessElementmethod. - DoFnSignature.Parameter.BundleFinalizerParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.BundleFinalizer. - DoFnSignature.Parameter.Cases<ResultT> - Interface in org.apache.beam.sdk.transforms.reflect
-
An interface for destructuring a
DoFnSignature.Parameter. - DoFnSignature.Parameter.Cases.WithDefault<ResultT> - Class in org.apache.beam.sdk.transforms.reflect
-
A base class for a visitor with a default method for cases it is not interested in.
- DoFnSignature.Parameter.ElementParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.Element. - DoFnSignature.Parameter.FinishBundleContextParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.FinishBundleContext. - DoFnSignature.Parameter.KeyParameter - Class in org.apache.beam.sdk.transforms.reflect
- DoFnSignature.Parameter.OnTimerContextParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.OnTimerContext. - DoFnSignature.Parameter.OnWindowExpirationContextParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.OnWindowExpirationContext. - DoFnSignature.Parameter.OutputReceiverParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.OutputReceiver. - DoFnSignature.Parameter.PaneInfoParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typePaneInfo. - DoFnSignature.Parameter.PipelineOptionsParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof a subtype ofPipelineOptions. - DoFnSignature.Parameter.ProcessContextParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.ProcessContext. - DoFnSignature.Parameter.RestrictionParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.Restriction. - DoFnSignature.Parameter.RestrictionTrackerParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof a subclass ofRestrictionTracker. - DoFnSignature.Parameter.SchemaElementParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a (@link Parameter} of type
DoFn.Elementwhere the type does not match the DoFn's input type. - DoFnSignature.Parameter.SchemaElementParameter.Builder - Class in org.apache.beam.sdk.transforms.reflect
-
Builder class.
- DoFnSignature.Parameter.SideInputParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.SideInput. - DoFnSignature.Parameter.SideInputParameter.Builder - Class in org.apache.beam.sdk.transforms.reflect
-
Builder class.
- DoFnSignature.Parameter.StartBundleContextParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.StartBundleContext. - DoFnSignature.Parameter.StateParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof a subclass ofState, with an id indicated by itsDoFn.StateIdannotation. - DoFnSignature.Parameter.TaggedOutputReceiverParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.MultiOutputReceiver. - DoFnSignature.Parameter.TimeDomainParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterrepresenting the time domain of a timer. - DoFnSignature.Parameter.TimerFamilyParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.TimerFamily. - DoFnSignature.Parameter.TimerIdParameter - Class in org.apache.beam.sdk.transforms.reflect
- DoFnSignature.Parameter.TimerParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeTimer, with an id indicated by itsDoFn.TimerIdannotation. - DoFnSignature.Parameter.TimestampParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.Timestamp. - DoFnSignature.Parameter.WatermarkEstimatorParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.WatermarkEstimatorState. - DoFnSignature.Parameter.WatermarkEstimatorStateParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeDoFn.WatermarkEstimatorState. - DoFnSignature.Parameter.WindowParameter - Class in org.apache.beam.sdk.transforms.reflect
-
Descriptor for a
DoFnSignature.Parameterof typeBoundedWindow. - DoFnSignature.ProcessElementMethod - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a
DoFn.ProcessElementmethod. - DoFnSignature.SplitRestrictionMethod - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a
DoFn.SplitRestrictionmethod. - DoFnSignature.StateDeclaration - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a state declaration; a field of type
StateSpecannotated withDoFn.StateId. - DoFnSignature.TimerDeclaration - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a timer declaration; a field of type
TimerSpecannotated withDoFn.TimerId. - DoFnSignature.TimerFamilyDeclaration - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a timer family declaration; a field of type
TimerSpecannotated withDoFn.TimerFamily. - DoFnSignature.TruncateRestrictionMethod - Class in org.apache.beam.sdk.transforms.reflect
-
Describes a
DoFn.TruncateRestrictionmethod. - DoFnSignatures - Class in org.apache.beam.sdk.transforms.reflect
-
Utilities for working with
DoFnSignature. - DoFnTester<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
Deprecated.Use
TestPipelinewith theDirectRunner. - DoFnTester.CloningBehavior - Enum in org.apache.beam.sdk.transforms
-
Deprecated.Use
TestPipelinewith theDirectRunner. - 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
- doFnWithExecutionInformationFromProto(RunnerApi.FunctionSpec) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- DONE - org.apache.beam.sdk.PipelineResult.State
-
The job has successfully completed.
- 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() - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionComponentContext
- DotExpressionComponentContext(ParserRuleContext, int) - 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 - org.apache.beam.sdk.schemas.Schema.TypeName
- DOUBLE - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
-
The type of double fields.
- DOUBLE_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- DoubleCoder - Class in org.apache.beam.sdk.coders
-
A
DoubleCoderencodesDoublevalues in 8 bytes using Java serialization. - doubles() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorfor Double. - doublesGlobally() - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a
PTransformthat takes an inputPCollection<Double>and returns aPCollection<Double>whose contents is the maximum of the inputPCollection's elements, orDouble.NEGATIVE_INFINITYif there are no elements. - doublesGlobally() - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a
PTransformthat takes an inputPCollection<Double>and returns aPCollection<Double>whose contents is the minimum of the inputPCollection's elements, orDouble.POSITIVE_INFINITYif there are no elements. - doublesGlobally() - Static method in class org.apache.beam.sdk.transforms.Sum
-
Returns a
PTransformthat takes an inputPCollection<Double>and returns aPCollection<Double>whose contents is the sum of the inputPCollection's elements, or0if there are no elements. - doublesPerKey() - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a
PTransformthat takes an inputPCollection<KV<K, Double>>and returns aPCollection<KV<K, Double>>that contains an output element mapping each distinct key in the inputPCollectionto the maximum of the values associated with that key in the inputPCollection. - doublesPerKey() - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a
PTransformthat takes an inputPCollection<KV<K, Double>>and returns aPCollection<KV<K, Double>>that contains an output element mapping each distinct key in the inputPCollectionto the minimum of the values associated with that key in the inputPCollection. - doublesPerKey() - Static method in class org.apache.beam.sdk.transforms.Sum
-
Returns a
PTransformthat takes an inputPCollection<KV<K, Double>>and returns aPCollection<KV<K, Double>>that contains an output element mapping each distinct key in the inputPCollectionto the sum of the values associated with that key in the inputPCollection. - drop(List<String>) - Method in class org.apache.beam.sdk.util.RowFilter
- 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.
- DURATION - org.apache.beam.sdk.transforms.display.DisplayData.Type
- DurationCoder - Class in org.apache.beam.sdk.coders
- durationMilliSec - Variable in class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
- DynamicDestinations() - Constructor for class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
- DynamicFileDestinations - Class in org.apache.beam.sdk.io
-
Some helper classes that derive from
FileBasedSink.DynamicDestinations. - DynamicFileDestinations() - Constructor for class org.apache.beam.sdk.io.DynamicFileDestinations
E
- EARLIEST - org.apache.beam.sdk.transforms.windowing.TimestampCombiner
-
The policy of taking at the earliest of a set of timestamps.
- EARLY - org.apache.beam.sdk.transforms.windowing.PaneInfo.Timing
-
Pane was fired before the input watermark had progressed after the end of the window.
- eitherOf(Watch.Growth.TerminationCondition<InputT, FirstStateT>, Watch.Growth.TerminationCondition<InputT, SecondStateT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
Returns a
Watch.Growth.TerminationConditionthat holds when at least one of the given two conditions holds. - element() - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContext
-
Returns the input element to be processed.
- element() - 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
- 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 - org.apache.beam.sdk.testing.TestStream.EventType
- 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
- elementCoderId() - Method in class org.apache.beam.sdk.util.construction.ModelCoders.WindowedValueCoderComponents
- elementCountAtLeast(int) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterPane
-
Creates a trigger that fires when the pane contains at least
countElemselements. - ElementDelimitedOutputStream(DataStreams.OutputChunkConsumer<ByteString>, int) - Constructor for class org.apache.beam.sdk.fn.stream.DataStreams.ElementDelimitedOutputStream
- 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
- 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 method in class org.apache.beam.sdk.metrics.BoundedTrieResult
- empty() - Static method in class org.apache.beam.sdk.metrics.GaugeResult
- empty() - Static method in class org.apache.beam.sdk.metrics.StringSetResult
- empty() - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Asserts that the iterable in question is empty.
- empty() - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
- empty() - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.empty(). - empty() - Static method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
Returns an empty
CoGbkResult. - empty() - Static method in class org.apache.beam.sdk.transforms.Requirements
-
Describes an empty set of requirements.
- empty() - Static method in class org.apache.beam.sdk.util.ApiSurface
-
Returns an empty
ApiSurface. - empty() - Static method in class org.apache.beam.sdk.values.TupleTagList
-
Returns an empty
TupleTagList. - empty(Coder<T>) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns a new
Create.Valuestransform that produces an emptyPCollection. - empty(Pipeline) - Static method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
Returns an empty
KeyedPCollectionTuple<K>on the given pipeline. - empty(Pipeline) - Static method in class org.apache.beam.sdk.values.PCollectionList
-
Returns an empty
PCollectionListthat is part of the givenPipeline. - empty(Pipeline) - Static method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
Returns an empty
PCollectionRowTuplethat is part of the givenPipeline. - empty(Pipeline) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
Returns an empty
PCollectionTuplethat is part of the givenPipeline. - empty(Schema) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns a new
Create.Valuestransform that produces an emptyPCollectionof rows. - empty(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns a new
Create.Valuestransform that produces an emptyPCollection. - EMPTY - Static variable in class org.apache.beam.sdk.io.range.ByteKey
-
An empty key.
- EMPTY - Static variable in class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
- emptyArray() - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.emptyArray(). - emptyFlatten() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
- EmptyFlattenAsCreateFactory<T> - Class in org.apache.beam.sdk.util.construction
-
A
PTransformOverrideFactorythat provides an emptyCreateto replace aFlatten.PCollectionsthat takes no inputPCollections. - emptyIterable() - Static method in class org.apache.beam.sdk.fn.stream.PrefetchableIterables
-
Returns an empty
PrefetchableIterable. - emptyIterable() - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.emptyIterable(). - emptyIterator() - Static method in class org.apache.beam.sdk.fn.stream.PrefetchableIterators
-
Returns an empty
PrefetchableIterator. - EmptyListDefault() - Constructor for class org.apache.beam.sdk.transforms.resourcehints.ResourceHintsOptions.EmptyListDefault
- EmptyMatchTreatment - Enum in org.apache.beam.sdk.io.fs
-
Options for allowing or disallowing filepatterns that match no resources in
FileSystems.match(java.util.List<java.lang.String>). - EmptyOnDeserializationThreadLocal<T> - Class in org.apache.beam.sdk.util
-
A
SerializableThreadLocalwhich 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. - EncodableThrowable - Class in org.apache.beam.sdk.values
-
A wrapper around a
Throwablefor use with coders. - 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(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(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(IterableT, OutputStream) - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
- encode(Boolean, OutputStream) - Method in class org.apache.beam.sdk.coders.BooleanCoder
- encode(Byte, OutputStream) - Method in class org.apache.beam.sdk.coders.ByteCoder
- encode(Double, OutputStream) - Method in class org.apache.beam.sdk.coders.DoubleCoder
- encode(Float, OutputStream) - Method in class org.apache.beam.sdk.coders.FloatCoder
- encode(Integer, OutputStream) - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
- encode(Integer, OutputStream) - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
- encode(Integer, OutputStream) - Method in class org.apache.beam.sdk.coders.VarIntCoder
- encode(Integer, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
- encode(Long, OutputStream) - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
- encode(Long, OutputStream) - Method in class org.apache.beam.sdk.coders.VarLongCoder
- encode(Object, OutputStream) - Method in class org.apache.beam.sdk.util.construction.UnknownCoderWrapper
- encode(Short, OutputStream) - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
- 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(Void, OutputStream) - Method in class org.apache.beam.sdk.coders.VoidCoder
- 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(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) - Method in class org.apache.beam.sdk.util.BitSetCoder
-
Deprecated.
- encode(BitSet, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.BitSetCoder
- encode(BitSet, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.util.BitSetCoder
-
Deprecated.
- 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(Optional<T>, OutputStream) - Method in class org.apache.beam.sdk.coders.OptionalCoder
- encode(SortedMap<K, V>, OutputStream) - Method in class org.apache.beam.sdk.coders.SortedMapCoder
- encode(SortedMap<K, V>, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.SortedMapCoder
- encode(EncodedBoundedWindow, OutputStream) - Method in class org.apache.beam.sdk.fn.windowing.EncodedBoundedWindow.Coder
- encode(CountingSource.CounterMark, OutputStream) - Method in class org.apache.beam.sdk.io.CountingSource.CounterMarkCoder
- 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(FileIO.ReadableFile, OutputStream) - Method in class org.apache.beam.sdk.io.ReadableFileCoder
- 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(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(Timer<K>, OutputStream) - Method in class org.apache.beam.sdk.util.construction.Timer.Coder
- encode(ShardedKey<K>, OutputStream) - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
- 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(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(PCollectionViews.ValueOrMetadata<T, MetaT>, OutputStream) - Method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadataCoder
- encode(ShardedKey<KeyT>, OutputStream) - Method in class org.apache.beam.sdk.coders.ShardedKeyCoder
- 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
- encode(WindowedValue<T>, OutputStream) - Method in class org.apache.beam.sdk.values.WindowedValues.FullWindowedValueCoder
- encode(WindowedValue<T>, OutputStream) - Method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
- encode(WindowedValue<T>, OutputStream) - Method in class org.apache.beam.sdk.values.WindowedValues.ValueOnlyWindowedValueCoder
-
Deprecated.
- encode(WindowedValue<T>, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.WindowedValues.FullWindowedValueCoder
- encode(WindowedValue<T>, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
- encode(WindowedValue<T>, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.values.WindowedValues.ValueOnlyWindowedValueCoder
-
Deprecated.
- encode(Instant, OutputStream) - Method in class org.apache.beam.sdk.coders.InstantCoder
- encode(ReadableDuration, OutputStream) - Method in class org.apache.beam.sdk.coders.DurationCoder
- encode(T, OutputStream) - Method in class org.apache.beam.sdk.coders.Coder
-
Encodes the given value of type
Tonto the given output stream. - encode(T, OutputStream) - Method in class org.apache.beam.sdk.coders.DelegateCoder
- encode(T, OutputStream) - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
- encode(T, OutputStream) - Method in class org.apache.beam.sdk.coders.SerializableCoder
- 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) - Method in class org.apache.beam.sdk.coders.TimestampPrefixingWindowCoder
- encode(T, OutputStream) - Method in class org.apache.beam.sdk.coders.ZstdCoder
- encode(T, OutputStream) - Method in class org.apache.beam.sdk.schemas.SchemaCoder
- encode(T, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.Coder
-
Deprecated.only implement and call
Coder.encode(Object value, OutputStream) - encode(T, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.DelegateCoder
- encode(T, OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
- encodeAndOwn(byte[], OutputStream, Coder.Context) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
-
Encodes the provided
valuewith the identical encoding toByteArrayCoder.encode(byte[], java.io.OutputStream), but with optimizations that take ownership of the value. - EncodedBoundedWindow - Class in org.apache.beam.sdk.fn.windowing
-
An encoded
BoundedWindowused within Runners to track window information without needing to decode the window. - EncodedBoundedWindow() - Constructor for class org.apache.beam.sdk.fn.windowing.EncodedBoundedWindow
- EncodedBoundedWindow.Coder - Class in org.apache.beam.sdk.fn.windowing
- 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.
- END_OF_WINDOW - org.apache.beam.sdk.transforms.windowing.TimestampCombiner
-
The policy of using the end of the window, regardless of input timestamps.
- endsWith(String) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.endsWith(java.lang.String). - ensureAllReadsConsumed(Pipeline) - Static method in class org.apache.beam.sdk.util.construction.UnconsumedReads
- ensureSerializable(Coder<?>) - Static method in class org.apache.beam.sdk.util.SerializableUtils
-
Serializes a Coder and verifies that it can be correctly deserialized.
- ensureSerializable(T) - Static method in class org.apache.beam.sdk.util.SerializableUtils
- 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
- ENTER_TRANSFORM - org.apache.beam.sdk.Pipeline.PipelineVisitor.CompositeBehavior
- enterArrayQualifier(FieldSpecifierNotationParser.ArrayQualifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Enter a parse tree produced by
FieldSpecifierNotationParser.arrayQualifier(). - enterArrayQualifier(FieldSpecifierNotationParser.ArrayQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Enter a parse tree produced by
FieldSpecifierNotationParser.arrayQualifier(). - enterArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Enter a parse tree produced by the
arrayQualifierListlabeled alternative inFieldSpecifierNotationParser.qualifierList(). - enterArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Enter a parse tree produced by the
arrayQualifierListlabeled alternative inFieldSpecifierNotationParser.qualifierList(). - enterCompositeTransform(TransformHierarchy.Node) - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
- enterCompositeTransform(TransformHierarchy.Node) - Method in interface org.apache.beam.sdk.Pipeline.PipelineVisitor
-
Called for each composite transform after all topological predecessors have been visited but before any of its component transforms.
- enterCompositeTransform(TransformHierarchy.Node) - Method in class org.apache.beam.sdk.util.construction.renderer.PipelineDotRenderer
- enterDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Enter a parse tree produced by
FieldSpecifierNotationParser.dotExpression(). - enterDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Enter a parse tree produced by
FieldSpecifierNotationParser.dotExpression(). - enterEveryRule(ParserRuleContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
- enterFieldSpecifier(FieldSpecifierNotationParser.FieldSpecifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Enter a parse tree produced by
FieldSpecifierNotationParser.fieldSpecifier(). - enterFieldSpecifier(FieldSpecifierNotationParser.FieldSpecifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Enter a parse tree produced by
FieldSpecifierNotationParser.fieldSpecifier(). - enterMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Enter a parse tree produced by
FieldSpecifierNotationParser.mapQualifier(). - enterMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Enter a parse tree produced by
FieldSpecifierNotationParser.mapQualifier(). - enterMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Enter a parse tree produced by the
mapQualifierListlabeled alternative inFieldSpecifierNotationParser.qualifierList(). - enterMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Enter a parse tree produced by the
mapQualifierListlabeled alternative inFieldSpecifierNotationParser.qualifierList(). - enterPipeline(Pipeline) - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
- enterPipeline(Pipeline) - Method in interface org.apache.beam.sdk.Pipeline.PipelineVisitor
-
Called before visiting anything values or transforms, as many uses of a visitor require access to the
Pipelineobject itself. - enterPipeline(Pipeline) - Method in class org.apache.beam.sdk.util.construction.renderer.PipelineDotRenderer
- enterQualifiedComponent(FieldSpecifierNotationParser.QualifiedComponentContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Enter a parse tree produced by
FieldSpecifierNotationParser.qualifiedComponent(). - enterQualifiedComponent(FieldSpecifierNotationParser.QualifiedComponentContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Enter a parse tree produced by
FieldSpecifierNotationParser.qualifiedComponent(). - enterQualifyComponent(FieldSpecifierNotationParser.QualifyComponentContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Enter a parse tree produced by the
qualifyComponentlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - enterQualifyComponent(FieldSpecifierNotationParser.QualifyComponentContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Enter a parse tree produced by the
qualifyComponentlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierContext
- enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierListContext
- enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionContext
- enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.FieldSpecifierContext
- enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierContext
- enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierListContext
- enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
- enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifyComponentContext
- enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.SimpleIdentifierContext
- enterRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.WildcardContext
- enterSimpleIdentifier(FieldSpecifierNotationParser.SimpleIdentifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Enter a parse tree produced by the
simpleIdentifierlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - enterSimpleIdentifier(FieldSpecifierNotationParser.SimpleIdentifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Enter a parse tree produced by the
simpleIdentifierlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - enterWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Enter a parse tree produced by the
wildcardlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - enterWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Enter a parse tree produced by the
wildcardlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - entries() - Method in interface org.apache.beam.sdk.state.MapState
-
Returns an
Iterableover the key-value pairs contained in this map. - entries() - Method in interface org.apache.beam.sdk.state.MultimapState
-
Returns an
Iterableover all key-value pairs contained in this multimap. - entrySet() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- EnumerationType - Class in org.apache.beam.sdk.schemas.logicaltypes
-
This
Schema.LogicalTyperepresent an enumeration over a fixed set of values. - EnumerationType.Value - Class in org.apache.beam.sdk.schemas.logicaltypes
-
This class represents a single enum value.
- ENVIRONMENT_DOCKER - Static variable in class org.apache.beam.sdk.util.construction.Environments
- ENVIRONMENT_EMBEDDED - Static variable in class org.apache.beam.sdk.util.construction.Environments
- ENVIRONMENT_EXTERNAL - Static variable in class org.apache.beam.sdk.util.construction.Environments
- ENVIRONMENT_LOOPBACK - Static variable in class org.apache.beam.sdk.util.construction.Environments
- ENVIRONMENT_PROCESS - Static variable in class org.apache.beam.sdk.util.construction.Environments
- Environments - Class in org.apache.beam.sdk.util.construction
-
Utilities for interacting with portability
environments. - Environments.JavaVersion - Enum in org.apache.beam.sdk.util.construction
- equal(T) - Static method in class org.apache.beam.sdk.transforms.Filter
-
Returns a
PTransformthat takes an inputPCollection<T>and returns aPCollection<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.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.CachingFactory
- equals(Object) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
-
Deprecated.
- equals(Object) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema
- equals(Object) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema.GetterTypeSupplier
- equals(Object) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema.SetterTypeSupplier
- equals(Object) - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType.Value
- equals(Object) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
- equals(Object) - Method in class org.apache.beam.sdk.schemas.Schema
-
Returns true if two Schemas have the same fields in the same order.
- equals(Object) - Method in class org.apache.beam.sdk.schemas.Schema.Field
- equals(Object) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
- equals(Object) - Method in class org.apache.beam.sdk.schemas.Schema.Options
- equals(Object) - Method in class org.apache.beam.sdk.schemas.SchemaCoder
- equals(Object) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- equals(Object) - Method in class org.apache.beam.sdk.testing.PAssert.PAssertionSite
- equals(Object) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
-
Deprecated.
Object.equals(Object)is not supported on PAssert objects. If you meant to test object equality, use a variant ofPAssert.PCollectionContentsAssert.containsInAnyOrder(T...)instead. - equals(Object) - Method in class org.apache.beam.sdk.testing.SuccessOrFailure
- equals(Object) - Method in class org.apache.beam.sdk.testing.TestStream
- equals(Object) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique
-
Deprecated.
- equals(Object) - Method in class org.apache.beam.sdk.transforms.CombineFns.CoCombineResult
- equals(Object) - Method in class org.apache.beam.sdk.transforms.display.DisplayData
- equals(Object) - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
- equals(Object) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
- equals(Object) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
- equals(Object) - Method in class org.apache.beam.sdk.transforms.join.RawUnionValue
- equals(Object) - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
- equals(Object) - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHint
- equals(Object) - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHints
- 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.construction.RunnerPCollectionView
- equals(Object) - Method in class org.apache.beam.sdk.util.construction.Timer
- equals(Object) - Method in class org.apache.beam.sdk.util.HistogramData
- equals(Object) - Method in class org.apache.beam.sdk.util.SerializableThrowable
- 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.values.KV
- equals(Object) - Method in class org.apache.beam.sdk.values.PCollectionList
- equals(Object) - Method in class org.apache.beam.sdk.values.PCollectionRowTuple
- equals(Object) - Method in class org.apache.beam.sdk.values.PCollectionTuple
- equals(Object) - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryListFromMultimapViewFn
- equals(Object) - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryListViewFn
- equals(Object) - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableBackedListViewFn
- 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(Object) - Method in class org.apache.beam.sdk.values.RowWithGetters
- equals(Object) - Method in class org.apache.beam.sdk.values.ShardedKey
-
Deprecated.
- 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
- equals(WindowedValue<T>, WindowedValue<T>) - Static method in class org.apache.beam.sdk.values.WindowedValues
- equals(Object) - Method in class org.apache.beam.sdk.coders.ZstdCoder
- equals(Object) - Method in class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter
- equals(Object) - Method in class org.apache.beam.sdk.util.ShardedKey
- equals(Object) - Method in class org.apache.beam.sdk.util.WeightedValue
- equals(Object) - Method in class org.apache.beam.sdk.values.EncodableThrowable
- Equals() - Constructor for class org.apache.beam.sdk.values.Row.Equals
- equalTo(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.equalTo(Object). - equalTo(T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.equalTo(Object). - equivalent(Schema) - Method in class org.apache.beam.sdk.schemas.Schema
-
Returns true if two Schemas have the same fields, but possibly in different orders.
- equivalent(Schema.FieldType, Schema.EquivalenceNullablePolicy) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Check whether two types are equivalent.
- ERROR - org.apache.beam.sdk.io.fs.MatchResult.Status
- ERROR - org.apache.beam.sdk.options.PipelineOptions.CheckEnabled
- ERROR - org.apache.beam.sdk.options.SdkHarnessOptions.LogLevel
-
LogLevel for logging error messages.
- 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
- ERROR_TAG - Static variable in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformProvider
- ERROR_TAG - Static variable in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformProvider
- ErrorFn(String, SerializableFunction<byte[], Row>, Schema, boolean) - Constructor for class org.apache.beam.sdk.io.TFRecordReadSchemaTransformProvider.ErrorFn
- ErrorFn(String, SerializableFunction<Row, byte[]>, Schema, boolean) - Constructor for class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformProvider.ErrorFn
- ErrorHandler<ErrorT,OutputT extends POutput> - Interface in org.apache.beam.sdk.transforms.errorhandling
-
An Error Handler is a utility object used for plumbing error PCollections to a configured sink Error Handlers must be closed before a pipeline is run to properly pipe error collections to the sink, and the pipeline will be rejected if any handlers aren't closed.
- ErrorHandler.BadRecordErrorHandler<OutputT extends POutput> - Class in org.apache.beam.sdk.transforms.errorhandling
- ErrorHandler.DefaultErrorHandler<ErrorT,OutputT extends POutput> - Class in org.apache.beam.sdk.transforms.errorhandling
-
A default, placeholder error handler that exists to allow usage of .addErrorCollection() without effects.
- ErrorHandler.PTransformErrorHandler<ErrorT,OutputT extends POutput> - Class in org.apache.beam.sdk.transforms.errorhandling
- ErrorHandler.PTransformErrorHandler.WriteErrorMetrics<ErrorT> - Class in org.apache.beam.sdk.transforms.errorhandling
- ErrorHandler.PTransformErrorHandler.WriteErrorMetrics.CountErrors<ErrorT> - Class in org.apache.beam.sdk.transforms.errorhandling
- ErrorHandling - Class in org.apache.beam.sdk.schemas.transforms.providers
- ErrorHandling() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling
- ErrorHandling.Builder - Class in org.apache.beam.sdk.schemas.transforms.providers
- errorRecord(Schema, byte[], Throwable) - Static method in class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling
- errorRecord(Schema, Row, Throwable) - Static method in class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling
- errorSchema(Schema) - Static method in class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling
- errorSchemaBytes() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling
- 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
- EVENT_TIME - org.apache.beam.sdk.state.TimeDomain
-
The
TimeDomain.EVENT_TIMEdomain corresponds to the timestamps on the elements. - 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
SlidingWindowswith the original size, that assigns timestamps into half-open intervals of the form [N * period, N * period + size), where 0 is the epoch. - exceptAll() - Static method in class org.apache.beam.sdk.transforms.Sets
-
Returns a new
PTransformtransform that follows SET ALL semantics which takes aPCollectionList<PCollection<T>>and returns aPCollection<T>containing the difference all (exceptAll) of collections done in order for all collections inPCollectionList<T>. - exceptAll(PCollection<T>) - Static method in class org.apache.beam.sdk.transforms.Sets
-
Returns a new
PTransformtransform that follows SET ALL semantics to compute the difference all (exceptAll) with providedPCollection<T>. - exceptDistinct() - Static method in class org.apache.beam.sdk.transforms.Sets
-
Returns a
PTransformthat takes aPCollectionList<PCollection<T>>and returns aPCollection<T>containing the difference (except) of collections done in order for all collections inPCollectionList<T>. - exceptDistinct(PCollection<T>) - Static method in class org.apache.beam.sdk.transforms.Sets
-
Returns a new
PTransformtransform that follows SET DISTINCT semantics to compute the difference (except) with providedPCollection<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
- EXCEPTION - org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult.IsException
- ExceptionAsMapHandler() - Constructor for class org.apache.beam.sdk.transforms.WithFailures.ExceptionAsMapHandler
- ExceptionElement() - Constructor for class org.apache.beam.sdk.transforms.WithFailures.ExceptionElement
- exceptionHandler - Variable in class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform
- ExceptionOrResult() - Constructor for class org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult
- exceptionsInto(TypeDescriptor<FailureT>) - Method in class org.apache.beam.sdk.transforms.MapKeys
-
Returns a new
SimpleMapWithFailurestransform that catches exceptions raised while mapping elements, with the given type descriptor used for the failure collection but the exception handler yet to be specified usingSimpleMapWithFailures.exceptionsVia(ProcessFunction). - exceptionsInto(TypeDescriptor<FailureT>) - Method in class org.apache.beam.sdk.transforms.MapValues
-
Returns a new
SimpleMapWithFailurestransform that catches exceptions raised while mapping elements, with the given type descriptor used for the failure collection but the exception handler yet to be specified usingSimpleMapWithFailures.exceptionsVia(ProcessFunction). - exceptionsInto(TypeDescriptor<NewFailureT>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
-
Returns a new
FlatMapElements.FlatMapWithFailurestransform that catches exceptions raised while mapping elements, with the given type descriptor used for the failure collection but the exception handler yet to be specified usingFlatMapElements.FlatMapWithFailures.exceptionsVia(ProcessFunction). - exceptionsInto(TypeDescriptor<NewFailureT>) - Method in class org.apache.beam.sdk.transforms.MapElements
-
Returns a new
MapElements.MapWithFailurestransform that catches exceptions raised while mapping elements, with the given type descriptor used for the failure collection but the exception handler yet to be specified usingMapElements.MapWithFailures.exceptionsVia(ProcessFunction). - exceptionsVia(InferableFunction<WithFailures.ExceptionElement<InputT>, FailureT>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
-
Returns a new
FlatMapElements.FlatMapWithFailurestransform that catches exceptions raised while mapping elements, passing the raised exception instance and the input element being processed through the givenexceptionHandlerand 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.MapWithFailurestransform that catches exceptions raised while mapping elements, passing the raised exception instance and the input element being processed through the givenexceptionHandlerand emitting the result to a failure collection. - exceptionsVia(InferableFunction<WithFailures.ExceptionElement<KV<K, V1>>, FailureT>) - Method in class org.apache.beam.sdk.transforms.MapValues
-
Returns a new
SimpleMapWithFailurestransform that catches exceptions raised while mapping elements, passing the raised exception instance and the input element being processed through the givenexceptionHandlerand emitting the result to a failure collection. - exceptionsVia(InferableFunction<WithFailures.ExceptionElement<KV<K1, V>>, FailureT>) - Method in class org.apache.beam.sdk.transforms.MapKeys
-
Returns a new
SimpleMapWithFailurestransform that catches exceptions raised while mapping elements, passing the raised exception instance and the input element being processed through the givenexceptionHandlerand 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.FlatMapWithFailurestransform that catches exceptions raised while mapping elements, passing the raised exception instance and the input element being processed through the givenexceptionHandlerand 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
PTransformthat catches exceptions raised while mapping elements, passing the raised exception instance and the input element being processed through the givenexceptionHandlerand emitting the result to a failure collection. - ExecutableStage - Interface in org.apache.beam.sdk.util.construction.graph
-
A combination of PTransforms that can be executed within a single SDK harness.
- ExecutableStageTranslation - Class in org.apache.beam.sdk.util.construction
-
Utilities for converting
ExecutableStages to and fromRunnerApiprotocol buffers. - ExecutableStageTranslation() - Constructor for class org.apache.beam.sdk.util.construction.ExecutableStageTranslation
- execute(Runnable) - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- ExecutorOptions - Interface in org.apache.beam.sdk.options
-
Options for configuring the
ScheduledExecutorServiceused throughout the Java runtime. - ExecutorOptions.ScheduledExecutorServiceFactory - Class in org.apache.beam.sdk.options
-
Returns the default
ScheduledExecutorServiceto use within the Apache Beam SDK. - exitArrayQualifier(FieldSpecifierNotationParser.ArrayQualifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Exit a parse tree produced by
FieldSpecifierNotationParser.arrayQualifier(). - exitArrayQualifier(FieldSpecifierNotationParser.ArrayQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Exit a parse tree produced by
FieldSpecifierNotationParser.arrayQualifier(). - exitArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Exit a parse tree produced by the
arrayQualifierListlabeled alternative inFieldSpecifierNotationParser.qualifierList(). - exitArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Exit a parse tree produced by the
arrayQualifierListlabeled alternative inFieldSpecifierNotationParser.qualifierList(). - exitDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Exit a parse tree produced by
FieldSpecifierNotationParser.dotExpression(). - exitDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Exit a parse tree produced by
FieldSpecifierNotationParser.dotExpression(). - exitEveryRule(ParserRuleContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
- exitFieldSpecifier(FieldSpecifierNotationParser.FieldSpecifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Exit a parse tree produced by
FieldSpecifierNotationParser.fieldSpecifier(). - exitFieldSpecifier(FieldSpecifierNotationParser.FieldSpecifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Exit a parse tree produced by
FieldSpecifierNotationParser.fieldSpecifier(). - exitMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Exit a parse tree produced by
FieldSpecifierNotationParser.mapQualifier(). - exitMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Exit a parse tree produced by
FieldSpecifierNotationParser.mapQualifier(). - exitMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Exit a parse tree produced by the
mapQualifierListlabeled alternative inFieldSpecifierNotationParser.qualifierList(). - exitMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Exit a parse tree produced by the
mapQualifierListlabeled alternative inFieldSpecifierNotationParser.qualifierList(). - exitQualifiedComponent(FieldSpecifierNotationParser.QualifiedComponentContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Exit a parse tree produced by
FieldSpecifierNotationParser.qualifiedComponent(). - exitQualifiedComponent(FieldSpecifierNotationParser.QualifiedComponentContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Exit a parse tree produced by
FieldSpecifierNotationParser.qualifiedComponent(). - exitQualifyComponent(FieldSpecifierNotationParser.QualifyComponentContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Exit a parse tree produced by the
qualifyComponentlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - exitQualifyComponent(FieldSpecifierNotationParser.QualifyComponentContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Exit a parse tree produced by the
qualifyComponentlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierContext
- exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierListContext
- exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionContext
- exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.FieldSpecifierContext
- exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierContext
- exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierListContext
- exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
- exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifyComponentContext
- exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.SimpleIdentifierContext
- exitRule(ParseTreeListener) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.WildcardContext
- exitSimpleIdentifier(FieldSpecifierNotationParser.SimpleIdentifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Exit a parse tree produced by the
simpleIdentifierlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - exitSimpleIdentifier(FieldSpecifierNotationParser.SimpleIdentifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Exit a parse tree produced by the
simpleIdentifierlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - exitWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
-
Exit a parse tree produced by the
wildcardlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - exitWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationListener
-
Exit a parse tree produced by the
wildcardlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - expand() - Method in class org.apache.beam.sdk.io.WriteFilesResult
- expand() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
Expands the component
PCollections, stripping off any tag-specific information. - expand() - Method in class org.apache.beam.sdk.transforms.JsonToRow.ParseResult
- expand() - Method in class org.apache.beam.sdk.transforms.WithFailures.Result
- expand() - Method in class org.apache.beam.sdk.util.construction.RunnerPCollectionView
- 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.PCollectionRowTuple
- 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
-
Deprecated.A
PValuealways expands into itself. CallingPValue.expand()on a PValue is almost never appropriate. - expand(InputT) - Method in class org.apache.beam.sdk.transforms.PTransform
-
Override this method to specify how this
PTransformshould be expanded on the givenInputT. - expand(InputT) - Method in class org.apache.beam.sdk.util.construction.External.ExpandableTransform
- expand(InputT) - Method in class org.apache.beam.sdk.util.construction.ForwardingPTransform
- expand(InputT) - Method in class org.apache.beam.sdk.util.construction.PTransformTranslation.RawPTransform
-
By default, throws an exception, but can be overridden.
- expand(ExpansionApi.ExpansionRequest) - Method in interface org.apache.beam.sdk.util.construction.ExpansionServiceClient
- expand(KeyedPCollectionTuple<K>) - Method in class org.apache.beam.sdk.transforms.join.CoGroupByKey
- expand(PBegin) - Method in class org.apache.beam.sdk.io.BoundedReadFromUnboundedSource
- expand(PBegin) - Method in class org.apache.beam.sdk.io.FileIO.Match
- 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(PBegin) - Method in class org.apache.beam.sdk.io.TextIO.Read
- expand(PBegin) - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
- expand(PBegin) - Method in class org.apache.beam.sdk.testing.PAssert.OneSideInputAssert
- expand(PBegin) - Method in class org.apache.beam.sdk.testing.TestStream
- 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(PBegin) - Method in class org.apache.beam.sdk.transforms.Create.WindowedValues
- expand(PBegin) - Method in class org.apache.beam.sdk.transforms.Impulse
- expand(PBegin) - Method in class org.apache.beam.sdk.transforms.PeriodicImpulse
- expand(PBegin) - Method in class org.apache.beam.sdk.util.construction.PrimitiveCreate
- expand(PBegin) - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.PrimitiveBoundedRead
- expand(PBegin) - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.PrimitiveUnboundedRead
- expand(PBegin) - Method in class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource
- expand(PCollection) - Method in class org.apache.beam.sdk.schemas.transforms.Join.Impl
- expand(PCollection<? extends InputT>) - Method in class org.apache.beam.sdk.schemas.io.DeadLetteredTransform
- expand(PCollection<? extends InputT>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
- expand(PCollection<? extends InputT>) - Method in class org.apache.beam.sdk.transforms.MapElements
- 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<? extends Iterable<T>>) - Method in class org.apache.beam.sdk.transforms.Flatten.Iterables
- expand(PCollection<? extends KV<?, V>>) - Method in class org.apache.beam.sdk.transforms.Values
- expand(PCollection<? extends KV<K, ?>>) - Method in class org.apache.beam.sdk.transforms.Keys
- expand(PCollection<? extends KV<K, ? extends Iterable<InputT>>>) - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
- expand(PCollection<byte[]>) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
- expand(PCollection<ElemT>) - Method in class org.apache.beam.sdk.transforms.View.CreatePCollectionView
- expand(PCollection<ErrorT>) - Method in class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.PTransformErrorHandler.WriteErrorMetrics
- 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<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<InputT>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements.FlatMapWithFailures
- expand(PCollection<InputT>) - Method in class org.apache.beam.sdk.transforms.MapElements.MapWithFailures
- expand(PCollection<InputT>) - Method in class org.apache.beam.sdk.transforms.Watch.Growth
- expand(PCollection<InputT>) - Method in class org.apache.beam.sdk.util.construction.SplittableParDo
- expand(PCollection<String>) - Method in class org.apache.beam.sdk.io.FileIO.MatchAll
- expand(PCollection<String>) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
-
Deprecated.
- expand(PCollection<String>) - Method in class org.apache.beam.sdk.io.TextIO.Write
- expand(PCollection<String>) - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
- 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<FileIO.ReadableFile>) - Method in class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform
- expand(PCollection<FileIO.ReadableFile>) - Method in class org.apache.beam.sdk.io.TextIO.ReadFiles
- expand(PCollection<FileIO.ReadableFile>) - Method in class org.apache.beam.sdk.io.TFRecordIO.ReadFiles
- expand(PCollection<MatchResult.Metadata>) - Method in class org.apache.beam.sdk.io.FileIO.ReadMatches
- expand(PCollection<SuccessOrFailure>) - Method in class org.apache.beam.sdk.testing.PAssert.DefaultConcludeTransform
- expand(PCollection<PeriodicSequence.SequenceDefinition>) - Method in class org.apache.beam.sdk.transforms.PeriodicSequence
- expand(PCollection<KV<byte[], KV<InputT, RestrictionT>>>) - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElements
- 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(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(PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.PerKey
-
Deprecated.
- expand(PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.Deduplicate.KeyedValues
- expand(PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.GroupByEncryptedKey
- expand(PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.GroupByKey
- expand(PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.KvSwap
- expand(PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.Redistribute.RedistributeByKey
- expand(PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.Reshuffle
- 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<KV<K, V1>>) - Method in class org.apache.beam.sdk.transforms.MapValues
- expand(PCollection<KV<K1, V>>) - Method in class org.apache.beam.sdk.transforms.MapKeys
- 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(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<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<T>) - Method in class org.apache.beam.sdk.schemas.transforms.WithKeys
- 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(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.Globally
-
Deprecated.
- 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<T>) - Method in class org.apache.beam.sdk.transforms.Partition
- expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.Redistribute.RedistributeArbitrarily
- expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.Reshuffle.ViaRandomKey
- expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.Tee
- expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.ToJson
- 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<T>) - Method in class org.apache.beam.sdk.transforms.View.AsSingleton
- expand(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.Wait.OnSignal
- 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(PCollection<T>) - Method in class org.apache.beam.sdk.transforms.WithTimestamps
- expand(PCollection<UserT>) - Method in class org.apache.beam.sdk.io.FileIO.Write
- expand(PCollection<UserT>) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
- expand(PCollection<UserT>) - Method in class org.apache.beam.sdk.io.WriteFiles
- expand(PCollection<V>) - Method in class org.apache.beam.sdk.transforms.WithKeys
- expand(PCollectionList<T>) - Method in class org.apache.beam.sdk.transforms.Flatten.PCollections
- expand(PCollectionRowTuple) - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceSchemaTransform
- expand(PCollectionRowTuple) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider.ExplodeTransform
- expand(PCollectionRowTuple) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider.JavaFilterTransform
- expand(PCollectionRowTuple) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.JavaMapToFieldsTransform
- expand(PCollectionRowTuple) - Method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider.LoggingTransform
- 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
- expandAnyOfEnvironments(RunnerApi.Environment) - Static method in class org.apache.beam.sdk.util.construction.Environments
- 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
- ExpansionServiceClient - Interface in org.apache.beam.sdk.util.construction
-
A high-level client for a cross-language expansion service.
- ExpansionServiceClientFactory - Interface in org.apache.beam.sdk.util.construction
-
A factory for generating
ExpansionServiceClientfromEndpoints.ApiServiceDescriptor. - expectFileToNotExist() - Method in class org.apache.beam.sdk.io.fs.CreateOptions
-
True if the file is expected to not exist.
- ExperimentalOptions - Interface in org.apache.beam.sdk.options
-
Apache Beam provides a number of experimental features that can be enabled with this flag.
- ExplicitShardedFile - Class in org.apache.beam.sdk.util
-
A sharded file where the file names are simply provided.
- ExplicitShardedFile(Collection<String>) - Constructor for class org.apache.beam.sdk.util.ExplicitShardedFile
-
Constructs an
ExplicitShardedFilefor the given files. - explodeWindows() - Method in interface org.apache.beam.sdk.values.WindowedValue
-
A representation of each of the actual values represented by this compressed
WindowedValue, one per window. - explodeWindows() - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- exponential(int, int) - Static method in class org.apache.beam.sdk.util.HistogramData
-
Returns a histogram object with exponential boundaries.
- ExponentialBuckets() - Constructor for class org.apache.beam.sdk.util.HistogramData.ExponentialBuckets
- ExposedByteArrayInputStream - Class in org.apache.beam.sdk.util
-
ByteArrayInputStreamthat 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
-
ByteArrayOutputStreamspecial 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 - Class in org.apache.beam.sdk.util.construction
-
Cross-language external transform.
- External() - Constructor for class org.apache.beam.sdk.io.GenerateSequence.External
- External() - Constructor for class org.apache.beam.sdk.util.construction.External
- EXTERNAL_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.ExternalTranslation
- External.ExpandableTransform<InputT extends PInput,OutputT extends POutput> - Class in org.apache.beam.sdk.util.construction
-
Base Expandable Transform which calls ExpansionService to expand itself.
- External.MultiOutputExpandableTransform<InputT extends PInput> - Class in org.apache.beam.sdk.util.construction
-
Expandable transform for output type of PCollectionTuple.
- External.SingleOutputExpandableTransform<InputT extends PInput,OutputT> - Class in org.apache.beam.sdk.util.construction
-
Expandable transform for output type of PCollection.
- ExternalConfiguration() - Constructor for class org.apache.beam.sdk.io.GenerateSequence.External.ExternalConfiguration
- ExternalTransformBuilder<ConfigT,InputT extends PInput,OutputT extends POutput> - Interface in org.apache.beam.sdk.transforms
-
An interface for building a transform from an externally provided configuration.
- ExternalTransformRegistrar - Interface in org.apache.beam.sdk.expansion
-
A registrar which contains a mapping from URNs to available
ExternalTransformBuilders. - ExternalTranslation - Class in org.apache.beam.sdk.util.construction
-
Translating External transforms to proto.
- ExternalTranslation() - Constructor for class org.apache.beam.sdk.util.construction.ExternalTranslation
- ExternalTranslation.ExternalTranslator - Class in org.apache.beam.sdk.util.construction
-
Translator for ExpandableTransform.
- ExternalTranslationOptions - Interface in org.apache.beam.sdk.util.construction
- ExternalTranslationOptionsRegistrar - Class in org.apache.beam.sdk.util.construction
-
A registrar for ExternalTranslationOptions.
- ExternalTranslationOptionsRegistrar() - Constructor for class org.apache.beam.sdk.util.construction.ExternalTranslationOptionsRegistrar
- ExternalTranslator() - Constructor for class org.apache.beam.sdk.util.construction.ExternalTranslation.ExternalTranslator
- extractFromTypeParameters(T, Class<? super T>, TypeDescriptors.TypeVariableExtractor<T, V>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
Extracts a type from the actual type parameters of a parameterized class, subject to Java type erasure.
- extractFromTypeParameters(TypeDescriptor<T>, Class<? super T>, TypeDescriptors.TypeVariableExtractor<T, V>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
Like
TypeDescriptors.extractFromTypeParameters(Object, Class, TypeVariableExtractor), but takes aTypeDescriptorof the instance being analyzed rather than the instance itself. - 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(double[]) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
- 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.AccumulatingCombineFn
- 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(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(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(List<V>) - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
- extractOutput(ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
-
Deprecated.
- extractOutput(Combine.Holder<V>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
- extractOutput(Top.BoundedHeap<KV<Integer, T>, SerializableComparator<KV<Integer, T>>>) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
- extractResult() - Method in class org.apache.beam.sdk.util.HistogramData
- 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 class org.apache.beam.sdk.transforms.reflect.DoFnSignature.LifecycleMethod
-
Types of optional parameters of the annotated method, in the order they appear.
- extraParameters() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.MethodWithExtraParameters
-
Types of optional parameters of the annotated method, in the order they appear.
- extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewTrackerMethod
-
Types of optional parameters of the annotated method, in the order they appear.
- extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewWatermarkEstimatorMethod
-
Types of optional parameters of the annotated method, in the order they appear.
- extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerFamilyMethod
-
Types of optional parameters of the annotated method, in the order they appear.
- extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerMethod
-
Types of optional parameters of the annotated method, in the order they appear.
- extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnWindowExpirationMethod
-
Types of optional parameters of the annotated method, in the order they appear.
- extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
-
Types of optional parameters of the annotated method, in the order they appear.
- extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.SplitRestrictionMethod
-
Types of parameters of the annotated method, in the order they appear.
- extraParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TruncateRestrictionMethod
-
Types of parameters of the annotated method, in the order they appear.
F
- Factory<T> - Interface in org.apache.beam.sdk.schemas
-
A Factory interface for schema-related objects for a specific Java type.
- Factory() - Constructor for class org.apache.beam.sdk.util.construction.PrimitiveCreate.Factory
- FAILED - org.apache.beam.sdk.PipelineResult.State
-
The job has failed.
- 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
-
A coder for
FailsafeValueInSingleWindow. - failure(PAssert.PAssertionSite, Throwable) - Static method in class org.apache.beam.sdk.testing.SuccessOrFailure
- 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() - Constructor for class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Failure
- FAILURE_COUNTER - Static variable in class org.apache.beam.sdk.testing.PAssert
- Failure.Builder - Class in org.apache.beam.sdk.schemas.io
- 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
- Fanout() - Constructor for class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields.Fanout
- fewKeys() - Method in class org.apache.beam.sdk.transforms.GroupByKey
-
Returns whether it groups just few keys.
- fewKeys(CombineFnBase.GlobalCombineFn<? super InputT, ?, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.PerKey, and set fewKeys inGroupByKey. - 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
- 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() - Constructor for class org.apache.beam.sdk.schemas.Schema.Field
- fieldAccess(FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.transforms.Select
-
Select a set of fields described in a
FieldAccessDescriptor. - FieldAccessDeclaration() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.FieldAccessDeclaration
- fieldAccessDeclarations() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Field access declaration.
- fieldAccessDescriptor(FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.transforms.CoGroup.By
-
Join by the following field access descriptor.
- FieldAccessDescriptor - Class in org.apache.beam.sdk.schemas
-
Used inside of a
DoFnto describe which fields in a schema type need to be accessed for processing. - FieldAccessDescriptor() - Constructor for class org.apache.beam.sdk.schemas.FieldAccessDescriptor
- 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() - Static method in class org.apache.beam.sdk.state.StateKeySpec
- fields(Integer...) - Static method in class org.apache.beam.sdk.schemas.transforms.DropFields
- fields(String...) - 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
- FieldsEqual() - Constructor for class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual
- fieldSpecifier() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- FieldSpecifierContext(ParserRuleContext, int) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.FieldSpecifierContext
- FieldSpecifierNotationBaseListener - Class in org.apache.beam.sdk.schemas.parser.generated
-
This class provides an empty implementation of
FieldSpecifierNotationListener, which can be extended to create a listener which only needs to handle a subset of the available methods. - FieldSpecifierNotationBaseListener() - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
- FieldSpecifierNotationBaseVisitor<T> - Class in org.apache.beam.sdk.schemas.parser.generated
-
This class provides an empty implementation of
FieldSpecifierNotationVisitor, which can be extended to create a visitor which only needs to handle a subset of the available methods. - FieldSpecifierNotationBaseVisitor() - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
- FieldSpecifierNotationLexer - Class in org.apache.beam.sdk.schemas.parser.generated
- FieldSpecifierNotationLexer(CharStream) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- FieldSpecifierNotationListener - Interface in org.apache.beam.sdk.schemas.parser.generated
-
This interface defines a complete listener for a parse tree produced by
FieldSpecifierNotationParser. - FieldSpecifierNotationParser - Class in org.apache.beam.sdk.schemas.parser.generated
- FieldSpecifierNotationParser(TokenStream) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- FieldSpecifierNotationParser.ArrayQualifierContext - Class in org.apache.beam.sdk.schemas.parser.generated
- FieldSpecifierNotationParser.ArrayQualifierListContext - Class in org.apache.beam.sdk.schemas.parser.generated
- FieldSpecifierNotationParser.DotExpressionComponentContext - Class in org.apache.beam.sdk.schemas.parser.generated
- FieldSpecifierNotationParser.DotExpressionContext - Class in org.apache.beam.sdk.schemas.parser.generated
- FieldSpecifierNotationParser.FieldSpecifierContext - Class in org.apache.beam.sdk.schemas.parser.generated
- FieldSpecifierNotationParser.MapQualifierContext - Class in org.apache.beam.sdk.schemas.parser.generated
- FieldSpecifierNotationParser.MapQualifierListContext - Class in org.apache.beam.sdk.schemas.parser.generated
- FieldSpecifierNotationParser.QualifiedComponentContext - Class in org.apache.beam.sdk.schemas.parser.generated
- FieldSpecifierNotationParser.QualifierListContext - Class in org.apache.beam.sdk.schemas.parser.generated
- FieldSpecifierNotationParser.QualifyComponentContext - Class in org.apache.beam.sdk.schemas.parser.generated
- FieldSpecifierNotationParser.SimpleIdentifierContext - Class in org.apache.beam.sdk.schemas.parser.generated
- FieldSpecifierNotationParser.WildcardContext - Class in org.apache.beam.sdk.schemas.parser.generated
- FieldSpecifierNotationVisitor<T> - Interface in org.apache.beam.sdk.schemas.parser.generated
-
This interface defines a complete generic visitor for a parse tree produced by
FieldSpecifierNotationParser. - FieldType() - Constructor for class org.apache.beam.sdk.schemas.Schema.FieldType
- FieldTypeDescriptors - Class in org.apache.beam.sdk.schemas
-
Utilities for converting between
Schemafield types andTypeDescriptors 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
-
Get a
Schema.FieldTypefrom aTypeDescriptor. - FieldValueGetter<ObjectT extends @NonNull java.lang.Object,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.GetterBasedSchemaProvider
-
Deprecated.new implementations should override
GetterBasedSchemaProvider.fieldValueGetters(TypeDescriptor, Schema)and make this method throw anUnsupportedOperationException - fieldValueGetters(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProviderV2
- fieldValueGetters(TypeDescriptor<T>, Schema) - Method in class org.apache.beam.sdk.schemas.AutoValueSchema
- fieldValueGetters(TypeDescriptor<T>, Schema) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
-
Deprecated.Delegates to the
GetterBasedSchemaProvider.fieldValueGetters(Class, Schema)for backwards compatibility, override it if you want to use the richer type signature contained in theTypeDescriptornot subject to the type erasure. - fieldValueGetters(TypeDescriptor<T>, Schema) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProviderV2
- fieldValueGetters(TypeDescriptor<T>, Schema) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema
- fieldValueGetters(TypeDescriptor<T>, Schema) - Method in class org.apache.beam.sdk.schemas.JavaFieldSchema
- FieldValueHaver<ObjectT> - Interface in org.apache.beam.sdk.schemas
-
For internal use only; no backwards-compatibility guarantees.
- 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.GetterBasedSchemaProvider
-
Deprecated.new implementations should override
GetterBasedSchemaProvider.fieldValueTypeInformations(TypeDescriptor, Schema)and make this method throw anUnsupportedOperationException - fieldValueTypeInformations(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProviderV2
- fieldValueTypeInformations(TypeDescriptor<?>, Schema) - Method in class org.apache.beam.sdk.schemas.AutoValueSchema
- fieldValueTypeInformations(TypeDescriptor<?>, Schema) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
-
Deprecated.Delegates to the
GetterBasedSchemaProvider.fieldValueTypeInformations(Class, Schema)for backwards compatibility, override it if you want to use the richer type signature contained in theTypeDescriptornot subject to the type erasure. - fieldValueTypeInformations(TypeDescriptor<?>, Schema) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProviderV2
- fieldValueTypeInformations(TypeDescriptor<?>, Schema) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema
- fieldValueTypeInformations(TypeDescriptor<?>, 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.
- FILE - org.apache.beam.sdk.io.FileSystem.LineageLevel
- FILE_TRIGGERING_BYTE_COUNT - Static variable in class org.apache.beam.sdk.io.WriteFiles
- FILE_TRIGGERING_RECORD_BUFFERING_DURATION - Static variable in class org.apache.beam.sdk.io.WriteFiles
- FILE_TRIGGERING_RECORD_COUNT - Static variable in class org.apache.beam.sdk.io.WriteFiles
- 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
FileBasedSinkwith the given temp directory, producing uncompressed files. - FileBasedSink(ValueProvider<ResourceId>, FileBasedSink.DynamicDestinations<?, DestinationT, OutputT>, Compression) - Constructor for class org.apache.beam.sdk.io.FileBasedSink
-
Construct a
FileBasedSinkwith the given temp directory and output channel type. - FileBasedSink(ValueProvider<ResourceId>, FileBasedSink.DynamicDestinations<?, DestinationT, OutputT>, FileBasedSink.WritableByteChannelFactory) - Constructor for class org.apache.beam.sdk.io.FileBasedSink
-
Construct a
FileBasedSinkwith the given temp directory and output channel type. - FileBasedSink.CompressionType - Enum in org.apache.beam.sdk.io
-
Deprecated.use
Compression. - FileBasedSink.DynamicDestinations<UserT,DestinationT,OutputT> - Class in org.apache.beam.sdk.io
-
A class that allows value-dependent writes in
FileBasedSink. - FileBasedSink.FilenamePolicy - Class in org.apache.beam.sdk.io
-
A naming policy for output files.
- FileBasedSink.FileResult<DestinationT> - Class in org.apache.beam.sdk.io
-
Result of a single bundle write.
- FileBasedSink.FileResultCoder<DestinationT> - Class in org.apache.beam.sdk.io
-
A coder for
FileBasedSink.FileResultobjects. - FileBasedSink.OutputFileHints - Interface in org.apache.beam.sdk.io
-
Provides hints about how to generate output files, such as a suggested filename suffix (e.g.
- FileBasedSink.WritableByteChannelFactory - Interface in org.apache.beam.sdk.io
-
Implementations create instances of
WritableByteChannelused byFileBasedSinkand related classes to allow decorating, or otherwise transforming, the raw data that would normally be written directly to theWritableByteChannelpassed intoFileBasedSink.WritableByteChannelFactory.create(WritableByteChannel). - FileBasedSink.WriteOperation<DestinationT,OutputT> - Class in org.apache.beam.sdk.io
-
Abstract operation that manages the process of writing to
FileBasedSink. - FileBasedSink.Writer<DestinationT,OutputT> - Class in org.apache.beam.sdk.io
-
Abstract writer that writes a bundle to a
FileBasedSink. - FileBasedSource<T> - Class in org.apache.beam.sdk.io
-
A common base class for all file-based
Sources. - FileBasedSource(MatchResult.Metadata, long, long, long) - Constructor for class org.apache.beam.sdk.io.FileBasedSource
-
Create a
FileBasedSourcebased on a single file. - FileBasedSource(ValueProvider<String>, long) - Constructor for class org.apache.beam.sdk.io.FileBasedSource
-
Like
FileBasedSource(ValueProvider, EmptyMatchTreatment, long), but uses the default value ofEmptyMatchTreatment.DISALLOW. - FileBasedSource(ValueProvider<String>, EmptyMatchTreatment, long) - Constructor for class org.apache.beam.sdk.io.FileBasedSource
-
Create a
FileBaseSourcebased on a file or a file pattern specification, with the given strategy for treating filepatterns that do not match any files. - FileBasedSource.FileBasedReader<T> - Class in org.apache.beam.sdk.io
-
A
readerthat implements code common to readers ofFileBasedSources. - FileBasedSource.Mode - Enum in org.apache.beam.sdk.io
-
A given
FileBasedSourcerepresents 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
ShardedFilein E2E test. - fileContentsHaveChecksum(String) - Static method in class org.apache.beam.sdk.testing.FileChecksumMatcher
- FileIO - Class in org.apache.beam.sdk.io
-
General-purpose transforms for working with files: listing files (matching), reading and writing.
- FileIO() - Constructor for class org.apache.beam.sdk.io.FileIO
- FileIO.Match - Class in org.apache.beam.sdk.io
-
Implementation of
FileIO.match(). - FileIO.MatchAll - Class in org.apache.beam.sdk.io
-
Implementation of
FileIO.matchAll(). - FileIO.MatchConfiguration - Class in org.apache.beam.sdk.io
-
Describes configuration for matching filepatterns, such as
EmptyMatchTreatmentand continuous watching for matching files. - FileIO.ReadableFile - Class in org.apache.beam.sdk.io
-
A utility class for accessing a potentially compressed file.
- FileIO.ReadMatches - Class in org.apache.beam.sdk.io
-
Implementation of
FileIO.readMatches(). - FileIO.ReadMatches.DirectoryTreatment - Enum in org.apache.beam.sdk.io
-
Enum to control how directories are handled.
- FileIO.Sink<ElementT> - Interface in org.apache.beam.sdk.io
-
Specifies how to write elements to individual files in
FileIO.write()andFileIO.writeDynamic(). - FileIO.Write<DestinationT,UserT> - Class in org.apache.beam.sdk.io
-
Implementation of
FileIO.write()andFileIO.writeDynamic(). - FileIO.Write.FileNaming - Interface in org.apache.beam.sdk.io
-
A policy for generating names for shard files.
- FilenamePolicy() - Constructor for class org.apache.beam.sdk.io.FileBasedSink.FilenamePolicy
- filepattern(String) - Method in class org.apache.beam.sdk.io.FileIO.Match
-
Matches the given filepattern.
- filepattern(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.FileIO.Match
-
Like
FileIO.Match.filepattern(String)but using aValueProvider. - FILEPATTERN - org.apache.beam.sdk.io.FileBasedSource.Mode
- FilePatternMatchingShardedFile - Class in org.apache.beam.sdk.util
-
A sharded file which matches a given file pattern.
- FilePatternMatchingShardedFile(String) - Constructor for class org.apache.beam.sdk.util.FilePatternMatchingShardedFile
-
Constructs an
FilePatternMatchingShardedFilefor the given file pattern. - FileResult(ResourceId, int, BoundedWindow, PaneInfo, DestinationT) - Constructor for class org.apache.beam.sdk.io.FileBasedSink.FileResult
- FileResultCoder(Coder<BoundedWindow>, Coder<DestinationT>) - Constructor for class org.apache.beam.sdk.io.FileBasedSink.FileResultCoder
- FileStagingOptions - Interface in org.apache.beam.sdk.options
-
File staging related options.
- 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
- FileSystem.LineageLevel - Enum in org.apache.beam.sdk.io
- FileSystemRegistrar - Interface in org.apache.beam.sdk.io
-
A registrar that creates
FileSysteminstances fromPipelineOptions. - FileSystems - Class in org.apache.beam.sdk.io
-
Clients facing
FileSystemutility. - 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(List<Row>) - Method in class org.apache.beam.sdk.util.RowFilter
-
Applies
RowFilter.filter(Row)to each Row in a list. - filter(Row) - Method in class org.apache.beam.sdk.util.RowFilter
-
Performs a filter operation (keep or drop) on the input
Row. - Filter - Class in org.apache.beam.sdk.schemas.transforms
-
A
PTransformfor filtering a collection of schema types. - Filter<T> - Class in org.apache.beam.sdk.transforms
-
PTransforms for filtering from aPCollectionthe elements satisfying a predicate, or satisfying an inequality with a given value based on the elements' natural ordering. - Filter() - Constructor for class org.apache.beam.sdk.schemas.transforms.Filter
- 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.UnboundedReadersince the previous checkpoint was taken. - finalizeCheckpoint() - Method in class org.apache.beam.sdk.io.UnboundedSource.CheckpointMark.NoopCheckpointMark
- finalizeCheckpoint() - Method in class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter.Checkpoint
- finalizeDestination(DestinationT, BoundedWindow, Integer, Collection<FileBasedSink.FileResult<DestinationT>>) - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
- find(String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.FindPTransformthat checks if a portion of the line matches the Regex. - find(String, int) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.FindPTransformthat checks if a portion of the line matches the Regex. - find(String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.FindNamePTransformthat checks if a portion of the line matches the Regex. - find(Pattern) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.FindPTransformthat checks if a portion of the line matches the Regex. - find(Pattern, int) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.FindPTransformthat checks if a portion of the line matches the Regex. - find(Pattern, String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.FindNamePTransformthat checks if a portion of the line matches the Regex. - Find(Pattern, int) - Constructor for class org.apache.beam.sdk.transforms.Regex.Find
- findAll(String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.FindAllPTransformthat checks if a portion of the line matches the Regex. - findAll(Pattern) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.FindAllPTransformthat checks if a portion of the line matches the Regex. - FindAll(Pattern) - Constructor for class org.apache.beam.sdk.transforms.Regex.FindAll
- findClassLoader() - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
-
Finds the appropriate
ClassLoaderto be used by theServiceLoader.load(java.lang.Class<S>, java.lang.ClassLoader, java.lang.Module)call, which by default would use the contextClassLoader, which can be null. - findClassLoader(ClassLoader) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
-
Finds the appropriate
ClassLoaderto be used by theServiceLoader.load(java.lang.Class<S>, java.lang.ClassLoader, java.lang.Module)call, which by default would use the proposedClassLoader, which can be null. - findClassLoader(Class<?>...) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
-
Find the common classloader of all these classes.
- findKV(String, int, int) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.FindKVPTransformthat checks if a portion of the line matches the Regex. - findKV(String, String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.FindNameKVPTransformthat checks if a portion of the line matches the Regex. - findKV(Pattern, int, int) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.FindKVPTransformthat checks if a portion of the line matches the Regex. - findKV(Pattern, String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.FindNameKVPTransformthat checks if a portion of the line matches the Regex. - FindKV(Pattern, int, int) - Constructor for class org.apache.beam.sdk.transforms.Regex.FindKV
- FindName(Pattern, String) - Constructor for class org.apache.beam.sdk.transforms.Regex.FindName
- FindNameKV(Pattern, String, String) - Constructor for class org.apache.beam.sdk.transforms.Regex.FindNameKV
- findUpgradeURN(PTransform) - Static method in class org.apache.beam.sdk.util.construction.TransformUpgrader
-
A utility to find the registered URN for a given transform.
- finish() - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformProvider.ErrorFn
- finish() - Method in class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
-
Finishes the encoding by flushing any buffered data, and outputting a final count of 0.
- finish(DoFn.FinishBundleContext) - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformProvider.ErrorFn
- finishBundle() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - finishBundle() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.FinishBundlemethod. - finishBundle(DoFn.FinishBundleContext) - Method in class org.apache.beam.sdk.util.construction.SplittableParDoNaiveBounded.NaiveProcessFn
- finishBundle(DoFn.FinishBundleContext) - Method in class org.apache.beam.sdk.transforms.View.ToListViewDoFn
- finishBundleContext() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- finishBundleContext(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provide a
DoFn.FinishBundleContextto use with the givenDoFn. - finishBundleContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- finishBundleContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- FinishBundleContext() - Constructor for class org.apache.beam.sdk.transforms.DoFn.FinishBundleContext
- finishSpecifying() - Method in interface org.apache.beam.sdk.state.StateSpec
-
For internal use only; no backwards-compatibility guarantees.
- finishSpecifying(PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PCollection
-
After building, finalizes this
PValueto make it ready for running. - finishSpecifying(PInput, PTransform<?, ?>) - Method in interface org.apache.beam.sdk.values.PValue
-
After building, finalizes this
PValueto make it ready for being used as an input to aPTransform. - finishSpecifying(PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PValueBase
- finishSpecifyingInput() - Method in class org.apache.beam.sdk.runners.TransformHierarchy
-
Finish specifying all of the input
PValuesof the currentTransformHierarchy.Node. - finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.io.WriteFilesResult
- finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.transforms.JsonToRow.ParseResult
- finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.transforms.WithFailures.Result
- finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PCollection
- finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PCollectionList
- finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PCollectionRowTuple
- finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
- finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PDone
-
Does nothing; there is nothing to finish specifying.
- finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in interface org.apache.beam.sdk.values.POutput
-
As part of applying the producing
PTransform, finalizes this output to make it ready for being used as an input and for running. - finishSpecifyingOutput(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.values.PValueBase
- finishWrite() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
-
Called after all calls to
FileBasedSink.Writer.writeHeader(),FileBasedSink.Writer.write(OutputT)andFileBasedSink.Writer.writeFooter(). - FIRE_ALWAYS - org.apache.beam.sdk.transforms.windowing.Window.ClosingBehavior
-
Always fire the last pane.
- FIRE_ALWAYS - org.apache.beam.sdk.transforms.windowing.Window.OnTimeBehavior
-
Always fire the on-time pane.
- FIRE_IF_NON_EMPTY - org.apache.beam.sdk.transforms.windowing.Window.ClosingBehavior
-
Only fire the last pane if there is new data since the previous firing.
- FIRE_IF_NON_EMPTY - org.apache.beam.sdk.transforms.windowing.Window.OnTimeBehavior
-
Only fire the on-time pane if there is new data since the previous firing.
- fireTimestamp() - Method in class org.apache.beam.sdk.transforms.DoFn.OnTimerContext
-
Returns the firing timestamp of the current timer.
- first - Variable in class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
- fixDefaults() - Method in class org.apache.beam.sdk.values.WindowingStrategy
-
Fixes all the defaults so that equals can be used to check that two strategies are the same, regardless of the state of "defaulted-ness".
- FIXED_WINDOWS_URN - Static variable in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- FixedBytes - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A LogicalType representing a fixed-length byte array.
- FixedPrecisionNumeric - Class in org.apache.beam.sdk.schemas.logicaltypes
-
Fixed precision numeric types used to represent jdbc NUMERIC and DECIMAL types.
- fixedSizeGlobally(int) - Static method in class org.apache.beam.sdk.transforms.Sample
-
Returns a
PTransformthat takes aPCollection<T>, selectssampleSizeelements, uniformly at random, and returns aPCollection<Iterable<T>>containing the selected elements. - fixedSizePerKey(int) - Static method in class org.apache.beam.sdk.transforms.Sample
-
Returns a
PTransformthat takes an inputPCollection<KV<K, V>>and returns aPCollection<KV<K, Iterable<V>>>that contains an output element mapping each distinct key in the inputPCollectionto a sample ofsampleSizevalues associated with that key in the inputPCollection, taken uniformly at random. - FixedString - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A LogicalType representing a fixed-length string.
- FixedWindows - Class in org.apache.beam.sdk.transforms.windowing
-
A
WindowFnthat windows values into fixed-size timestamp-based windows. - FlatMapElements<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
PTransforms for mapping a simple function that returns iterables over the elements of aPCollectionand merging the results. - FlatMapElements.FlatMapWithFailures<InputT,OutputT,FailureT> - Class in org.apache.beam.sdk.transforms
-
A
PTransformthat adds exception handling toFlatMapElements. - Flatten - Class in org.apache.beam.sdk.transforms
-
Flatten<T>takes multiplePCollection<T>s bundled into aPCollectionList<T>and returns a singlePCollection<T>containing all the elements in all the inputPCollections. - Flatten() - Constructor for class org.apache.beam.sdk.transforms.Flatten
- FLATTEN_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- Flatten.Iterables<T> - Class in org.apache.beam.sdk.transforms
-
FlattenIterables<T>takes aPCollection<Iterable<T>>and returns aPCollection<T>that contains all the elements from each iterable. - Flatten.PCollections<T> - Class in org.apache.beam.sdk.transforms
-
A
PTransformthat flattens aPCollectionListinto aPCollectioncontaining all the elements of all thePCollections in its input. - Flattened() - Constructor for class org.apache.beam.sdk.schemas.transforms.Select.Flattened
- flattenedSchema() - Static method in class org.apache.beam.sdk.schemas.transforms.Select
-
Selects every leaf-level field.
- FlattenTransformProvider - Class in org.apache.beam.sdk.schemas.transforms.providers
-
An implementation of
TypedSchemaTransformProviderfor Flatten. - FlattenTransformProvider() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.FlattenTransformProvider
- FlattenTransformProvider.Configuration - Class in org.apache.beam.sdk.schemas.transforms.providers
- FlattenTransformProvider.Configuration.Builder - Class in org.apache.beam.sdk.schemas.transforms.providers
- FlattenTranslator - Class in org.apache.beam.sdk.util.construction
-
Utility methods for translating a
Window.Assignto and fromRunnerApirepresentations. - FlattenTranslator.Registrar - Class in org.apache.beam.sdk.util.construction
-
Registers
FlattenTranslator. - flattenWithDuplicateInputs() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
A
PTransformMatcherwhich matches aFlatten.PCollectionswhich consumes a single inputPCollectionmultiple times. - FlattenWithHeterogeneousCoders - Interface in org.apache.beam.sdk.testing
-
Category tag for tests that use a
Flattenwhere the inputPCollectionListcontainsPCollectionsheterogeneouscoders. - FLOAT - org.apache.beam.sdk.schemas.Schema.TypeName
- FLOAT - org.apache.beam.sdk.transforms.display.DisplayData.Type
- FLOAT - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
-
The type of float fields.
- FloatCoder - Class in org.apache.beam.sdk.coders
-
A
FloatCoderencodesFloatvalues in 4 bytes using Java serialization. - floats() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorfor Float. - FluentBackoff - Class in org.apache.beam.sdk.util
-
A fluent builder for
BackOffobjects that allows customization of the retry algorithm. - flush() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataInboundObserver
- flush() - Method in interface org.apache.beam.sdk.fn.data.CloseableFnDataReceiver
-
Deprecated.to be removed once splitting/checkpointing are available in SDKs and rewinding in readers.
- flush() - Method in interface org.apache.beam.sdk.io.FileIO.Sink
-
Flushes the buffered state (if any) before the channel is closed.
- flush() - Method in class org.apache.beam.sdk.io.TextIO.Sink
- flush() - Method in class org.apache.beam.sdk.io.TFRecordIO.Sink
- flush() - Method in class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
- fn(Contextful.Fn<InputT, OutputT>, Requirements) - Static method in class org.apache.beam.sdk.transforms.Contextful
-
Same with
Contextful.of(ClosureT, org.apache.beam.sdk.transforms.Requirements)but with better type inference behavior for the case ofContextful.Fn. - fn(ProcessFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Contextful
- fn(SerializableFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Contextful
-
Binary compatibility adapter for
Contextful.fn(ProcessFunction). - fnClass() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Class of the original
DoFnfrom which this signature was produced. - FnDataReceiver<T> - Interface in org.apache.beam.sdk.fn.data
-
A receiver of streamed data.
- FnService - Interface in org.apache.beam.sdk.fn.server
-
An interface sharing common behavior with services used during execution of user Fns.
- forAppliedParDo(AppliedPTransform<PCollection<InputT>, PCollectionTuple, ?>) - Static method in class org.apache.beam.sdk.util.construction.SplittableParDo
-
Creates the transform for a
ParDo-compatibleAppliedPTransform. - forCoder(TypeDescriptor<?>, Coder<?>) - Static method in class org.apache.beam.sdk.coders.CoderProviders
-
Creates a
CoderProviderthat always returns the given coder for the specified type. - forComponents(RunnerApi.Components) - Static method in class org.apache.beam.sdk.util.construction.RehydratedComponents
-
Create a new
RehydratedComponentsfrom a Runner APIRunnerApi.Components. - forConsumers(List<DataEndpoint<?>>, List<TimerEndpoint<?>>) - Static method in class org.apache.beam.sdk.fn.data.BeamFnDataInboundObserver
-
Creates a receiver that is able to consume elements multiplexing on to the provided set of endpoints.
- forDescriptor(Endpoints.ApiServiceDescriptor) - Method in class org.apache.beam.sdk.fn.channel.ManagedChannelFactory
- forEncoding(ByteString) - Static method in class org.apache.beam.sdk.fn.windowing.EncodedBoundedWindow
- forever(Trigger) - Static method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
-
Create a composite trigger that repeatedly executes the trigger
repeated, firing each time it fires and ignoring any indications to finish. - forField(TypeDescriptor<?>, Field, int) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- forFn(DoFn<InputT, OutputT>, WindowingStrategy<?, ?>, Iterable<PCollectionView<?>>, Coder<InputT>, Map<TupleTag<?>, Coder<?>>, TupleTag<OutputT>, DoFnSchemaInformation, Map<String, PCollectionView<?>>) - Static method in class org.apache.beam.sdk.util.DoFnInfo
- forFn(DoFn<InputT, OutputT>, WindowingStrategy<?, ?>, Iterable<PCollectionView<?>>, Coder<InputT>, TupleTag<OutputT>, DoFnSchemaInformation, Map<String, PCollectionView<?>>) - Static method in class org.apache.beam.sdk.util.DoFnInfo
- forGetter(TypeDescriptor<?>, Method, int) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- forGetter(Method, int) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- forGrpcPortRead(QueryablePipeline, PipelineNode.PCollectionNode, Set<PipelineNode.PTransformNode>) - Static method in class org.apache.beam.sdk.util.construction.graph.GreedyStageFuser
-
Returns an
ExecutableStagewhere the initialPTransformis a Remote gRPC Port Read, reading elements from the materializedPCollection. - forKnownUrns(RunnerApi.Pipeline, Set<String>) - Static method in class org.apache.beam.sdk.util.construction.graph.TrivialNativeTransformExpander
-
Replaces transforms with the known URN with a native equivalent stripping the environment and removing any sub-transforms from the returned pipeline.
- formatAnnotation(Annotation) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
-
A
Functionthat returns a concise string for aAnnotation. - formatMethod(Method) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
-
Returns a string representation of the signature of a
Method. - formatMethodWithClass(Method) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
-
Returns a string representation of the class + method signature for a
Method. - formatRecord(UserT) - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
-
Convert an input record type into the output type.
- formatTimestamp(Instant) - Static method in class org.apache.beam.sdk.transforms.windowing.BoundedWindow
-
Formats a
Instanttimestamp with additional Beam-specific metadata, such as indicating whether the timestamp is the end of the global window or one of the distinguished valuesBoundedWindow.TIMESTAMP_MIN_VALUEorBoundedWindow.TIMESTAMP_MIN_VALUE. - forNewInput(Instant, InputT) - Method in interface org.apache.beam.sdk.transforms.Watch.Growth.TerminationCondition
-
Called by the
Watchtransform to create a new independent termination state for a newly arrivedInputT. - forOneOf(String, boolean, Map<String, FieldValueTypeInformation>) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- forPipeline(RunnerApi.Pipeline) - Static method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
-
Create a new
QueryablePipelinewhich uses the root transform IDs and components of the providedRunnerApi.Pipeline. - forPrimitivesIn(RunnerApi.Components) - Static method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
-
Create a new
QueryablePipelinebased on the provided components. - forSchema(Schema) - Static method in class org.apache.beam.sdk.util.RowJson.RowJsonDeserializer
- forSchema(Schema) - Static method in class org.apache.beam.sdk.util.RowJson.RowJsonSerializer
- forSetter(TypeDescriptor<?>, Method) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- forSetter(TypeDescriptor<?>, Method, String) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- forSetter(Method) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- forSetter(Method, String) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- forSpecification(String) - Static method in enum org.apache.beam.sdk.util.construction.Environments.JavaVersion
-
Return the LTS java version given the Java specification version.
- forSpecificationStrict(String) - Static method in enum org.apache.beam.sdk.util.construction.Environments.JavaVersion
- forThrowable(Throwable) - Static method in class org.apache.beam.sdk.values.EncodableThrowable
-
Wraps
throwableand returns the result. - forTransformHierarchy(TransformHierarchy, PipelineOptions) - Static method in class org.apache.beam.sdk.Pipeline
- forTransforms(Collection<String>, RunnerApi.Components) - Static method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
-
Create a new
QueryablePipelinebased on the provided components containing only the providedtransformIds. - forTypeName(Schema.TypeName) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
- forUrn(String) - Static method in class org.apache.beam.sdk.util.construction.PTransformTranslation.TransformPayloadTranslator.NotSerializable
- forValueWithCoder(T, Coder<T>) - Static method in class org.apache.beam.sdk.util.MutationDetectors
-
Creates a new
MutationDetectorfor the providedvaluethat uses the providedCoderto perform deep copies and comparisons by serializing and deserializing values. - ForwardingClientResponseObserver<ReqT,RespT> - Class in org.apache.beam.sdk.fn.stream
-
A
ClientResponseObserverwhich delegates allStreamObservercalls. - ForwardingPTransform<InputT extends PInput,OutputT extends POutput> - Class in org.apache.beam.sdk.util.construction
-
A base class for implementing
PTransformoverrides, which behave identically to the delegate transform but with overridden methods. - ForwardingPTransform() - Constructor for class org.apache.beam.sdk.util.construction.ForwardingPTransform
- from(double, double) - Static method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.Progress
-
A representation for the amount of known completed and remaining work.
- from(long) - Static method in class org.apache.beam.sdk.io.GenerateSequence
-
Specifies the minimum number to generate (inclusive).
- from(ConfigT) - Method in class org.apache.beam.sdk.schemas.transforms.TypedSchemaTransformProvider
-
Produce a SchemaTransform from ConfigT.
- from(String) - Method in class org.apache.beam.sdk.io.TextIO.Read
-
Reads text files that reads from the file(s) with the given filename or filename pattern.
- from(String) - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
-
Returns a transform for reading TFRecord files that reads from the file(s) with the given filename or filename pattern.
- from(String, Row, Schema) - Method in interface org.apache.beam.sdk.schemas.io.SchemaIOProvider
-
Produce a SchemaIO given a String representing the data's location, the schema of the data that resides there, and some IO-specific configuration object.
- from(ExecutorService) - Static method in class org.apache.beam.sdk.fn.test.TestExecutors
- from(Supplier<ExecutorService>) - Static method in class org.apache.beam.sdk.fn.test.TestExecutors
- from(Map<String, String>) - Static method in class org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides
-
Expects a map keyed by logger
Names with values representingLogLevels. - from(BoundedSource<T>) - Method in class org.apache.beam.sdk.io.Read.Builder
-
Returns a new
Read.BoundedPTransformreading from the givenBoundedSource. - from(BoundedSource<T>) - Static method in class org.apache.beam.sdk.io.Read
-
Returns a new
Read.BoundedPTransformreading from the givenBoundedSource. - from(FileBasedSource<T>) - Static method in class org.apache.beam.sdk.io.CompressedSource
-
Creates a
CompressedSourcefrom an underlyingFileBasedSource. - from(TFRecordReadSchemaTransformConfiguration) - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformProvider
-
Returns the expected
SchemaTransformof the configuration. - from(TFRecordWriteSchemaTransformConfiguration) - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformProvider
-
Returns the expected
SchemaTransformof the configuration. - from(UnboundedSource<T, ?>) - Method in class org.apache.beam.sdk.io.Read.Builder
-
Returns a new
Read.UnboundedPTransformreading from the givenUnboundedSource. - from(UnboundedSource<T, ?>) - Static method in class org.apache.beam.sdk.io.Read
- from(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.TextIO.Read
-
Same as
from(filepattern), but accepting aValueProvider. - from(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
-
Same as
from(filepattern), but accepting aValueProvider. - from(GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration) - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider
- from(FlattenTransformProvider.Configuration) - Method in class org.apache.beam.sdk.schemas.transforms.providers.FlattenTransformProvider
- from(JavaExplodeTransformProvider.Configuration) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider
- from(JavaFilterTransformProvider.Configuration) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider
- from(JavaMapToFieldsTransformProvider.Configuration) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider
- from(LoggingTransformProvider.Configuration) - Method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider
- from(HasDisplayData) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Collect the
DisplayDatafrom a component. - from(Row) - Method in interface org.apache.beam.sdk.schemas.transforms.SchemaTransformProvider
-
Produce a
SchemaTransformfrom some transform-specific configuration object. - from(Row) - Method in class org.apache.beam.sdk.schemas.transforms.TypedSchemaTransformProvider
-
Produces a
SchemaTransformfrom a Row configuration. - fromArgs(String...) - Method in class org.apache.beam.sdk.options.PipelineOptionsFactory.Builder
-
Sets the command line arguments to parse when constructing the
PipelineOptions. - fromArgs(String...) - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
-
Sets the command line arguments to parse when constructing the
PipelineOptions. - fromArray(T...) - Static method in class org.apache.beam.sdk.fn.stream.PrefetchableIterables
-
Returns a
PrefetchableIterableover the specified values. - fromArray(T...) - Static method in class org.apache.beam.sdk.fn.stream.PrefetchableIterators
-
Returns a
PrefetchableIteratorover the specified values. - fromByteArray(byte[]) - Static method in class org.apache.beam.sdk.util.construction.TransformUpgrader
-
A utility method that converts a byte array obtained by invoking
TransformUpgrader.toByteArray(Object)back to a Java object. - fromCanonical(Compression) - Static method in enum org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.
- fromClass(Class<?>) - Method in class org.apache.beam.sdk.util.InstanceBuilder
-
Sets the factory class to use for instance construction.
- fromClassName(String) - Method in class org.apache.beam.sdk.util.InstanceBuilder
-
Sets the class name to be constructed.
- fromComponents(List<Coder<?>>, byte[]) - Static method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
- fromComponents(List<Coder<?>>, byte[], CoderTranslation.TranslationContext) - Method in interface org.apache.beam.sdk.util.construction.CoderTranslator
- fromConfigRow(Row, PipelineOptions) - Method in class org.apache.beam.sdk.schemas.transforms.SchemaTransformTranslation.SchemaTransformPayloadTranslator
- fromConfigRow(Row, PipelineOptions) - Method in interface org.apache.beam.sdk.util.construction.PTransformTranslation.TransformPayloadTranslator
-
Construts a transform from a provided Row-based construction configuration.
- fromExceptionInformation(RecordT, Coder<RecordT>, Exception, String) - Static method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord
- fromFactoryMethod(String) - Method in class org.apache.beam.sdk.util.InstanceBuilder
-
Sets the name of the factory method used to construct the instance.
- fromFile(File, boolean) - Static method in class org.apache.beam.sdk.io.LocalResources
- fromJson(String) - Static method in class org.apache.beam.sdk.util.construction.PipelineOptionsTranslation
-
Converts the provided Json
StringintoPipelineOptions. - fromOptions(PipelineOptions) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderFileSystemRegistrar
- fromOptions(PipelineOptions) - Method in class org.apache.beam.sdk.io.LocalFileSystemRegistrar
- fromOptions(PipelineOptions) - Method in interface org.apache.beam.sdk.io.FileSystemRegistrar
-
Create zero or more
filesystemsfrom the givenPipelineOptions. - fromOptions(PipelineOptions) - Static method in class org.apache.beam.sdk.PipelineRunner
-
Constructs a runner from the provided
PipelineOptions. - fromOptions(PipelineOptions) - Static method in class org.apache.beam.sdk.testing.CrashingRunner
- fromOptions(PipelineOptions) - Static method in class org.apache.beam.sdk.testing.TestPipeline
- fromOptions(PipelineOptions) - Static method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHints
-
Creates a
ResourceHintsinstance with hints supplied in options. - fromParams(DefaultFilenamePolicy.Params) - Static method in class org.apache.beam.sdk.io.DefaultFilenamePolicy
-
Construct a
DefaultFilenamePolicyfrom aDefaultFilenamePolicy.Paramsobject. - fromPath(Path, boolean) - Static method in class org.apache.beam.sdk.io.LocalResources
- fromPayload(RunnerApi.ExecutableStagePayload) - Static method in interface org.apache.beam.sdk.util.construction.graph.ExecutableStage
-
Return an
ExecutableStageconstructed from the providedRunnerApi.FunctionSpecrepresentation. - fromProcessFunctionWithOutputType(ProcessFunction<InputT, OutputT>, TypeDescriptor<OutputT>) - Static method in class org.apache.beam.sdk.transforms.InferableFunction
- fromProto(RunnerApi.AccumulationMode.Enum) - Static method in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- fromProto(RunnerApi.ClosingBehavior.Enum) - Static method in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- fromProto(RunnerApi.Coder, RehydratedComponents, CoderTranslation.TranslationContext) - Static method in class org.apache.beam.sdk.util.construction.CoderTranslation
- fromProto(RunnerApi.MessageWithComponents) - Static method in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
-
Converts from a
RunnerApi.WindowingStrategyaccompanied byRunnerApi.Componentsto the SDK'sWindowingStrategy. - fromProto(RunnerApi.OnTimeBehavior.Enum) - Static method in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- fromProto(RunnerApi.PCollection, Pipeline, RehydratedComponents) - Static method in class org.apache.beam.sdk.util.construction.PCollectionTranslation
- fromProto(RunnerApi.Trigger) - Static method in class org.apache.beam.sdk.util.construction.TriggerTranslation
- fromProto(RunnerApi.WindowingStrategy, RehydratedComponents) - Static method in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
-
Converts from
RunnerApi.WindowingStrategyto the SDK'sWindowingStrategyusing the provided components to dereferences identifiers found in the proto. - fromProto(Struct) - Static method in class org.apache.beam.sdk.util.construction.PipelineOptionsTranslation
-
Converts the provided
StructintoPipelineOptions. - fromPTransform(RunnerApi.PTransform) - Static method in class org.apache.beam.sdk.fn.data.RemoteGrpcPortRead
- fromPTransform(RunnerApi.PTransform) - Static method in class org.apache.beam.sdk.fn.data.RemoteGrpcPortWrite
- fromRawEvents(Coder<T>, List<TestStream.Event<T>>) - Static method in class org.apache.beam.sdk.testing.TestStream
-
For internal use only.
- fromRow(Row) - Static method in class org.apache.beam.sdk.values.Row
-
Creates a row builder based on the specified row.
- fromRowFunction(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProvider
-
Given a type, returns a function that converts from a
Rowobject to that type. - fromRowFunction(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
-
Deprecated.
- fromRowFunction(TypeDescriptor<T>) - Method in interface org.apache.beam.sdk.schemas.SchemaProvider
-
Given a type, returns a function that converts from a
Rowobject to that type. - fromRows(Class<OutputT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Convert
-
Convert a
PCollection<Row> into aPCollection<OutputT>. - fromRows(TypeDescriptor<OutputT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Convert
-
Convert a
PCollection<Row> into aPCollection<OutputT>. - fromSerializableFunctionWithOutputType(SerializableFunction<InputT, OutputT>, TypeDescriptor<OutputT>) - Static method in class org.apache.beam.sdk.transforms.SimpleFunction
- fromSideInputId(RunnerApi.ExecutableStagePayload.SideInputId, RunnerApi.Components) - Static method in class org.apache.beam.sdk.util.construction.graph.SideInputReference
-
Create a side input reference from a SideInputId proto and components.
- fromStandardParameters(ValueProvider<ResourceId>, String, String, boolean) - Static method in class org.apache.beam.sdk.io.DefaultFilenamePolicy
-
Construct a
DefaultFilenamePolicy. - fromStaticMethods(Class<?>, Class<?>) - Static method in class org.apache.beam.sdk.coders.CoderProviders
-
Creates a
CoderProviderfrom a class'sstatic <T> Coder<T> of(TypeDescriptor<T>, List<Coder<?>>) method. - fromString(String, boolean) - Static method in class org.apache.beam.sdk.io.LocalResources
- fromString(ValueProvider<String>, boolean) - Static method in class org.apache.beam.sdk.io.LocalResources
- fromSupplier(SerializableSupplier<Matcher<T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
Constructs a
SerializableMatcherfrom a non-serializableMatchervia indirection throughSerializableSupplier. - fromTimerId(RunnerApi.ExecutableStagePayload.TimerId, RunnerApi.Components) - Static method in class org.apache.beam.sdk.util.construction.graph.TimerReference
-
Create a timer reference from a TimerId proto and components.
- fromUserStateId(RunnerApi.ExecutableStagePayload.UserStateId, RunnerApi.Components) - Static method in class org.apache.beam.sdk.util.construction.graph.UserStateReference
-
Create a user state reference from a UserStateId proto and components.
- fullOuterJoin(PCollection<RhsT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Join
-
Perform a full outer join.
- fullyExpand(Map<TupleTag<?>, PValue>) - Static method in class org.apache.beam.sdk.values.PValues
-
Returns all the tagged
PCollectionsrepresented in the givenPValue. - FUNCTION - org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields.Fanout.Kind
- fuse(RunnerApi.Pipeline) - Static method in class org.apache.beam.sdk.util.construction.graph.GreedyPipelineFuser
-
Fuses a
RunnerApi.Pipelineinto a collection ofExecutableStages. - FusedPipeline - Class in org.apache.beam.sdk.util.construction.graph
-
A
RunnerApi.Pipelinewhich has been separated into collections of executable components. - FusedPipeline() - Constructor for class org.apache.beam.sdk.util.construction.graph.FusedPipeline
G
- gauge(Class<?>, String) - Static method in class org.apache.beam.sdk.metrics.Metrics
-
Create a metric that can have its new value set, and is aggregated by taking the last reported value.
- gauge(String, String) - Static method in class org.apache.beam.sdk.metrics.Metrics
-
Create a metric that can have its new value set, and is aggregated by taking the last reported value.
- gauge(MetricName) - Static method in class org.apache.beam.sdk.metrics.Metrics
-
Create a metric that can have its new value set, and is aggregated by taking the last reported value.
- Gauge - Interface in org.apache.beam.sdk.metrics
-
A metric that reports the latest value out of reported values.
- GaugeResult - Class in org.apache.beam.sdk.metrics
-
The result of a
Gaugemetric. - GaugeResult() - Constructor for class org.apache.beam.sdk.metrics.GaugeResult
- GaugeResult.EmptyGaugeResult - Class in org.apache.beam.sdk.metrics
-
Empty
GaugeResult, representing no values reported. - GcpSecret - Class in org.apache.beam.sdk.util
-
A
Secretmanager implementation that retrieves secrets from Google Cloud Secret Manager. - GcpSecret(String) - Constructor for class org.apache.beam.sdk.util.GcpSecret
-
Initializes a
GcpSecretobject. - generate(Schema) - Static method in class org.apache.beam.sdk.coders.RowCoderGenerator
- generateNameFromStagePayload(RunnerApi.ExecutableStagePayload) - Static method in class org.apache.beam.sdk.util.construction.ExecutableStageTranslation
- generateNameFromTransformNames(Collection<String>, boolean) - Static method in class org.apache.beam.sdk.util.construction.ExecutableStageTranslation
-
Creates a human-readable name for a set of stage names that occur in a single stage.
- GenerateSequence - Class in org.apache.beam.sdk.io
-
A
PTransformthat produces longs starting from the given value, and either up to the given limit or untilLong.MAX_VALUE/ until the given time elapses. - GenerateSequence() - Constructor for class org.apache.beam.sdk.io.GenerateSequence
- GenerateSequence.External - Class in org.apache.beam.sdk.io
-
Exposes GenerateSequence as an external transform for cross-language usage.
- GenerateSequence.External.ExternalConfiguration - Class in org.apache.beam.sdk.io
-
Parameters class to expose the transform to an external SDK.
- GenerateSequenceConfiguration() - Constructor for class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration
- GenerateSequenceSchemaTransformProvider - Class in org.apache.beam.sdk.providers
- GenerateSequenceSchemaTransformProvider() - Constructor for class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider
- GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration - Class in org.apache.beam.sdk.providers
- GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Builder - Class in org.apache.beam.sdk.providers
- GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate - Class in org.apache.beam.sdk.providers
- GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate.Builder - Class in org.apache.beam.sdk.providers
- GenerateSequenceSchemaTransformProvider.GenerateSequenceSchemaTransform - Class in org.apache.beam.sdk.providers
- GenericDlq - Class in org.apache.beam.sdk.schemas.io
-
Helper to generate a DLQ transform to write PCollection
to an external system. - GenericDlqProvider - Interface in org.apache.beam.sdk.schemas.io
-
A Provider for generic DLQ transforms that handle deserialization failures.
- get() - Method in interface org.apache.beam.sdk.options.ValueProvider
-
Returns the runtime value wrapped by this
ValueProviderin case it isValueProvider.isAccessible(), otherwise fails. - get() - Method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
- get() - Method in class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
- get() - Method in class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
- get() - Method in interface org.apache.beam.sdk.transforms.Materializations.IterableView
-
Returns an iterable for all values.
- get() - Method in interface org.apache.beam.sdk.transforms.Materializations.MultimapView
-
Returns an iterable of all keys.
- get() - Method in class org.apache.beam.sdk.util.BucketingFunction
-
Return the (bucketized) combined value of all samples.
- get() - Method in class org.apache.beam.sdk.util.Holder
- get() - Method in class org.apache.beam.sdk.util.MemoizingPerInstantiationSerializableSupplier
- get() - Static method in class org.apache.beam.sdk.util.NoopLock
- get() - Method in interface org.apache.beam.sdk.util.ThrowingSupplier
- get() - Method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadata
- get(int) - Method in class org.apache.beam.sdk.values.PCollectionList
-
Returns the
PCollectionat the given index (origin zero). - get(int) - Method in class org.apache.beam.sdk.values.TupleTagList
-
Returns the
TupleTagat the given index (origin zero). - get(long) - Method in class org.apache.beam.sdk.util.MovingFunction
-
Return the minimum/maximum/sum of all retained values within samplePeriodMs of
nowMsSinceEpoch. - get(K) - Method in interface org.apache.beam.sdk.transforms.Materializations.MultimapView
-
Returns an iterable of all the values for the specified key.
- get(Object) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- get(String) - Method in interface org.apache.beam.sdk.state.TimerMap
- get(String) - Method in class org.apache.beam.sdk.values.PCollectionRowTuple
- get(String) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
Returns the
PCollectionassociated with the given tag in thisPCollectionTuple. - get(CompletionStage<T>) - Static method in class org.apache.beam.sdk.util.MoreFutures
-
Gets the result of the given future.
- get(CompletionStage<T>, long, TimeUnit) - Static method in class org.apache.beam.sdk.util.MoreFutures
-
Gets the result of the given future.
- get(K) - Method in interface org.apache.beam.sdk.state.MapState
-
A deferred lookup, using null values if the item is not found.
- get(K) - Method in interface org.apache.beam.sdk.state.MultimapState
-
A deferred lookup, returns an empty iterable if the item is not found.
- get(ObjectT) - Method in interface org.apache.beam.sdk.schemas.FieldValueGetter
- get(TupleTag<T>) - Method in interface org.apache.beam.sdk.transforms.DoFn.MultiOutputReceiver
-
Returns an
DoFn.OutputReceiverfor the given tag. - get(TupleTag<T>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
- get(TupleTag<V>) - Method in class org.apache.beam.sdk.transforms.CombineFns.CoCombineResult
-
Returns the value represented by the given
TupleTag. - get(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.AutoValueSchema.AbstractGetterTypeSupplier
- get(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema.GetterTypeSupplier
- get(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema.SetterTypeSupplier
- get(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.JavaFieldSchema.JavaFieldTypeSupplier
- get(TypeDescriptor<?>) - Method in interface org.apache.beam.sdk.schemas.utils.FieldValueTypeSupplier
-
Return all the FieldValueTypeInformations.
- get(TypeDescriptor<?>, Schema) - Method in interface org.apache.beam.sdk.schemas.utils.FieldValueTypeSupplier
-
Return all the FieldValueTypeInformations.
- getAccum() - Method in interface org.apache.beam.sdk.state.CombiningState
-
Read the merged accumulator for this state cell.
- getAccumulatedBucketSize(int) - Method in interface org.apache.beam.sdk.util.HistogramData.BucketType
- getAccumulatedBucketSize(int) - Method in class org.apache.beam.sdk.util.HistogramData.ExponentialBuckets
- getAccumulatedBucketSize(int) - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
- getAccumulatedBucketSize(int) - Method in class org.apache.beam.sdk.util.HistogramData.UnsupportedBuckets
- getAccumulatorCoder() - Method in class org.apache.beam.sdk.util.AppliedCombineFn
- getAccumulatorCoder(CoderRegistry, Coder<DataT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
- getAccumulatorCoder(CoderRegistry, Coder<DataT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
- getAccumulatorCoder(CoderRegistry, Coder<InputT>) - Method in interface org.apache.beam.sdk.transforms.CombineFnBase.GlobalCombineFn
-
Returns the
Coderto use for accumulatorAccumTvalues, or null if it is not able to be inferred. - getAccumulatorCoder(CoderRegistry, Coder<Double>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
- getAccumulatorCoder(CoderRegistry, Coder<Integer>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
- getAccumulatorCoder(CoderRegistry, Coder<Long>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
- getAccumulatorCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
- getAccumulatorCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
-
Deprecated.
- getAccumulatorCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
- getAccumulatorCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.Top.TopCombineFn
- getAccumulatorCoder(CoderRegistry, Coder<V>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
- getAdditionalInputs() - Method in class org.apache.beam.sdk.io.WriteFiles
- getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
Returns the side inputs of this
Combine, tagged with the tag of thePCollectionView. - getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
-
Returns the side inputs of this
Combine, tagged with the tag of thePCollectionView. - getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
-
Returns the side inputs of this
ParDo, tagged with the tag of thePCollectionView. - getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
-
Returns the side inputs of this
ParDo, tagged with the tag of thePCollectionView. - getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.PTransform
-
Returns all
PValuesthat are consumed as inputs to thisPTransformthat are independent of the expansion of thePTransformwithinPTransform.expand(PInput). - getAdditionalInputs() - Method in class org.apache.beam.sdk.util.construction.ForwardingPTransform
- getAdditionalInputs() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo
- getAdditionalInputs() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElements
- getAdditionalOutputTags() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
- getAdditionalOutputTags() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElements
- getAdditionalOutputTags(AppliedPTransform<?, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- getAll() - Method in class org.apache.beam.sdk.values.PCollectionList
-
Returns an immutable List of all the
PCollectionsin thisPCollectionList. - getAll() - Method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
Returns an immutable Map from tag to corresponding
PCollection, for all the members of thisPCollectionRowTuple. - getAll() - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
Returns an immutable Map from
TupleTagto correspondingPCollection, for all the members of thisPCollectionTuple. - getAll() - Method in class org.apache.beam.sdk.values.TupleTagList
-
Returns an immutable List of all the
TupleTagsin thisTupleTagList. - getAll(String) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
Like
CoGbkResult.getAll(TupleTag)but using a String instead of aTupleTag. - getAll(TupleTag<V>) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
Returns the values from the table represented by the given
TupleTag<V>as anIterable<V>(which may be empty if there are no results). - getAllFields() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
If true, all fields are being accessed.
- getAllMetadata() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Deprecated.use schema options instead.
- getAllowDuplicates() - Method in class org.apache.beam.sdk.transforms.Redistribute.RedistributeArbitrarily
- getAllowDuplicates() - Method in class org.apache.beam.sdk.transforms.Redistribute.RedistributeByKey
- getAllowedLateness() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- getAllowedTimestampSkew() - Method in class org.apache.beam.sdk.transforms.DoFn
-
Deprecated.This method permits a
DoFnto emit elements behind the watermark. These elements are considered late, and if behind theallowed latenessof a downstreamPCollectionmay be silently dropped. See https://github.com/apache/beam/issues/18065 for details on a replacement. - getAllowedTimestampSkew() - Method in class org.apache.beam.sdk.transforms.WithTimestamps
-
Deprecated.This method permits a to elements to be emitted behind the watermark. These elements are considered late, and if behind the
allowed latenessof a downstreamPCollectionmay be silently dropped. See https://github.com/apache/beam/issues/18065 for details on a replacement. - getAndReset() - Method in class org.apache.beam.sdk.util.HistogramData
-
Copies all updates to a new histogram object and resets 'this' histogram.
- getAnnotatedConstructor(Class<?>) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
- getAnnotatedCreateMethod(Class<?>) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
- getAnnotations() - Method in class org.apache.beam.sdk.transforms.PTransform
-
Returns annotations map to provide additional hints to the runner.
- getAnyExposurePath(Class<?>) - Method in class org.apache.beam.sdk.util.ApiSurface
-
Returns a path from an exposed class to a root class.
- getApiServiceDescriptor() - Method in class org.apache.beam.sdk.fn.server.GrpcFnServer
-
Get an
Endpoints.ApiServiceDescriptordescribing the endpoint thisGrpcFnServeris bound to. - getAppend() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration
- getAppliedFn(CoderRegistry, Coder<? extends KV<K, ? extends Iterable<InputT>>>, WindowingStrategy<?, ?>) - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
-
Returns the
Combine.CombineFnbound to its coders. - getAppName() - Method in interface org.apache.beam.sdk.options.ApplicationNameOptions
-
Name of application, for display purposes.
- getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Date
- getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
- getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
- getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
- getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
- getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Time
- getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.UuidLogicalType
- getArgument() - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
-
An optional argument to configure the type.
- getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Date
- getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
- getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
- getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
- getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
- getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
- getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PythonCallable
- getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.SchemaLogicalType
- getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Time
- getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.UuidLogicalType
- getArgumentType() - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
-
A schema type representing how to interpret the argument.
- getArgumentTypes(Method) - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns a list of argument types for the given method, which must be a part of the class.
- getArray(int) - Method in class org.apache.beam.sdk.values.Row
-
Get an array value by field index,
IllegalStateExceptionis thrown if schema doesn't match. - getArray(String) - Method in class org.apache.beam.sdk.values.Row
-
Get an array value by field name,
IllegalStateExceptionis thrown if schema doesn't match. - getArtifacts(List<String>) - Static method in class org.apache.beam.sdk.util.construction.Environments
- getATN() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- getATN() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- getAttempted() - Method in class org.apache.beam.sdk.metrics.MetricResult
-
Return the value of this metric across all attempts of executing all parts of the pipeline.
- getAutoValueGenerated(TypeDescriptor<?>) - Static method in class org.apache.beam.sdk.schemas.utils.AutoValueUtils
- getAutoValueGeneratedBuilder(TypeDescriptor<?>) - Static method in class org.apache.beam.sdk.schemas.utils.AutoValueUtils
- getBacking() - Method in class org.apache.beam.sdk.fn.data.WeightedList
- getBadRecordErrorHandler() - Method in class org.apache.beam.sdk.io.WriteFiles
- getBadRecordRouter() - Method in class org.apache.beam.sdk.io.WriteFiles
- getBase() - Method in class org.apache.beam.sdk.util.HistogramData.ExponentialBuckets
- getBaseAutoValueClass(TypeDescriptor<?>) - Static method in class org.apache.beam.sdk.schemas.utils.AutoValueUtils
- getBaseName() - Method in class org.apache.beam.sdk.metrics.LabeledMetricNameUtils.ParsedMetricName
- getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Date
- getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
- getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
- getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
- getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
- getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
- getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PythonCallable
- getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.SchemaLogicalType
- getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Time
- getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.UuidLogicalType
- getBaseType() - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
-
The base
Schema.FieldTypeused to store values of this type. - getBaseValue(int) - Method in class org.apache.beam.sdk.values.Row
-
Returns the base type for this field.
- getBaseValue(int, Class<T>) - Method in class org.apache.beam.sdk.values.Row
-
Returns the base type for this field.
- getBaseValue(String) - Method in class org.apache.beam.sdk.values.Row
-
Returns the base type for this field.
- getBaseValue(String, Class<T>) - Method in class org.apache.beam.sdk.values.Row
-
Returns the base type for this field.
- getBaseValues() - Method in class org.apache.beam.sdk.values.Row
-
Return a list of data values.
- getBatchingParams() - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches
-
Returns user supplied parameters for batching.
- getBatchingParams() - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches.WithShardedKey
-
Returns user supplied parameters for batching.
- getBatchSize() - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches.BatchingParams
- getBatchSizeBytes() - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches.BatchingParams
- getBoolean(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Booleanvalue by field index,ClassCastExceptionis thrown if schema doesn't match. - getBoolean(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.BOOLEANvalue by field name,IllegalStateExceptionis thrown if schema doesn't match. - getBottomBucketCount() - Method in class org.apache.beam.sdk.util.HistogramData
- getBottomBucketMean() - Method in class org.apache.beam.sdk.util.HistogramData
- getBoundedTrie(MetricName) - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
-
Return the
BoundedTriethat should be used for implementing the givenmetricNamein this container. - getBoundedTries() - Method in class org.apache.beam.sdk.metrics.MetricQueryResults
-
Return the metric results for the bounded tries that matched the filter.
- getBucketCount() - Method in class org.apache.beam.sdk.util.HistogramData
- getBucketIndex(double) - Method in interface org.apache.beam.sdk.util.HistogramData.BucketType
- getBucketIndex(double) - Method in class org.apache.beam.sdk.util.HistogramData.ExponentialBuckets
- getBucketIndex(double) - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
- getBucketIndex(double) - Method in class org.apache.beam.sdk.util.HistogramData.UnsupportedBuckets
- getBucketSize(int) - Method in interface org.apache.beam.sdk.util.HistogramData.BucketType
- getBucketSize(int) - Method in class org.apache.beam.sdk.util.HistogramData.ExponentialBuckets
- getBucketSize(int) - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
- getBucketSize(int) - Method in class org.apache.beam.sdk.util.HistogramData.UnsupportedBuckets
- getBucketType() - Method in class org.apache.beam.sdk.util.HistogramData
- getBufferSize() - Method in class org.apache.beam.sdk.fn.stream.BufferingStreamObserver
- getBuilderCreator(TypeDescriptor<?>, Schema, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.AutoValueUtils
-
Try to find an accessible builder class for creating an AutoValue class.
- getBundleProcessorCacheTimeout() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
- getByte(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.BYTEvalue by field index,ClassCastExceptionis thrown if schema doesn't match. - getByte(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.BYTEvalue by field name,IllegalStateExceptionis thrown if schema doesn't match. - getBytes() - Method in class org.apache.beam.sdk.io.range.ByteKey
-
Returns a newly-allocated
byte[]representing thisByteKey. - getBytes(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.BYTESvalue by field index,ClassCastExceptionis thrown if schema doesn't match. - getBytes(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.BYTESvalue by field name,IllegalStateExceptionis thrown if schema doesn't match. - getBytesPerOffset() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
-
Returns approximately how many bytes of data correspond to a single offset in this source.
- getBytesToRowFn(Schema) - Static method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformProvider
- getBytesWithoutClosing(InputStream) - Static method in class org.apache.beam.sdk.util.StreamUtils
-
Efficient converting stream to bytes.
- getCallable() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration
- getCaseEnumType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
Returns the
EnumerationTypethat is used to represent the case type. - getCaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
-
Returns the enumeration that specified which OneOf field is set.
- getChannel(int) - Method in class org.apache.beam.sdk.util.ShardingWritableByteChannel
-
Returns the WritableByteChannel associated with the given shard number.
- getChannelFactory() - Method in class org.apache.beam.sdk.io.CompressedSource
- getChannelNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- getCheckpointMark() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
-
Returns a
UnboundedSource.CheckpointMarkrepresenting the progress of thisUnboundedReader. - getCheckpointMarkCoder() - Method in class org.apache.beam.sdk.io.UnboundedSource
-
Returns a
Coderfor encoding and decoding the checkpoints for this source. - getCheckpointMarkCoder() - Method in class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter
- getClass(String, String) - Static method in class org.apache.beam.sdk.schemas.transforms.providers.StringCompiler
- getClasses() - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns a set of
TypeDescriptors, one for each superclass (including this class). - getClassLoadingStrategy(Class<?>) - Static method in class org.apache.beam.sdk.util.ByteBuddyUtils
-
Returns a class loading strategy that is compatible with Java 17+.
- getClazz() - Method in class org.apache.beam.sdk.schemas.utils.ReflectUtils.ClassWithSchema
- getClearBit() - Method in class org.apache.beam.sdk.util.construction.Timer
-
Returns whether the timer is going to be cleared.
- getCloningBehavior() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - getClosingBehavior() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- getClosure() - Method in class org.apache.beam.sdk.transforms.Contextful
-
Returns the closure.
- getClosureOfMethodsOnInterface(Class<?>) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
-
Returns all the methods visible from
iface. - getClosureOfMethodsOnInterfaces(Iterable<? extends Class<?>>) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
-
Returns all the methods visible from the provided interfaces.
- getCodedType(TypeDescriptor) - Static method in class org.apache.beam.sdk.util.CoderUtils
-
If
coderTypeis a subclass ofCoder<T>for a specific typeT, returnsT.class. - getCoder() - Method in class org.apache.beam.sdk.coders.DelegateCoder
-
Returns the coder used to encode/decode the intermediate values produced/consumed by the coding functions of this
DelegateCoder. - getCoder() - Method in class org.apache.beam.sdk.fn.data.DataEndpoint
- getCoder() - Method in class org.apache.beam.sdk.fn.data.TimerEndpoint
- getCoder() - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record
-
The coder for the record, or null if there is no coder.
- getCoder() - Static method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
-
Returns a
Codersuitable forIntervalWindow. - getCoder() - Method in class org.apache.beam.sdk.values.PCollection
-
Returns the
Coderused by thisPCollectionto encode and decode the values stored in it. - getCoder(Class<? extends T>, Class<T>, Map<Type, ? extends Coder<?>>, TypeVariable<?>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
-
Deprecated.This method is to change in an unknown backwards incompatible way once support for this functionality is refined.
- getCoder(Class<T>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
-
Returns the
Coderto use for values of the given class. - getCoder(String) - Method in class org.apache.beam.sdk.util.construction.RehydratedComponents
-
Returns a
Coderrehydrated from the Runner API component with the given ID. - getCoder(Pipeline) - Static method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord
- getCoder(TypeDescriptor<OutputT>, TypeDescriptor<InputT>, Coder<InputT>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
-
Deprecated.This method is to change in an unknown backwards incompatible way once support for this functionality is refined.
- getCoder(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
-
Returns the
Coderto use for values of the given type. - getCoderArguments() - Method in class org.apache.beam.sdk.coders.AtomicCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.Coder
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.CustomCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.KvCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.MapCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.NullableCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.OptionalCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.ShardedKeyCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.SnappyCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.SortedMapCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.TimestampPrefixingWindowCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.VarLongCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.ZstdCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResultCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.io.ReadableFileCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.testing.TestStream.TestStreamCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindow.Coder
- getCoderArguments() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.util.construction.Timer.Coder
- getCoderArguments() - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
- getCoderArguments() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow.Coder
- getCoderArguments() - Method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadataCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
- getCoderArguments() - Method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.values.WindowedValues.FullWindowedValueCoder
- getCoderArguments() - Method in class org.apache.beam.sdk.values.WindowedValues.ValueOnlyWindowedValueCoder
-
Deprecated.
- getCoderInternal() - Method in class org.apache.beam.sdk.util.construction.RunnerPCollectionView
- getCoderInternal() - Method in interface org.apache.beam.sdk.values.PCollectionView
-
Deprecated.this method will be removed entirely. The
PCollectionunderlying a side input, including itsCoder, is part of the side input's specification with aParDotransform, which will obtain that information via a package-private channel. - getCoderInternal() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
- getCoderProvider() - Static method in class org.apache.beam.sdk.coders.SerializableCoder
-
Returns a
CoderProviderwhich uses theSerializableCoderif possible for all types. - getCoderProviders() - Method in interface org.apache.beam.sdk.coders.CoderProviderRegistrar
-
Returns a list of
coder providerswhich will be registered by default within eachcoder registryinstance. - getCoderProviders() - Method in class org.apache.beam.sdk.coders.DefaultCoder.DefaultCoderProviderRegistrar
- getCoderProviders() - Method in class org.apache.beam.sdk.coders.SerializableCoder.SerializableCoderProviderRegistrar
- getCoderRegistry() - Method in class org.apache.beam.sdk.Pipeline
-
Returns the
CoderRegistrythat thisPipelineuses. - getCoderTranslators() - Method in interface org.apache.beam.sdk.util.construction.CoderTranslatorRegistrar
-
Returns a mapping of URN to
CoderTranslator. - getCoderTranslators() - Method in class org.apache.beam.sdk.util.construction.ModelCoderRegistrar
- getCoderURNs() - Method in interface org.apache.beam.sdk.util.construction.CoderTranslatorRegistrar
-
Returns a mapping of coder classes to the URN representing that coder.
- getCoderURNs() - Method in class org.apache.beam.sdk.util.construction.ModelCoderRegistrar
- getCoGbkResultSchema() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
Returns the
CoGbkResultSchemaassociated with thisKeyedPCollectionTuple. - getCollection() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple.TaggedKeyedPCollection
-
Returns the underlying PCollection of this TaggedKeyedPCollection.
- getCollectionElementType() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
- getCombineFn() - Method in class org.apache.beam.sdk.transforms.Combine.GloballyAsSingletonView
- getCommitted() - Method in class org.apache.beam.sdk.metrics.MetricResult
-
Return the value of this metric across all successfully completed parts of the pipeline.
- getCommittedOrNull() - Method in class org.apache.beam.sdk.metrics.MetricResult
-
Return the value of this metric across all attempts of executing all parts of the pipeline.
- getComponents() - Method in class org.apache.beam.sdk.coders.AtomicCoder
- getComponents() - Method in class org.apache.beam.sdk.coders.StructuredCoder
- getComponents() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResultCoder
- getComponents() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
-
Hierarchy list of component paths making up the full path, starting with the top-level child component path.
- getComponents() - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
- getComponents() - Method in interface org.apache.beam.sdk.util.construction.graph.ExecutableStage
-
Return the
RunnerApi.Componentsrequired to execute thisExecutableStage. - getComponents() - Method in class org.apache.beam.sdk.util.construction.graph.ImmutableExecutableStage
- getComponents() - Method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
- getComponents() - Method in class org.apache.beam.sdk.util.construction.RehydratedComponents
- getComponents() - Method in class org.apache.beam.sdk.util.construction.Timer.Coder
- getComponents() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow.Coder
- getComponents() - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
- getComponents() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
- getComponents() - Method in class org.apache.beam.sdk.values.WindowedValues.FullWindowedValueCoder
- getComponents(T) - Method in interface org.apache.beam.sdk.util.construction.CoderTranslator
-
Extract all component
coderswithin a coder. - getComponentType() - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns the component type if this type is an array type, otherwise returns
null. - getCompression() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
-
Returns the method with which this file will be decompressed in
FileIO.ReadableFile.open(). - getCompression() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
- getCompression() - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformConfiguration
- getCompression() - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration
- getComputeNumShards() - Method in class org.apache.beam.sdk.io.WriteFiles
- getConfiguredLoggerFromOptions(SdkHarnessOptions) - Static method in interface org.apache.beam.sdk.options.SdkHarnessOptions
-
Configure log manager's default log level and log level overrides from the sdk harness options, and return the list of configured loggers.
- getConstant(ProtocolMessageEnum) - Static method in class org.apache.beam.sdk.util.construction.BeamUrns
-
Returns the constant value of a given enum annotated with [(beam_constant)].
- getConstructorCreator(TypeDescriptor<?>, Constructor, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
- getConstructorCreator(TypeDescriptor<?>, Schema, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.AutoValueUtils
-
Try to find an accessible constructor for creating an AutoValue class.
- getConstructorCreator(TypeDescriptor<T>, Constructor<T>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
- getContinuationTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
- getContinuationTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
-
Return a trigger to use after a
GroupByKeyto preserve the intention of this trigger. - getContinuationTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger.OnceTrigger
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterAll
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterEach
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterFirst
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.Never.NeverTrigger
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.ReshuffleTrigger
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
-
Subclasses should override this to return the
Trigger.getContinuationTrigger()of thisTrigger. - getConvertedSchemaInformation(Schema, TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.utils.RowSchemaInformationProvider
- getConvertedSchemaInformation(Schema, TypeDescriptor<T>) - Method in interface org.apache.beam.sdk.schemas.utils.SchemaInformationProvider
- getConvertedSchemaInformation(Schema, TypeDescriptor<T>, SchemaRegistry) - Static method in class org.apache.beam.sdk.schemas.utils.ConvertHelpers
-
Get the coder used for converting from an inputSchema to a given type.
- getConvertPrimitive(Schema.FieldType, TypeDescriptor<?>, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.ConvertHelpers
-
Returns a function to convert a Row into a primitive type.
- getCount() - Method in class org.apache.beam.sdk.metrics.DistributionResult
- getCount() - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
- getCount(int) - Method in class org.apache.beam.sdk.util.HistogramData
-
TODO(https://github.com/apache/beam/issues/20853): Update this function to allow indexing the -INF and INF bucket (using 0 and length -1) Get the bucket count for the given bucketIndex.
- getCounter(MetricName) - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
-
Return the
Counterthat should be used for implementing the givenmetricNamein this container. - getCounters() - Method in class org.apache.beam.sdk.metrics.MetricQueryResults
-
Return the metric results for the counters that matched the filter.
- getCrossProduct() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider.Configuration
- getCurrent() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
- getCurrent() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
-
Gets the current record from the delegate reader.
- getCurrent() - Method in class org.apache.beam.sdk.io.Source.Reader
-
Returns the value of the data item that was read by the last
Source.Reader.start()orSource.Reader.advance()call. - getCurrent() - Method in class org.apache.beam.sdk.runners.TransformHierarchy
- getCurrentBlock() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
-
Returns the current block (the block that was read by the last successful call to
BlockBasedSource.BlockBasedReader.readNextBlock()). - getCurrentBlockOffset() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
-
Returns the largest offset such that starting to read from that offset includes the current block.
- getCurrentBlockSize() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
-
Returns the size of the current block in bytes as it is represented in the underlying file, if possible.
- getCurrentContainer() - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
-
Return the
MetricsContainerfor the current thread. - getCurrentDirectory() - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderResourceId
- getCurrentDirectory() - Method in interface org.apache.beam.sdk.io.fs.ResourceId
-
Returns the
ResourceIdthat represents the current directory of thisResourceId. - getCurrentOffset() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
- getCurrentOffset() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
- getCurrentOffset() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
-
Returns the starting offset of the
current record, which has been read by the last successfulSource.Reader.start()orSource.Reader.advance()call. - getCurrentRecord() - Method in class org.apache.beam.sdk.io.BlockBasedSource.Block
-
Returns the current record.
- getCurrentRecordId() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
-
Returns a unique identifier for the current record.
- getCurrentRecordId() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
- getCurrentRecordOffset() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
- getCurrentRecordOffset() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
- getCurrentRelativeTime() - Method in interface org.apache.beam.sdk.state.Timer
-
Returns the current relative time used by
Timer.setRelative()andTimer.offset(org.joda.time.Duration). - getCurrentSource() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
-
Returns a
Sourcedescribing the same input that thisReadercurrently reads (including items already read). - getCurrentSource() - Method in class org.apache.beam.sdk.io.FileBasedSource.FileBasedReader
- getCurrentSource() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
- getCurrentSource() - Method in class org.apache.beam.sdk.io.Source.Reader
-
Returns a
Sourcedescribing the same input that thisReadercurrently reads (including items already read). - getCurrentSource() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
-
Returns the
UnboundedSourcethat created this reader. - getCurrentTimestamp() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
-
By default, returns the minimum possible timestamp.
- getCurrentTimestamp() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
- getCurrentTimestamp() - Method in class org.apache.beam.sdk.io.Source.Reader
-
Returns the timestamp associated with the current data item.
- getDateTime(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.DATETIMEvalue by field index,IllegalStateExceptionis thrown if schema doesn't match. - getDateTime(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.DATETIMEvalue by field name,IllegalStateExceptionis thrown if schema doesn't match. - getDayOfMonth() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
- getDayOfMonth() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
- getDecimal(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a
BigDecimalvalue by field index,ClassCastExceptionis thrown if schema doesn't match. - getDecimal(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.DECIMALvalue by field name,IllegalStateExceptionis thrown if schema doesn't match. - getDefaultDestination() - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
-
Returns the default destination.
- getDefaultDockerRepoPrefix() - Method in class org.apache.beam.sdk.util.ReleaseInfo
-
Provides docker image default repo prefix (beam_).
- getDefaultDockerRepoRoot() - Method in class org.apache.beam.sdk.util.ReleaseInfo
-
Provides docker image default root (apache).
- getDefaultEnvironmentConfig() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- getDefaultEnvironmentType() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- getDefaultOutputCoder() - Method in class org.apache.beam.sdk.io.Source
-
Deprecated.Override
Source.getOutputCoder()instead. - getDefaultOutputCoder() - Method in class org.apache.beam.sdk.transforms.PTransform
-
Deprecated.Instead, the PTransform should explicitly call
PCollection.setCoder(org.apache.beam.sdk.coders.Coder<T>)on the returned PCollection. - getDefaultOutputCoder() - Method in class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter
- getDefaultOutputCoder() - Method in class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource
- getDefaultOutputCoder(InputT) - Method in class org.apache.beam.sdk.transforms.PTransform
-
Deprecated.Instead, the PTransform should explicitly call
PCollection.setCoder(org.apache.beam.sdk.coders.Coder<T>)on the returned PCollection. - getDefaultOutputCoder(InputT, PCollection<T>) - Method in class org.apache.beam.sdk.transforms.PTransform
-
Deprecated.Instead, the PTransform should explicitly call
PCollection.setCoder(org.apache.beam.sdk.coders.Coder<T>)on the returned PCollection. - getDefaultOutputCoder(CoderRegistry, Coder<InputT>) - Method in interface org.apache.beam.sdk.transforms.CombineFnBase.GlobalCombineFn
-
Returns the
Coderto use by default for outputOutputTvalues, or null if it is not able to be inferred. - getDefaultOutputCoder(CoderRegistry, Coder<Double>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
- getDefaultOutputCoder(CoderRegistry, Coder<Integer>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
- getDefaultOutputCoder(CoderRegistry, Coder<Long>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
- getDefaultOutputCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
- getDefaultOutputCoder(CoderRegistry, Coder<V>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
- getDefaultSdkHarnessLogLevel() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
-
This option controls the default log level of all loggers without a log level override.
- getDefaultValue() - Method in interface org.apache.beam.sdk.values.PCollectionViews.HasDefaultValue
- getDefaultValue() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
-
Deprecated.Returns the default value that was specified.
- getDefaultValue() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn2
-
Returns the default value that was specified.
- getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
- getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn
- getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
- getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
-
Return a
WindowMappingFnthat returns the earliest window that contains the end of the main-input window. - getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
Returns the default
WindowMappingFnto use to map main input windows to side input windows. - getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.util.IdentityWindowFn
- getDeferredArtifacts(PipelineOptions) - Static method in class org.apache.beam.sdk.util.construction.Environments
- getDelay() - Method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform.Delay
- getDelimiters() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
- getDependencies(ConfigT, PipelineOptions) - Method in interface org.apache.beam.sdk.transforms.ExternalTransformBuilder
-
List the dependencies needed for this transform.
- getDescription() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
If the field has a description, returns the description for the field.
- getDescription() - Method in class org.apache.beam.sdk.schemas.Schema.Field
-
Returns the field's description.
- getDescription() - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Failure
-
The description of what was being attempted when the failure occurred.
- getDestination() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
- getDestination() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
-
Return the user destination object for this writer.
- getDestination(UserT) - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
-
Returns an object that represents at a high level the destination being written to.
- getDestinationCoder() - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
-
Returns the coder for
FileBasedSink.DynamicDestinations. - getDestinationFile(boolean, FileBasedSink.DynamicDestinations<?, DestinationT, ?>, int, FileBasedSink.OutputFileHints) - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
- getDiagnostics() - Method in exception org.apache.beam.sdk.schemas.transforms.providers.StringCompiler.CompileException
- getDirectoryTreatment() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
- getDistribution(MetricName) - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
-
Return the
Distributionthat should be used for implementing the givenmetricNamein this container. - getDistributions() - Method in class org.apache.beam.sdk.metrics.MetricQueryResults
-
Return the metric results for the distributions that matched the filter.
- getDlqTransform(String) - Static method in class org.apache.beam.sdk.schemas.io.GenericDlq
- getDoFn() - Method in class org.apache.beam.sdk.util.DoFnInfo
-
Returns the embedded function.
- getDoFn() - Method in class org.apache.beam.sdk.util.DoFnWithExecutionInformation
- getDoFn(RunnerApi.ParDoPayload) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- getDoFn(AppliedPTransform<?, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- getDoFnSchemaInformation() - Method in class org.apache.beam.sdk.util.DoFnInfo
- getDoFnSchemaInformation(DoFn<?, ?>, PCollection<?>) - Static method in class org.apache.beam.sdk.transforms.ParDo
-
Extract information on how the DoFn uses schemas.
- getDouble(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.DOUBLEvalue by field index,ClassCastExceptionis thrown if schema doesn't match. - getDouble(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.DOUBLEvalue by field name,IllegalStateExceptionis thrown if schema doesn't match. - getDrop() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration
- getDynamicDestinations() - Method in class org.apache.beam.sdk.io.FileBasedSink
-
Return the
FileBasedSink.DynamicDestinationsused. - getDynamicDestinationSideInputs(AppliedPTransform<PCollection<UserT>, WriteFilesResult<DestinationT>, ? extends PTransform<PCollection<UserT>, WriteFilesResult<DestinationT>>>) - Static method in class org.apache.beam.sdk.util.construction.WriteFilesTranslation
- getDynamicTimerTag() - Method in class org.apache.beam.sdk.util.construction.Timer
-
Returns the tag that the timer is set on.
- getEarlyTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
- getElemCoder() - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
- getElementByteSize() - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches.BatchingParams
- getElementCoder() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElements
- getElementCoders() - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
- getElementConverters() - Method in class org.apache.beam.sdk.transforms.DoFnSchemaInformation
-
The schema of the @Element parameter.
- getElementCount() - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
-
The number of elements after which this trigger may fire.
- getElementProcessingTimeoutMinutes() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
-
The time limit (in minute) that an SDK worker allows for a PTransform operation before signaling the runner harness to restart the SDK worker.
- getElements() - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate
- getElements() - Method in class org.apache.beam.sdk.testing.TestStream.ElementEvent
- getElements() - Method in class org.apache.beam.sdk.transforms.Create.Values
- getElements() - Method in class org.apache.beam.sdk.util.construction.PrimitiveCreate
- getElementType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
If the field is a container type, returns the element type.
- getEmptyMatchTreatment() - Method in class org.apache.beam.sdk.io.FileBasedSource
- getEmptyMatchTreatment() - Method in class org.apache.beam.sdk.io.FileIO.MatchConfiguration
- getEmptyMatchTreatment() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
- getEnableHeapDumps() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
-
If true and PipelineOption tempLocation is set, save a heap dump before shutting down the JVM due to GC thrashing or out of memory.
- getEnableLogViaFnApi() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
-
This option controls whether logging will be redirected through the FnApi.
- getEnclosingNode() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
-
Returns the enclosing composite transform node, or null if there is none.
- getEncodedElementByteSize(byte[]) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
- getEncodedElementByteSize(T) - Method in class org.apache.beam.sdk.coders.NullableCoder
-
Overridden to short-circuit the default
StructuredCoderbehavior of encoding and counting the bytes. - getEncodedElementByteSize(Boolean) - Method in class org.apache.beam.sdk.coders.BooleanCoder
- getEncodedElementByteSize(Byte) - Method in class org.apache.beam.sdk.coders.ByteCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Double) - Method in class org.apache.beam.sdk.coders.DoubleCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Float) - Method in class org.apache.beam.sdk.coders.FloatCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Integer) - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Integer) - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
- getEncodedElementByteSize(Integer) - Method in class org.apache.beam.sdk.coders.VarIntCoder
- getEncodedElementByteSize(Long) - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Long) - Method in class org.apache.beam.sdk.coders.VarLongCoder
- getEncodedElementByteSize(Short) - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(String) - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Void) - Method in class org.apache.beam.sdk.coders.VoidCoder
- getEncodedElementByteSize(BigDecimal) - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(BigInteger) - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Optional<T>) - Method in class org.apache.beam.sdk.coders.OptionalCoder
-
Overridden to short-circuit the default
StructuredCoderbehavior of encoding and counting the bytes. - getEncodedElementByteSize(EncodedBoundedWindow) - Method in class org.apache.beam.sdk.fn.windowing.EncodedBoundedWindow.Coder
- getEncodedElementByteSize(OffsetRange) - Method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
- getEncodedElementByteSize(Instant) - Method in class org.apache.beam.sdk.coders.InstantCoder
- getEncodedElementByteSize(T) - Method in class org.apache.beam.sdk.coders.Coder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(T) - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
-
Overridden to short-circuit the default
StructuredCoderbehavior of encoding and counting the bytes. - getEncodedElementByteSizeUsingCoder(Coder<T>, T) - Static method in class org.apache.beam.sdk.coders.Coder
- getEncodedRecord() - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record
-
Nullable to account for failing to encode, or if there is no coder for the record at the time of failure.
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.ByteCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.Coder
-
Returns the
TypeDescriptorfor the type encoded. - getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.CollectionCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.DelegateCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.DequeCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.DoubleCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.DurationCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.FloatCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.InstantCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.IterableCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.KvCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.ListCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.MapCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.NullableCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.OptionalCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.SerializableCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.SetCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.SortedMapCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.VarIntCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.VarLongCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.VoidCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
- getEncodedWindow() - Method in class org.apache.beam.sdk.fn.windowing.EncodedBoundedWindow
- getEncodingPositions() - Method in class org.apache.beam.sdk.schemas.Schema
-
Gets the encoding positions for this schema.
- getEnd() - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration
- getEndKey() - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
-
Returns the
ByteKeyrepresenting the upper bound of thisByteKeyRange. - getEndOffset() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
-
Returns the specified ending offset of the source.
- getEnumName(int) - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
- getEnumValue(String) - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
- getEnvironment() - Method in interface org.apache.beam.sdk.util.construction.graph.ExecutableStage
-
Returns the
RunnerApi.Environmentthis stage executes in. - getEnvironment() - Method in class org.apache.beam.sdk.util.construction.graph.ImmutableExecutableStage
- getEnvironment(String) - Method in class org.apache.beam.sdk.util.construction.RehydratedComponents
-
Returns the
RunnerApi.Environmentassociated with the given ID. - getEnvironment(String, RunnerApi.Components) - Static method in class org.apache.beam.sdk.util.construction.Environments
- getEnvironment(RunnerApi.PTransform, RehydratedComponents) - Static method in class org.apache.beam.sdk.util.construction.Environments
- getEnvironment(PipelineNode.PTransformNode) - Method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
- getEnvironmentCacheMillis() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- getEnvironmentExpirationMillis() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- getEnvironmentId() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- getEnvironmentIdFor(ResourceHints) - Method in class org.apache.beam.sdk.util.construction.SdkComponents
- getEnvironmentOption(PortablePipelineOptions, String) - Static method in interface org.apache.beam.sdk.options.PortablePipelineOptions
-
Return the value for the specified environment option or empty string if not present.
- getEnvironmentOptions() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- getError() - Method in class org.apache.beam.sdk.schemas.io.Failure
-
Information about the cause of the failure.
- getErrorContext() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
-
Return a human readable representation of the current call context to be used during error reporting.
- getErrorContext() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- getErrorContext() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.FakeArgumentProvider
- getErrorHandling() - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformConfiguration
- getErrorHandling() - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration
- getErrorHandling() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider.Configuration
- getErrorHandling() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration
- getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.BoundedSource
-
An estimate of the total size (in bytes) of the data that would be read from this source.
- getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSource
- getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.OffsetBasedSource
- getEvents() - Method in class org.apache.beam.sdk.testing.TestStream
-
Returns the sequence of
Eventsin thisTestStream. - getException() - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Failure
-
The exception itself, e.g.
- getException() - Method in class org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult
- getExceptionStacktrace() - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Failure
-
The full stacktrace.
- getExecutableStagePayload(AppliedPTransform<?, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.ExecutableStageTranslation
-
Extracts an
RunnerApi.ExecutableStagePayloadfrom the given transform. - getExpansionServiceClient(Endpoints.ApiServiceDescriptor) - Method in class org.apache.beam.sdk.util.construction.DefaultExpansionServiceClientFactory
- getExpansionServiceClient(Endpoints.ApiServiceDescriptor) - Method in interface org.apache.beam.sdk.util.construction.ExpansionServiceClientFactory
- getExperiments() - Method in interface org.apache.beam.sdk.options.ExperimentalOptions
- getExperimentValue(PipelineOptions, String) - Static method in interface org.apache.beam.sdk.options.ExperimentalOptions
-
Return the value for the specified experiment or null if not present.
- getExposedClasses() - Method in class org.apache.beam.sdk.util.ApiSurface
-
Returns exposed types in this set, including arrays and primitives as specified.
- getExpression() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration
- getExternalServiceAddress(PortablePipelineOptions) - Static method in class org.apache.beam.sdk.util.construction.Environments
- getFactory() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
- getFactory() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
- getFailedToParseLines() - Method in class org.apache.beam.sdk.transforms.JsonToRow.ParseResult
-
Returns a
PCollectioncontaining theRows that didn't parse. - getFailsafeValue() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow
-
Returns the failsafe value of this
FailsafeValueInSingleWindow. - getFailure() - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord
-
Information about why the record failed.
- getFanout() - Method in class org.apache.beam.sdk.transforms.Combine.GloballyAsSingletonView
- getField() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- getField(int) - Method in class org.apache.beam.sdk.schemas.Schema
-
Return a field by index.
- getField(String) - Method in class org.apache.beam.sdk.schemas.Schema
- getFieldAccessDescriptor() - Method in class org.apache.beam.sdk.transforms.DoFnSchemaInformation
-
Effective FieldAccessDescriptor applied by DoFn.
- getFieldCount() - Method in class org.apache.beam.sdk.schemas.Schema
-
Return the count of fields.
- getFieldCount() - Method in class org.apache.beam.sdk.values.Row
-
Return the size of data fields.
- getFieldCount() - Method in class org.apache.beam.sdk.values.RowWithGetters
- getFieldCount() - Method in class org.apache.beam.sdk.values.RowWithStorage
- getFieldDescription(T) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- getFieldId() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
- getFieldName() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
- getFieldNames() - Method in class org.apache.beam.sdk.schemas.Schema
-
Return the list of all field names.
- getFieldRename() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
- getFields() - Method in class org.apache.beam.sdk.schemas.Schema
- getFields() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider.Configuration
- getFields() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration
- getFields(Class<?>) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
- getFieldsAccessed() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
- getFieldType(OneOfType.Value) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
- getFieldTypes(TypeDescriptor<?>, Schema, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
- getFieldTypes(TypeDescriptor<?>, Schema, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
- getFilename() - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderResourceId
- getFilename() - Method in interface org.apache.beam.sdk.io.fs.ResourceId
-
Returns the name of the file or directory denoted by this
ResourceId. - getFilename(BoundedWindow, PaneInfo, int, int, Compression) - Method in interface org.apache.beam.sdk.io.FileIO.Write.FileNaming
-
Generates the filename.
- getFilenamePolicy(DestinationT) - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
-
Converts a destination into a
FileBasedSink.FilenamePolicy. - getFilenameSuffix() - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration
- getFileOrPatternSpec() - Method in class org.apache.beam.sdk.io.FileBasedSource
- getFileOrPatternSpecProvider() - Method in class org.apache.beam.sdk.io.FileBasedSource
- getFilePattern() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
- getFilePattern() - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformConfiguration
- getFilePattern() - Method in class org.apache.beam.sdk.util.NumberedShardedFile
- getFilesToStage() - Method in interface org.apache.beam.sdk.options.FileStagingOptions
-
List of local files to make available to workers.
- getFireTimestamp() - Method in class org.apache.beam.sdk.util.construction.Timer
-
Returns the timestamp of when the timer is scheduled to fire.
- getFloat(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.FLOATvalue by field index,ClassCastExceptionis thrown if schema doesn't match. - getFloat(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.FLOATvalue by field name,IllegalStateExceptionis thrown if schema doesn't match. - getFn() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
Returns the
CombineFnBase.GlobalCombineFnused by this Combine operation. - getFn() - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
-
Returns the
CombineFnBase.GlobalCombineFnused by this Combine operation. - getFn() - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
-
Returns the
CombineFnBase.GlobalCombineFnused by this Combine operation. - getFn() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
- getFn() - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
- getFn() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Get the bound
DoFn. - getFn() - Method in class org.apache.beam.sdk.util.AppliedCombineFn
- getFn() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElements
- getFractionConsumed() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
- getFractionConsumed() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
-
Returns a value in [0, 1] representing approximately what fraction of the
current sourcethis reader has read so far, ornullif such an estimate is not available. - getFractionConsumed() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
- getFractionConsumed() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
- getFractionConsumed() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
- getFractionConsumed() - Method in interface org.apache.beam.sdk.io.range.RangeTracker
-
Returns the approximate fraction of positions in the source that have been consumed by successful
RangeTracker.tryReturnRecordAt(boolean, PositionT)calls, or 0.0 if no such calls have happened. - getFractionOfBlockConsumed() - Method in class org.apache.beam.sdk.io.BlockBasedSource.Block
-
Returns the fraction of the block already consumed, if possible, as a value in
[0, 1]. - getFrom() - Method in class org.apache.beam.sdk.io.range.OffsetRange
- getFromRowFunction() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
-
Returns the toRow conversion function.
- getFromRowFunction() - Method in class org.apache.beam.sdk.values.PCollection
-
Returns the attached schema's fromRowFunction.
- getFromRowFunction(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Retrieve the function that converts a
Rowobject to the specified type. - getFromRowFunction(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Retrieve the function that converts a
Rowobject to the specified type. - getFullCoder(Coder<T>, Coder<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.values.WindowedValues
-
Returns the
Coderto use for aWindowedValue<T>, using the given valueCoder and windowCoder. - getFullName() - Method in class org.apache.beam.sdk.runners.AppliedPTransform
- getFullName() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
- getFunction() - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields.Fanout
- getFunction() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf
- getFusedStages() - Method in class org.apache.beam.sdk.util.construction.graph.FusedPipeline
-
The
executable stagesthat are executed by SDK harnesses. - getGapDuration() - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
- getGauge(MetricName) - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
-
Return the
Gaugethat should be used for implementing the givenmetricNamein this container. - getGauges() - Method in class org.apache.beam.sdk.metrics.MetricQueryResults
-
Return the metric results for the gauges that matched the filter.
- getGbek() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
A string defining whether GroupByKey transforms should be replaced by GroupByEncryptedKey
- getGCThrashingPercentagePerPeriod() - Method in interface org.apache.beam.sdk.options.MemoryMonitorOptions
-
The GC thrashing threshold percentage.
- getGetters() - Method in class org.apache.beam.sdk.values.RowWithGetters
- getGetters(TypeDescriptor<T>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
-
Return the list of
FieldValueGetters for a Java Bean class - getGetters(TypeDescriptor<T>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
- getGetterTarget() - Method in class org.apache.beam.sdk.values.RowWithGetters
- getGrammarFileName() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- getGrammarFileName() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- getGroupingTableMaxSizeMb() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
-
Size (in MB) of each grouping table used to pre-combine elements.
- getGzipCompressHeapDumps() - Method in interface org.apache.beam.sdk.options.MemoryMonitorOptions
-
Controls if heap dumps that are copied to remote destination are gzipped compressed.
- getHeaderAccessor() - Static method in class org.apache.beam.sdk.fn.server.GrpcContextHeaderAccessorProvider
- getHistogram(MetricName, HistogramData.BucketType) - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
-
Return the
Histogramthat should be used for implementing the givenmetricNamein this container. - getHistograms() - Method in class org.apache.beam.sdk.metrics.MetricQueryResults
-
Return the metric results for the sets that matched the filter.
- getHoldTimestamp() - Method in class org.apache.beam.sdk.util.construction.Timer
-
Returns the watermark that the timer is supposed to be held.
- getHumanReadableJsonRecord() - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record
-
The failing record, encoded as JSON.
- getId() - Method in interface org.apache.beam.sdk.fn.IdGenerator
- getId() - Method in interface org.apache.beam.sdk.util.construction.graph.PipelineNode
- getId() - Method in class org.apache.beam.sdk.util.construction.graph.PipelineNode.PCollectionNode
- getId() - Method in class org.apache.beam.sdk.util.construction.graph.PipelineNode.PTransformNode
- getId() - Method in class org.apache.beam.sdk.values.TupleTag
-
Returns the id of this
TupleTag. - getId() - Method in class org.apache.beam.sdk.values.ValueWithRecordId
- getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Date
- getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
- getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
- getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
- getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
- getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
- getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PythonCallable
- getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.SchemaLogicalType
- getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.Time
- getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.UuidLogicalType
- getIdentifier() - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
-
The unique identifier for this type.
- getInboundObserver() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer
- getIncompatibleGlobalWindowErrorMessage() - Method in interface org.apache.beam.sdk.transforms.CombineFnBase.GlobalCombineFn
-
Returns the error message for not supported default values in Combine.globally().
- getIncompatibleGlobalWindowErrorMessage() - Method in class org.apache.beam.sdk.transforms.Top.TopCombineFn
- getIndex() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
The zero-based index of this trigger firing that produced this pane.
- getIndex(TupleTag<?>) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
-
Returns the index for the given tuple tag, if the tag is present in this schema, -1 if it isn't.
- getInitialRestriction() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.GetInitialRestrictionmethod. - getInitialRestriction(InputT) - Method in class org.apache.beam.sdk.transforms.Watch.WatchGrowthFn
- GetInitialRestrictionMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialRestrictionMethod
- getInitialWatermarkEstimatorState() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.GetInitialWatermarkEstimatorStatemethod. - getInitialWatermarkEstimatorState(Instant) - Method in class org.apache.beam.sdk.transforms.Watch.WatchGrowthFn
- GetInitialWatermarkEstimatorStateMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialWatermarkEstimatorStateMethod
- getInput() - Method in class org.apache.beam.sdk.runners.PTransformOverrideFactory.PTransformReplacement
- getInputCoder() - Method in class org.apache.beam.sdk.util.DoFnInfo
- getInputPCollection() - Method in interface org.apache.beam.sdk.util.construction.graph.ExecutableStage
-
Returns the root
PipelineNode.PCollectionNodeof thisExecutableStage. - getInputPCollection() - Method in class org.apache.beam.sdk.util.construction.graph.ImmutableExecutableStage
- getInputs() - Method in class org.apache.beam.sdk.runners.AppliedPTransform
- getInputs() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
-
Returns the transform input, in fully expanded form.
- getInputType() - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
-
Returns a
TypeDescriptorcapturing what is known statically about the input type of thisCombineFninstance's most-derived class. - getInputTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.DoFn
-
Returns a
TypeDescriptorcapturing what is known statically about the input type of thisDoFninstance's most-derived class. - getInputTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.InferableFunction
-
Returns a
TypeDescriptorcapturing what is known statically about the input type of thisInferableFunctioninstance's most-derived class. - getInputValueCoder(Coder<KV<K, V>>) - Static method in class org.apache.beam.sdk.transforms.GroupByKey
-
Returns the
Coderof the values of the input to this transform. - getInputWindowingStrategy() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElements
- getInsertDefault() - Method in class org.apache.beam.sdk.transforms.Combine.GloballyAsSingletonView
- getInstance() - Static method in class org.apache.beam.sdk.metrics.NoOpCounter
- getInstance() - Static method in class org.apache.beam.sdk.metrics.NoOpHistogram
- getInstance(String, String) - Static method in class org.apache.beam.sdk.schemas.transforms.providers.StringCompiler
- getInstructionId() - Method in class org.apache.beam.sdk.fn.data.LogicalEndpoint
- getInt16(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.INT16value by field index,ClassCastExceptionis thrown if schema doesn't match. - getInt16(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.INT16value by field name,IllegalStateExceptionis thrown if schema doesn't match. - getInt32(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.INT32value by field index,ClassCastExceptionis thrown if schema doesn't match. - getInt32(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.INT32value by field name,IllegalStateExceptionis thrown if schema doesn't match. - getInt64(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.INT64value by field index,ClassCastExceptionis thrown if schema doesn't match. - getInt64(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.INT64value by field name,IllegalStateExceptionis thrown if schema doesn't match. - getInterfaces() - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns a set of
TypeDescriptors, one for each interface implemented by this class. - getInvLog2GrowthFactor() - Method in class org.apache.beam.sdk.util.HistogramData.ExponentialBuckets
-
Set to 2**scale which is equivalent to 1/log_2(base).
- getIsLazy() - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObserver
-
Returns whether byte counting for the current element is lazy, that is, whether the observer gets notified of the element's byte count only as element's pieces are being processed or iterated over.
- getIterable(int) - Method in class org.apache.beam.sdk.values.Row
-
Get an iterable value by field index,
IllegalStateExceptionis thrown if schema doesn't match. - getIterable(String) - Method in class org.apache.beam.sdk.values.Row
-
Get an iterable value by field name,
IllegalStateExceptionis thrown if schema doesn't match. - getIterableComponentType(TypeDescriptor) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
-
For an array T[] or a subclass of Iterable
, return a TypeDescriptor describing T. - getJavaCapabilities() - Static method in class org.apache.beam.sdk.util.construction.Environments
- getJavaVersion() - Static method in class org.apache.beam.sdk.util.construction.Environments
- getJdkAddOpenModules() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
-
Open modules needed for reflection that access JDK internals with Java 9+.
- getJdkAddRootModules() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
-
Add modules to the default root set with Java 11+.
- getJobEndpoint() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- getJobName() - Method in interface org.apache.beam.sdk.options.PipelineOptions
- getJobServerTimeout() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- getJsonBytesToRowFunction(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.JsonUtils
-
Returns a
SimpleFunctionmapping JSON byte[] arrays to BeamRows. - getJsonStringToRowFunction(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.JsonUtils
- getJsonToRowWithErrFn() - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError
- getKeep() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider.Configuration
- getKey() - Method in class org.apache.beam.sdk.metrics.MetricResult
- getKey() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
- getKey() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
The key for the display item.
- getKey() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
The key for the display item.
- getKey() - Method in class org.apache.beam.sdk.util.ShardedKey
- getKey() - Method in class org.apache.beam.sdk.values.KV
-
Returns the key of this
KV. - getKey() - Method in class org.apache.beam.sdk.values.ShardedKey
-
Deprecated.
- getKeyCoder() - Method in class org.apache.beam.sdk.coders.KvCoder
- getKeyCoder() - Method in class org.apache.beam.sdk.coders.MapCoder
- getKeyCoder() - Method in class org.apache.beam.sdk.coders.SortedMapCoder
- getKeyCoder() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
- getKeyCoder() - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
- getKeyCoder(Coder<KV<K, V>>) - Static method in class org.apache.beam.sdk.transforms.GroupByKey
-
Returns the
Coderof the keys of the input to this transform, which is also used as theCoderof the keys of the output of this transform. - getKeyedCollections() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
Returns a list of
TaggedKeyedPCollectionsfor thePCollectionscontained in thisKeyedPCollectionTuple. - getKind() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
- getKind() - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields.Fanout
- getKindString() - Method in class org.apache.beam.sdk.io.BoundedReadFromUnboundedSource
- getKindString() - Method in class org.apache.beam.sdk.io.Read.Bounded
- getKindString() - Method in class org.apache.beam.sdk.io.Read.Unbounded
- getKindString() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
- getKindString() - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
- getKindString() - Method in class org.apache.beam.sdk.transforms.Combine.PerKeyWithHotKeyFanout
- getKindString() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
- getKindString() - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
- getKindString() - Method in class org.apache.beam.sdk.transforms.PTransform
-
Returns the name to use by default for this
PTransform(not including the names of any enclosingPTransforms). - getKindString() - Method in class org.apache.beam.sdk.transforms.Tee
- getKindString() - Method in class org.apache.beam.sdk.transforms.windowing.Window
- getKindString() - Method in class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource
- getKindString() - Method in class org.apache.beam.sdk.values.PValueBase
-
Returns a
Stringcapturing the kind of thisPValueBase. - getKnownPayloadTranslators() - Static method in class org.apache.beam.sdk.util.construction.PTransformTranslation
- getKvCoder() - Method in class org.apache.beam.sdk.util.AppliedCombineFn
- getKvCoderComponents(RunnerApi.Coder) - Static method in class org.apache.beam.sdk.util.construction.ModelCoders
- getLabel() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
Retrieve the optional label for an item.
- getLabel() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
The optional label for an item.
- getLabels() - Method in class org.apache.beam.sdk.metrics.MetricName
-
Associated labels for the metric.
- getLanguage() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider.Configuration
- getLanguage() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration
- getLastEmitted() - Method in class org.apache.beam.sdk.io.CountingSource.CounterMark
-
Returns the last value emitted by the reader.
- getLastFieldId() - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- getLateTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
- getLength() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
- getLength() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedString
- getLength(int) - Static method in class org.apache.beam.sdk.util.VarInt
-
Returns the length of the encoding of the given value (in bytes).
- getLength(long) - Static method in class org.apache.beam.sdk.util.VarInt
-
Returns the length of the encoding of the given value (in bytes).
- getLevel() - Method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider.Configuration
- getLevenshteinDistance(String, String) - Static method in class org.apache.beam.sdk.util.StringUtils
-
Calculate the Levenshtein distance between two strings.
- getLinkUrl() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
Retrieve the optional link URL for an item.
- getLinkUrl() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
The optional link URL for an item.
- getList() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
- getLoadBalanceBundles() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- getLogicalType() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
- getLogicalType(Class<LogicalTypeT>) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Helper function for retrieving the concrete logical type subclass.
- getLogicalTypeValue(int, Class<T>) - Method in class org.apache.beam.sdk.values.Row
-
Returns the Logical Type input type for this field.
- getLogicalTypeValue(String, Class<T>) - Method in class org.apache.beam.sdk.values.Row
-
Returns the Logical Type input type for this field.
- getLogLevel() - Method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider.Configuration
- getLogMdc() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
-
Whether to include SLF4J MDC in log entries.
- getMainInput(RunnerApi.PTransform, RunnerApi.Components) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- getMainInputName(RunnerApi.PTransformOrBuilder) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
Returns the name of the main input of the ptransform.
- getMainInputs() - Method in class org.apache.beam.sdk.runners.AppliedPTransform
- getMainOutput() - Method in class org.apache.beam.sdk.util.DoFnInfo
- getMainOutputReceiver() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
-
The
DoFnSignature.Parameter.OutputReceiverParameterfor a main output, or null if there is none. - getMainOutputTag() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - getMainOutputTag() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
- getMainOutputTag() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElements
- getMainOutputTag() - Method in class org.apache.beam.sdk.util.DoFnWithExecutionInformation
- getMainOutputTag(RunnerApi.ParDoPayload) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- getMainOutputTag(AppliedPTransform<?, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- getMainTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
-
The main trigger, which will continue firing until the "until" trigger fires.
- getMap() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
- getMap(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a MAP value by field index,
IllegalStateExceptionis thrown if schema doesn't match. - getMap(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a MAP value by field name,
IllegalStateExceptionis thrown if schema doesn't match. - getMapKeyType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
If the field is a map type, returns the key type.
- getMapKeyType() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
- getMapType(TypeDescriptor, int) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
- getMapValueType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
If the field is a map type, returns the key type.
- getMapValueType() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
- getMatcher() - Method in class org.apache.beam.sdk.runners.PTransformOverride
-
Gets the
PTransformMatcherto identifyPTransformsto replace. - getMatchUpdatedFiles() - Method in class org.apache.beam.sdk.io.FileIO.MatchConfiguration
- getMaterialization() - Method in class org.apache.beam.sdk.transforms.ViewFn
-
Gets the materialization of this
ViewFn. - getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryListFromMultimapViewFn
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryListViewFn
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMapFromVoidKeyViewFn
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMapViewFn
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMultimapFromVoidKeyViewFn
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMultimapViewFn
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableBackedListViewFn
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn
-
Deprecated.
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn2
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.ListViewFn
-
Deprecated.
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.ListViewFn2
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.MapViewFn
-
Deprecated.
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.MapViewFn2
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn
-
Deprecated.
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn2
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
-
Deprecated.
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn2
- getMax() - Method in class org.apache.beam.sdk.metrics.DistributionResult
- getMaxBufferingDuration() - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches.BatchingParams
- getMaxCacheMemoryUsage(PipelineOptions) - Method in class org.apache.beam.sdk.options.SdkHarnessOptions.DefaultMaxCacheMemoryUsageMb
- getMaxCacheMemoryUsage(PipelineOptions) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions.MaxCacheMemoryUsageMb
- getMaxCacheMemoryUsageMb() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
-
Size (in MB) for the process wide cache within the SDK harness.
- getMaxCacheMemoryUsageMbClass() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
-
An instance of this class will be used to specify the maximum amount of memory to allocate to a cache within an SDK harness instance.
- getMaxCacheMemoryUsagePercent() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
-
Size (in % [0 - 100]) for the process wide cache within the SDK harness.
- getMaxEndOffset(PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSource
- getMaxEndOffset(PipelineOptions) - Method in class org.apache.beam.sdk.io.OffsetBasedSource
-
Returns the actual ending offset of the current source.
- getMaxLength() - Method in class org.apache.beam.sdk.schemas.logicaltypes.VariableBytes
- getMaxLength() - Method in class org.apache.beam.sdk.schemas.logicaltypes.VariableString
- getMaxNumWritersPerBundle() - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration
- getMean() - Method in class org.apache.beam.sdk.metrics.DistributionResult
- getMean() - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
- getMean() - Method in class org.apache.beam.sdk.util.HistogramData
- getMessage() - Method in exception org.apache.beam.sdk.coders.Coder.NonDeterministicException
- getMessage() - Method in exception org.apache.beam.sdk.transforms.windowing.IncompatibleWindowException
- getMetadata() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
-
Returns the
MatchResult.Metadataof the file. - getMetadata() - Method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadata
- getMetadata(String) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Deprecated.use schema options instead.
- getMetadataCoder() - Method in class org.apache.beam.sdk.io.ReadableFileCoder
- getMetadataString(String) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Deprecated.use schema options instead.
- getMethod() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- getMethods(Class<?>) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
-
Returns the list of non private/protected, non-static methods in the class, caching the results.
- getMethodsMap(Class<?>) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
- getMetricLabels() - Method in class org.apache.beam.sdk.metrics.LabeledMetricNameUtils.ParsedMetricName
- getMetricsEnvironmentStateForCurrentThread() - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
-
Returns the container holder for the current thread.
- getMetricsGraphiteHost() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
- getMetricsGraphitePort() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
- getMetricsHttpSinkUrl() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
- getMetricsPushPeriod() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
- getMetricsSink() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
- getMimeType() - Method in enum org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.
- getMimeType() - Method in interface org.apache.beam.sdk.io.FileBasedSink.OutputFileHints
-
Returns the MIME type that should be used for the files that will hold the output data.
- getMin() - Method in class org.apache.beam.sdk.metrics.DistributionResult
- getMinBundleSize() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
-
Returns the minimum bundle size that should be used when splitting the source into sub-sources.
- getMode() - Method in class org.apache.beam.sdk.io.FileBasedSource
- getMode() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- getModeNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- getMonitoringInfos() - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
-
Return the cumulative values for any metrics in this container as MonitoringInfos.
- getMonthOfYear() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
- getMutableOutput(TupleTag<T>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - getName() - Method in class org.apache.beam.sdk.metrics.DelegatingCounter
- getName() - Method in class org.apache.beam.sdk.metrics.DelegatingDistribution
- getName() - Method in class org.apache.beam.sdk.metrics.DelegatingGauge
- getName() - Method in class org.apache.beam.sdk.metrics.DelegatingHistogram
- getName() - Method in interface org.apache.beam.sdk.metrics.Metric
-
The
MetricNamegiven to this metric. - getName() - Method in class org.apache.beam.sdk.metrics.MetricName
-
The name of this metric.
- getName() - Method in class org.apache.beam.sdk.metrics.MetricNameFilter
-
If set, the metric must have this name to match this
MetricNameFilter. - getName() - Method in class org.apache.beam.sdk.metrics.MetricResult
-
Return the name of the metric.
- getName() - Method in class org.apache.beam.sdk.metrics.NoOpCounter
- getName() - Method in class org.apache.beam.sdk.metrics.NoOpHistogram
- getName() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
Returns the field name.
- getName() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
- getName() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedString
- getName() - Method in class org.apache.beam.sdk.schemas.logicaltypes.VariableBytes
- getName() - Method in class org.apache.beam.sdk.schemas.logicaltypes.VariableString
- getName() - Method in class org.apache.beam.sdk.schemas.Schema.Field
-
Returns the field name.
- getName() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration
- getName() - Method in class org.apache.beam.sdk.transforms.PTransform
-
Returns the transform name.
- getName() - Method in class org.apache.beam.sdk.util.construction.ForwardingPTransform
- getName() - Method in class org.apache.beam.sdk.util.ReleaseInfo
-
Provides the SDK name.
- getName() - Method in class org.apache.beam.sdk.values.PCollection
-
Returns the name of this
PCollection. - getName() - Method in interface org.apache.beam.sdk.values.PValue
-
Returns the name of this
PValue. - getName() - Method in class org.apache.beam.sdk.values.PValueBase
-
Returns the name of this
PValueBase. - getNameOverride() - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
- getNameOverride() - Method in class org.apache.beam.sdk.transforms.Top.TopCombineFn
- getNameOverride() - Method in interface org.apache.beam.sdk.util.NameUtils.NameOverride
-
Return the name to use for this instance.
- getNameOverride(String, T) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- getNamespace() - Method in class org.apache.beam.sdk.metrics.MetricName
-
The namespace associated with this metric.
- getNamespace() - Method in class org.apache.beam.sdk.metrics.MetricNameFilter
-
The inNamespace that a metric must be in to match this
MetricNameFilter. - getNamespace() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
- getNamespace() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
The namespace for the display item.
- getNamespace() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
The namespace for the display item.
- getNestedFieldsAccessed() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
- getNewValue() - Method in exception org.apache.beam.sdk.util.IllegalMutationException
-
The value after the illegal mutation.
- getNonNullPrefix() - Method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider.Configuration
- getNonSpeculativeIndex() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
The zero-based index of this trigger firing among non-speculative panes.
- getNoSpilling() - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration
- getNullable() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
- getNullableValue() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
-
Workaround for autovalue code generation, which does not allow type variables to be instantiated with nullable actual parameters.
- getNumber() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
Optionally returns the field index.
- getNumber() - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields.Fanout
- getNumber() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
- getNumber() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
- getNumber() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
- getNumberOverride(int, T) - Static method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- getNumBuckets() - Method in interface org.apache.beam.sdk.util.HistogramData.BucketType
- getNumBuckets() - Method in class org.apache.beam.sdk.util.HistogramData.ExponentialBuckets
- getNumBuckets() - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
- getNumSampledBytesPerFile() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
- getNumShards() - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration
- getNumShards() - Method in class org.apache.beam.sdk.util.ShardingWritableByteChannel
-
Returns the number of output shards.
- getNumShardsProvider() - Method in class org.apache.beam.sdk.io.WriteFiles
- getOffset() - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
- getOffset() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
- getOffset() - Method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform.AlignTo
- getOffsetLimit() - Method in interface org.apache.beam.sdk.io.UnboundedSource.CheckpointMark
- getOnCreateMatcher() - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
- getOneOfSchema() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
Returns the schema of the underlying
Rowthat is used to represent the union. - getOneOfTypes() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- getOnly(String) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
Like
CoGbkResult.getOnly(TupleTag)but using a String instead of a TupleTag. - getOnly(String, V) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
Like
CoGbkResult.getOnly(TupleTag, Object)but using a String instead of a TupleTag. - getOnly(TupleTag<V>) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
If there is a singleton value for the given tag, returns it.
- getOnly(TupleTag<V>, V) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
If there is a singleton value for the given tag, returns it.
- getOnSuccessMatcher() - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
- getOnTimeBehavior() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- getOptionNames() - Method in class org.apache.beam.sdk.schemas.Schema.Options
- getOptions() - Method in class org.apache.beam.sdk.Pipeline
- getOptions() - Method in class org.apache.beam.sdk.schemas.Schema.Field
-
Returns the fields
Schema.Options. - getOptions() - Method in class org.apache.beam.sdk.schemas.Schema
- getOptions() - Method in class org.apache.beam.sdk.testing.TestPipeline
- getOptionsId() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
Provides a process wide unique ID for this
PipelineOptionsobject, assigned at graph construction time. - getOrDefault(K, V) - Method in interface org.apache.beam.sdk.state.MapState
-
A deferred lookup.
- getOriginal() - Method in class org.apache.beam.sdk.runners.PTransformOverrideFactory.ReplacementOutput
- getOutboundObserver() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer
- getOutName(int) - Method in class org.apache.beam.sdk.values.TupleTag
-
If this
TupleTagis tagging outputoutputIndexof aPTransform, returns the name that should be used by default for the output. - getOutput() - Method in class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling
- getOutput() - Method in class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.DefaultErrorHandler
- getOutput() - Method in interface org.apache.beam.sdk.transforms.errorhandling.ErrorHandler
- getOutput() - Method in class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.PTransformErrorHandler
- getOutputCoder() - Method in class org.apache.beam.sdk.io.CompressedSource
-
Returns the delegate source's output coder.
- getOutputCoder() - Method in class org.apache.beam.sdk.io.Source
-
Returns the
Coderto use for the data read from this source. - getOutputCoder() - Method in class org.apache.beam.sdk.io.TextSource
- getOutputCoder(SerializableFunction<InputT, OutputT>, Coder<InputT>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
-
Deprecated.This method is to change in an unknown backwards incompatible way once support for this functionality is refined.
- getOutputCoders() - Method in class org.apache.beam.sdk.util.DoFnInfo
- getOutputCoders(AppliedPTransform<?, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- getOutputExecutablePath() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- getOutputFile() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
- getOutputKvCoder(Coder<KV<K, V>>) - Static method in class org.apache.beam.sdk.transforms.GroupByKey
-
Returns the
Coderof the output of this transform. - getOutputOrNull(ErrorHandling) - Static method in class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling
- getOutputParallelization() - Method in class org.apache.beam.sdk.io.FileIO.MatchAll
-
Returns whether to avoid the reshuffle operation.
- getOutputPCollections() - Method in interface org.apache.beam.sdk.util.construction.graph.ExecutableStage
-
Returns the leaf
PCollectionsof thisExecutableStage. - getOutputPCollections() - Method in class org.apache.beam.sdk.util.construction.graph.ImmutableExecutableStage
- getOutputPCollections(PipelineNode.PTransformNode) - Method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
- getOutputPrefix() - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration
- getOutputs() - Method in class org.apache.beam.sdk.runners.AppliedPTransform
- getOutputs() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
-
Returns the transform output, in expanded form.
- getOutputs() - Method in class org.apache.beam.sdk.testing.TestOutputReceiver
- getOutputSchema(Schema, FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.utils.SelectHelpers
-
Get the output schema resulting from selecting the given
FieldAccessDescriptorfrom the given schema. - getOutputStrategyInternal(WindowingStrategy<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.Window
-
Get the output strategy of this
Window PTransform. - getOutputTagsToCoders() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElements
- getOutputType() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf
- getOutputType() - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
-
Returns a
TypeDescriptorcapturing what is known statically about the output type of thisCombineFninstance's most-derived class. - getOutputTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.DoFn
-
Returns a
TypeDescriptorcapturing what is known statically about the output type of thisDoFninstance's most-derived class. - getOutputTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.InferableFunction
-
Returns a
TypeDescriptorcapturing what is known statically about the output type of thisInferableFunctioninstance's most-derived class. - getOverrideFactory() - Method in class org.apache.beam.sdk.runners.PTransformOverride
-
Gets the
PTransformOverrideFactoryof this override. - getPaneInfo() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
- getPaneInfo() - Method in class org.apache.beam.sdk.util.construction.Timer
-
Returns the
PaneInfothat is related to the timer. - getPaneInfo() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow
-
Returns the pane of this
FailsafeValueInSingleWindowin its window. - getPaneInfo() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
-
Returns the pane of this
ValueInSingleWindowin its window. - getPaneInfo() - Method in interface org.apache.beam.sdk.values.WindowedValue
-
The
PaneInfoassociated with this WindowedValue. - getPaneInfo() - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- getPaneInfo() - Method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
- getParamWindowedValueCoder(Coder<T>) - Static method in class org.apache.beam.sdk.values.WindowedValues
-
Returns the
ParamWindowedValueCoderfrom the given valueCoder. - getPath() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration
- getPath() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
- getPath() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
The path for the display item within a component hierarchy.
- getPayload() - Method in class org.apache.beam.sdk.schemas.io.Failure
-
Bytes containing the payload which has failed.
- getPayload() - Method in class org.apache.beam.sdk.schemas.logicaltypes.UnknownLogicalType
- getPayload() - Method in class org.apache.beam.sdk.util.construction.UnknownCoderWrapper
- getPayload(WindowedValues.ParamWindowedValueCoder<?>) - Static method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
-
Returns the serialized payload that will be provided when deserializing this coder.
- getPayload(T) - Method in interface org.apache.beam.sdk.util.construction.CoderTranslator
-
Returns the serialized payload that will be provided when deserializing this coder, if any.
- getPCollection() - Method in class org.apache.beam.sdk.util.construction.graph.PipelineNode.PCollectionNode
- getPCollection() - Method in class org.apache.beam.sdk.util.construction.RunnerPCollectionView
- getPCollection() - Method in interface org.apache.beam.sdk.values.PCollectionView
-
For internal use only.
- getPCollection() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
- getPCollection(String) - Method in class org.apache.beam.sdk.util.construction.RehydratedComponents
-
Returns a
PCollectionrehydrated from the Runner API component with the given ID. - getPercentileString(String, String) - Method in class org.apache.beam.sdk.util.HistogramData
- getPerDestinationOutputFilenames() - Method in class org.apache.beam.sdk.io.WriteFilesResult
-
Returns a
PCollectionof all output filenames generated by thisWriteFilesorganized by user destination type. - getPerElementConsumers(PipelineNode.PCollectionNode) - Method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
-
Get all of the
PTransformswhich consume the providedPipelineNode.PCollectionNodeon a per-element basis. - getPerElementInputPCollections(PipelineNode.PTransformNode) - Method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
-
Gets each
PipelineNode.PCollectionNodethat the providedPipelineNode.PTransformNodeconsumes on a per-element basis. - getPeriod() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
- getPeriod() - Method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform.AlignTo
- getPerWorkerCounter(MetricName) - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
-
Return the
Counterthat should be used for implementing the given per-worker {@code metricName) in this container. - getPipeline() - Method in class org.apache.beam.sdk.io.WriteFilesResult
- getPipeline() - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
- getPipeline() - Method in class org.apache.beam.sdk.runners.AppliedPTransform
- getPipeline() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
- getPipeline() - Method in class org.apache.beam.sdk.transforms.JsonToRow.ParseResult
- getPipeline() - Method in class org.apache.beam.sdk.transforms.WithFailures.Result
- getPipeline() - Method in class org.apache.beam.sdk.values.PBegin
- getPipeline() - Method in class org.apache.beam.sdk.values.PCollectionList
- getPipeline() - Method in class org.apache.beam.sdk.values.PCollectionRowTuple
- getPipeline() - Method in class org.apache.beam.sdk.values.PCollectionTuple
- getPipeline() - Method in class org.apache.beam.sdk.values.PDone
- getPipeline() - Method in interface org.apache.beam.sdk.values.PInput
- getPipeline() - Method in interface org.apache.beam.sdk.values.POutput
- getPipeline() - Method in class org.apache.beam.sdk.values.PValueBase
- getPipelineOptions() - Method in class org.apache.beam.sdk.options.DefaultPipelineOptionsRegistrar
- getPipelineOptions() - Method in class org.apache.beam.sdk.options.ManualDockerEnvironmentOptions.Options
- getPipelineOptions() - Method in interface org.apache.beam.sdk.options.PipelineOptionsRegistrar
- getPipelineOptions() - Method in class org.apache.beam.sdk.options.RemoteEnvironmentOptions.Options
- getPipelineOptions() - Method in interface org.apache.beam.sdk.state.StateContext
-
Returns the
PipelineOptionsspecified with thePipelineRunner. - getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.CombineWithContext.Context
- getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.DoFn.FinishBundleContext
- getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.DoFn.StartBundleContext
- getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
- getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHintsOptions.Options
- getPipelineOptions() - Method in class org.apache.beam.sdk.util.construction.ExternalTranslationOptionsRegistrar
- getPipelineResourcesDetector() - Method in interface org.apache.beam.sdk.util.construction.resources.PipelineResourcesDetector.Factory
- getPipelineResourcesDetector() - Method in class org.apache.beam.sdk.util.construction.resources.PipelineResourcesOptions.ClasspathScanningResourcesDetectorFactory
- getPipelineResourcesDetector() - Method in interface org.apache.beam.sdk.util.construction.resources.PipelineResourcesOptions
-
Instance of a pipeline resources detection algorithm.
- getPipelineResourcesDetectorFactoryClass() - Method in interface org.apache.beam.sdk.util.construction.resources.PipelineResourcesOptions
-
The class of the pipeline resources detector factory that should be created and used to create the detector.
- getPipelineRunners() - Method in interface org.apache.beam.sdk.runners.PipelineRunnerRegistrar
-
Get the set of
PipelineRunnersto register. - getPort() - Method in class org.apache.beam.sdk.fn.data.RemoteGrpcPortRead
- getPort() - Method in class org.apache.beam.sdk.fn.data.RemoteGrpcPortWrite
- getPositionForFractionConsumed(double) - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
-
Returns a position
Psuch that the range[start, P)represents approximately the given fraction of the range[start, end). - getPrefix() - Method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider.Configuration
- getPrimary() - Method in class org.apache.beam.sdk.transforms.splittabledofn.SplitResult
-
Returns the primary restriction.
- getProcessingTimeAdvance() - Method in class org.apache.beam.sdk.testing.TestStream.ProcessingTimeEvent
- getProcessWideContainer() - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
-
Return the
MetricsContainerfor the current process. - getProducer(PipelineNode.PCollectionNode) - Method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
- getProgress() - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.OutputRangeTracker
- getProgress() - Method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
- getProgress() - Method in class org.apache.beam.sdk.transforms.splittabledofn.GrowableOffsetRangeTracker
- getProgress() - Method in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
- getProgress() - Method in interface org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.HasProgress
-
A representation for the amount of known completed and known remaining work.
- getProperties() - Method in class org.apache.beam.sdk.util.ReleaseInfo
-
Returns an immutable map of all properties pertaining to this release.
- getProviderRuntimeValues() - Method in interface org.apache.beam.sdk.testing.TestPipeline.TestValueProviderOptions
- getPTransformIdOrThrow(AppliedPTransform<?, ?, ?>) - Method in class org.apache.beam.sdk.util.construction.SdkComponents
- getPythonCallableCode() - Method in class org.apache.beam.sdk.util.PythonCallableSource
- getQualifiers() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
- getRange() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
-
Returns the current range.
- getRangeFrom() - Method in interface org.apache.beam.sdk.util.HistogramData.BucketType
- getRangeFrom() - Method in class org.apache.beam.sdk.util.HistogramData.ExponentialBuckets
- getRangeFrom() - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
- getRangeFrom() - Method in class org.apache.beam.sdk.util.HistogramData.UnsupportedBuckets
- getRangeTo() - Method in interface org.apache.beam.sdk.util.HistogramData.BucketType
- getRangeTo() - Method in class org.apache.beam.sdk.util.HistogramData.ExponentialBuckets
- getRangeTo() - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
- getRangeTo() - Method in class org.apache.beam.sdk.util.HistogramData.UnsupportedBuckets
- getRate() - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration
- getRaw(ObjectT) - Method in interface org.apache.beam.sdk.schemas.FieldValueGetter
-
Returns the raw value of the getter before any further transformations.
- getRawType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
Returns the raw class type.
- getRawType() - Method in class org.apache.beam.sdk.values.TypeDescriptor
- getReason() - Method in exception org.apache.beam.sdk.coders.CannotProvideCoderException
- getReasons() - Method in exception org.apache.beam.sdk.coders.Coder.NonDeterministicException
- getReceiver() - Method in class org.apache.beam.sdk.fn.data.DataEndpoint
- getReceiver() - Method in class org.apache.beam.sdk.fn.data.TimerEndpoint
- getRecord() - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord
-
Information about the record that failed.
- getRecordId() - Method in interface org.apache.beam.sdk.values.WindowedValue
- getRecordId() - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- getRecordOffset() - Method in interface org.apache.beam.sdk.values.WindowedValue
- getRecordOffset() - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- getRecordType() - Method in class org.apache.beam.sdk.coders.SerializableCoder
- getRegisteredOptions() - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
- getReleaseInfo() - Static method in class org.apache.beam.sdk.util.ReleaseInfo
-
Returns an instance of
ReleaseInfo. - getRemoteHeapDumpLocation() - Method in interface org.apache.beam.sdk.options.MemoryMonitorOptions
-
A remote file system to upload captured heap dumps to.
- getRepeatedTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
- getReplacement() - Method in class org.apache.beam.sdk.runners.PTransformOverrideFactory.ReplacementOutput
- getReplacement(String, RunnerApi.ComponentsOrBuilder) - Method in interface org.apache.beam.sdk.util.construction.graph.ProtoOverrides.TransformReplacement
-
Returns the updated composite structure for the provided
RunnerApi.PTransform. - getReplacementTransform(AppliedPTransform<InputT, OutputT, TransformT>) - Method in interface org.apache.beam.sdk.runners.PTransformOverrideFactory
-
Returns a
PTransformthat produces equivalent output to the providedtransform. - getReplacementTransform(AppliedPTransform<InputT, OutputT, TransformT>) - Method in class org.apache.beam.sdk.util.construction.UnsupportedOverrideFactory
- getReplacementTransform(AppliedPTransform<PBegin, PCollection<T>, Create.Values<T>>) - Method in class org.apache.beam.sdk.util.construction.PrimitiveCreate.Factory
- getReplacementTransform(AppliedPTransform<PCollection<InputT>, PCollectionTuple, ParDo.MultiOutput<InputT, OutputT>>) - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.OverrideFactory
- getReplacementTransform(AppliedPTransform<PCollection<KV<byte[], KV<InputT, RestrictionT>>>, PCollectionTuple, SplittableParDo.ProcessKeyedElements<InputT, OutputT, RestrictionT, WatermarkEstimatorStateT>>) - Method in class org.apache.beam.sdk.util.construction.SplittableParDoNaiveBounded.OverrideFactory
- getReplacementTransform(AppliedPTransform<PCollectionList<T>, PCollection<T>, Flatten.PCollections<T>>) - Method in class org.apache.beam.sdk.util.construction.DeduplicatedFlattenFactory
- getReplacementTransform(AppliedPTransform<PCollectionList<T>, PCollection<T>, Flatten.PCollections<T>>) - Method in class org.apache.beam.sdk.util.construction.EmptyFlattenAsCreateFactory
- getRequirements() - Method in class org.apache.beam.sdk.transforms.Contextful
-
Returns the requirements needed to run the closure.
- getRequirements() - Method in class org.apache.beam.sdk.util.construction.graph.FusedPipeline
-
The
PTransformsthat a runner is responsible for executing. - getResidual() - Method in class org.apache.beam.sdk.transforms.splittabledofn.SplitResult
-
Returns the residual restriction.
- getResourceHints() - Method in class org.apache.beam.sdk.runners.AppliedPTransform
- getResourceHints() - Method in class org.apache.beam.sdk.transforms.PTransform
-
Returns resource hints set on the transform.
- getResourceHints() - Method in interface org.apache.beam.sdk.transforms.resourcehints.ResourceHintsOptions
- getRestrictionCoder() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.GetRestrictionCodermethod. - getRestrictionCoder() - Method in class org.apache.beam.sdk.transforms.Watch.WatchGrowthFn
- getRestrictionCoder() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElements
- GetRestrictionCoderMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetRestrictionCoderMethod
- getResult() - Method in class org.apache.beam.sdk.metrics.BoundedTrieResult
- getResult() - Method in class org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult
- getResults() - Method in class org.apache.beam.sdk.transforms.JsonToRow.ParseResult
-
Returns a
PCollectioncontaining theRows that have been parsed. - getRetainDockerContainers() - Method in interface org.apache.beam.sdk.options.ManualDockerEnvironmentOptions
- getRootCause() - Method in exception org.apache.beam.sdk.coders.CannotProvideCoderException
-
Returns the inner-most
CannotProvideCoderExceptionwhen they are deeply nested. - getRootClasses() - Method in class org.apache.beam.sdk.util.ApiSurface
-
Returns all public classes originally belonging to the package in the
ApiSurface. - getRootTransforms() - Method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
-
Get the transforms that are roots of this
QueryablePipeline. - getRow(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Rowvalue by field index,IllegalStateExceptionis thrown if schema doesn't match. - getRow(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.ROWvalue by field name,IllegalStateExceptionis thrown if schema doesn't match. - getRowReceiver(TupleTag<T>) - Method in interface org.apache.beam.sdk.transforms.DoFn.MultiOutputReceiver
-
Returns a
DoFn.OutputReceiverfor publishingRowobjects to the given tag. - getRowSchema() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
- getRowSelector(Schema, FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.utils.SelectHelpers
- getRowSelectorOptimized(Schema, FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.utils.SelectHelpers
- getRowToBytesFn(String) - Static method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformProvider
- getRowToJsonBytesFunction(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.JsonUtils
-
Returns a
SimpleFunctionmapping BeamRows to JSON byte[] arrays. - getRowToJsonStringsFunction(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.JsonUtils
- getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierContext
- getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionComponentContext
- getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionContext
- getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.FieldSpecifierContext
- getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierContext
- getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
- getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifierListContext
- getRuleNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- getRuleNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- getRunner() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
The pipeline runner that will be used to execute the pipeline.
- getRunnerExecutedTransforms() - Method in class org.apache.beam.sdk.util.construction.graph.FusedPipeline
-
The
PTransformsthat a runner is responsible for executing. - getSamplingStrategy() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
- getSavedValue() - Method in exception org.apache.beam.sdk.util.IllegalMutationException
-
The original value, before the illegal mutation.
- getScale() - Method in class org.apache.beam.sdk.util.HistogramData.ExponentialBuckets
- getScheduledExecutorService() - Method in interface org.apache.beam.sdk.options.ExecutorOptions
-
The
ScheduledExecutorServiceinstance to use to create threads, can be overridden to specify aScheduledExecutorServicethat is compatible with the user's environment. - getSchema() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
-
Returns the schema associated with this type.
- getSchema() - Method in class org.apache.beam.sdk.schemas.utils.ReflectUtils.ClassWithSchema
- getSchema() - Method in class org.apache.beam.sdk.schemas.utils.ReflectUtils.TypeDescriptorWithSchema
- getSchema() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
- getSchema() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
Returns the schema used by this
CoGbkResult. - getSchema() - Method in class org.apache.beam.sdk.values.PCollection
-
Returns the attached schema.
- getSchema() - Method in class org.apache.beam.sdk.values.Row.Builder
-
Return the schema for the row being built.
- getSchema() - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
- getSchema() - Method in class org.apache.beam.sdk.values.Row
-
Return
Schemawhich describes the fields. - getSchema(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Retrieve a
Schemafor a givenClasstype. - getSchema(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Retrieve a
Schemafor a givenTypeDescriptortype. - getSchemaCoder(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Retrieve a
SchemaCoderfor a givenClasstype. - getSchemaCoder(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Retrieve a
SchemaCoderfor a givenTypeDescriptortype. - getSchemaElementParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
- getSchemaInformation() - Method in class org.apache.beam.sdk.util.DoFnWithExecutionInformation
- getSchemaInformation(RunnerApi.ParDoPayload) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- getSchemaInformation(RunnerApi.PTransform) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- getSchemaInformation(AppliedPTransform<?, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- getSchemaProvider(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Retrieve a registered
SchemaProviderfor a givenClass. - getSchemaProvider(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Retrieve a registered
SchemaProviderfor a givenTypeDescriptor. - getSchemaProviders() - Method in class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProviderRegistrar
- getSchemaProviders() - Method in interface org.apache.beam.sdk.schemas.SchemaProviderRegistrar
-
Returns a list of
schema providerswhich will be registered by default within eachschema registryinstance. - getSchemaRegistry() - Method in class org.apache.beam.sdk.Pipeline
- getScheme() - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderResourceId
- getScheme() - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
- getScheme() - Method in class org.apache.beam.sdk.io.FileSystem
-
Get the URI scheme which defines the namespace of the
FileSystem. - getScheme() - Method in interface org.apache.beam.sdk.io.fs.ResourceId
-
Get the scheme which defines the namespace of the
ResourceId. - getSdkComponents(Collection<String>) - Method in class org.apache.beam.sdk.util.construction.RehydratedComponents
- getSdkHarnessLogLevelOverrides() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
-
This option controls the log levels for specifically named loggers.
- getSdkVersion() - Method in class org.apache.beam.sdk.util.ReleaseInfo
-
Provides the SDK version.
- getSdkWorkerId() - Method in interface org.apache.beam.sdk.fn.server.HeaderAccessor
-
This method should be called from the request method.
- getSdkWorkerParallelism() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- getSeconds() - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate
- getSecretBytes() - Method in class org.apache.beam.sdk.util.GcpSecret
-
Returns the secret as a byte array.
- getSecretBytes() - Method in interface org.apache.beam.sdk.util.Secret
-
Returns the secret as a byte array.
- getSemiPersistDir() - Method in interface org.apache.beam.sdk.options.RemoteEnvironmentOptions
- getSerializedATN() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- getSerializedATN() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- getSerializer(String, Schema, Map<String, Object>) - Static method in class org.apache.beam.sdk.schemas.io.payloads.PayloadSerializers
- getSerializer(Schema, Map<String, Object>) - Method in class org.apache.beam.sdk.schemas.io.payloads.JsonPayloadSerializerProvider
- getSerializer(Schema, Map<String, Object>) - Method in interface org.apache.beam.sdk.schemas.io.payloads.PayloadSerializerProvider
-
Get a PayloadSerializer.
- getServer() - Method in class org.apache.beam.sdk.fn.server.GrpcFnServer
-
Get the underlying
Servercontained by thisGrpcFnServer. - getService() - Method in class org.apache.beam.sdk.fn.server.GrpcFnServer
-
Get the service exposed by this
GrpcFnServer. - getSetFieldCreator(TypeDescriptor<T>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
- getSetters(TypeDescriptor<?>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
-
Return the list of
FieldValueSetters for a Java Bean class - getSetters(TypeDescriptor<T>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
- getShard() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
- getShardingFunction() - Method in class org.apache.beam.sdk.io.WriteFiles
- getShardNumber() - Method in class org.apache.beam.sdk.values.ShardedKey
-
Deprecated.
- getShardTemplate() - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration
- getShortValue() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
Return the optional short value for an item, or null if none is provided.
- getShortValue() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
The optional short value for an item, or
nullif none is provided. - getSideInputMapping() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElements
- getSideInputMapping() - Method in class org.apache.beam.sdk.util.DoFnInfo
- getSideInputMapping() - Method in class org.apache.beam.sdk.util.DoFnWithExecutionInformation
- getSideInputMapping(RunnerApi.ParDoPayload) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- getSideInputMapping(RunnerApi.PTransform) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- getSideInputMapping(AppliedPTransform<?, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- getSideInputParameters() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
- getSideInputs() - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
-
Override to specify that this object needs access to one or more side inputs.
- getSideInputs() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
Returns the side inputs used by this Combine operation.
- getSideInputs() - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
- getSideInputs() - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
-
Returns the side inputs used by this Combine operation.
- getSideInputs() - Method in class org.apache.beam.sdk.transforms.Combine.PerKeyWithHotKeyFanout
-
Returns the side inputs used by this Combine operation.
- getSideInputs() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
- getSideInputs() - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
- getSideInputs() - Method in class org.apache.beam.sdk.transforms.Requirements
-
The side inputs that this
Contextfulneeds access to. - getSideInputs() - Method in interface org.apache.beam.sdk.util.construction.graph.ExecutableStage
-
Returns a set of descriptors that will be accessed by this
ExecutableStageas side inputs. - getSideInputs() - Method in class org.apache.beam.sdk.util.construction.graph.ImmutableExecutableStage
- getSideInputs() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElements
- getSideInputs(AppliedPTransform<?, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- getSideInputs(PipelineNode.PTransformNode) - Method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
-
Returns the
SideInputReferencesthat the provided transform consumes as side inputs. - getSideInputViews() - Method in class org.apache.beam.sdk.util.AppliedCombineFn
- getSideInputViews() - Method in class org.apache.beam.sdk.util.DoFnInfo
- getSideInputWindow(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.WindowMappingFn
-
Returns the window of the side input corresponding to the given window of the main input.
- getSignature(Class<FnT>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- getSingleFileMetadata() - Method in class org.apache.beam.sdk.io.FileBasedSource
-
Returns the information about the single file that this source is reading from.
- getSinglePCollection() - Method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
Like
PCollectionRowTuple.get(String), but is a convenience method to get a single PCollection without providing a tag for that output. - getSingletonConsumers(PipelineNode.PCollectionNode) - Method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
-
Same as
QueryablePipeline.getPerElementConsumers(PipelineNode.PCollectionNode), but returns transforms that consume the collection as a singleton. - getSingletonMainInput(AppliedPTransform<? extends PCollection<? extends T>, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.PTransformReplacements
-
Gets the singleton input of an
AppliedPTransform, ignoring any additional inputs returned byPTransform.getAdditionalInputs(). - getSingletonMainOutput(AppliedPTransform<?, PCollection<T>, ? extends PTransform<?, PCollection<T>>>) - Static method in class org.apache.beam.sdk.util.construction.PTransformReplacements
- getSink() - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
-
Returns the FileBasedSink for this write operation.
- getSink() - Method in class org.apache.beam.sdk.io.WriteFiles
- getSink(AppliedPTransform<PCollection<UserT>, WriteFilesResult<DestinationT>, ? extends PTransform<PCollection<UserT>, WriteFilesResult<DestinationT>>>) - Static method in class org.apache.beam.sdk.util.construction.WriteFilesTranslation
- getSinks() - Static method in class org.apache.beam.sdk.metrics.Lineage
-
Lineagerepresenting sinks. - getSize() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.GetSizemethod. - getSize() - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
- getSize() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
- GetSizeMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetSizeMethod
- getSkipHeaderLines() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
- getSource() - Method in class org.apache.beam.sdk.io.Read.Bounded
-
Returns the
BoundedSourceused to create thisReadPTransform. - getSource() - Method in class org.apache.beam.sdk.io.Read.Unbounded
-
Returns the
UnboundedSourceused to create thisReadPTransform. - getSource() - Method in class org.apache.beam.sdk.io.TextIO.Read
- getSource() - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
- getSource() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.PrimitiveBoundedRead
- getSource() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.PrimitiveUnboundedRead
- getSources() - Static method in class org.apache.beam.sdk.metrics.Lineage
-
Lineagerepresenting sources and optionally side inputs. - getSpec() - Method in class org.apache.beam.sdk.util.construction.PTransformTranslation.RawPTransform
-
The payload for this transform, if any.
- getSplitBacklogBytes() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
-
Returns the size of the backlog of unread data in the underlying data source represented by this split of this source.
- getSplitPointsConsumed() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
-
Returns the total amount of parallelism in the consumed (returned and processed) range of this reader's current
BoundedSource(as would be returned byBoundedSource.BoundedReader.getCurrentSource()). - getSplitPointsConsumed() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
- getSplitPointsConsumed() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
- getSplitPointsConsumed() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
- getSplitPointsProcessed() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
-
Returns the total number of split points that have been processed.
- getSplitPointsRemaining() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
-
Returns the total amount of parallelism in the unprocessed part of this reader's current
BoundedSource(as would be returned byBoundedSource.BoundedReader.getCurrentSource()). - getSplitPointsRemaining() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
- getSplitPointsRemaining() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
- getStableUniqueNames() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
Whether to check for stable unique names on each transform.
- getStart() - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration
- getStart() - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
- getStartDate() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
- getStartDate() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
- getStartDate() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
- getStartKey() - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
-
Returns the
ByteKeyrepresenting the lower bound of thisByteKeyRange. - getStartOffset() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
-
Returns the starting offset of the source.
- getStartPosition() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
- getStartPosition() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
- getStartPosition() - Method in interface org.apache.beam.sdk.io.range.RangeTracker
-
Returns the starting position of the current range, inclusive.
- getStartTime() - Method in class org.apache.beam.sdk.io.CountingSource.CounterMark
-
Returns the time the reader was started.
- getState() - Method in interface org.apache.beam.sdk.PipelineResult
-
Retrieves the current state of the pipeline execution.
- getState() - Method in interface org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimator
-
Get current state of the
WatermarkEstimatorinstance, which can be used to recreate theWatermarkEstimatorwhen processing the restriction. - getState() - Method in class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.Manual
- getState() - Method in class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.MonotonicallyIncreasing
- getState() - Method in class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.WallTime
- getStateCoder() - Method in interface org.apache.beam.sdk.transforms.Watch.Growth.TerminationCondition
-
Used to encode the state of this
Watch.Growth.TerminationCondition. - getStateSpecOrThrow(DoFnSignature.StateDeclaration, DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- getStaticCreator(TypeDescriptor<?>, Method, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
- getStaticCreator(TypeDescriptor<?>, Method, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
- getStopPosition() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
- getStopPosition() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
- getStopPosition() - Method in interface org.apache.beam.sdk.io.range.RangeTracker
-
Returns the ending position of the current range, exclusive.
- getString(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Stringvalue by field index,ClassCastExceptionis thrown if schema doesn't match. - getString(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.STRINGvalue by field name,IllegalStateExceptionis thrown if schema doesn't match. - getStringSet() - Method in class org.apache.beam.sdk.metrics.StringSetResult.EmptyStringSetResult
-
Returns an empty immutable set.
- getStringSet() - Method in class org.apache.beam.sdk.metrics.StringSetResult
- getStringSet(MetricName) - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
-
Return the
StringSetthat should be used for implementing the givenmetricNamein this container. - getStringSets() - Method in class org.apache.beam.sdk.metrics.MetricQueryResults
-
Return the metric results for the sets that matched the filter.
- getSubtype(Class<? extends T>) - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns the generic form of a subtype.
- getSuggestedFilenameSuffix() - Method in enum org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.
- getSuggestedFilenameSuffix() - Method in interface org.apache.beam.sdk.io.FileBasedSink.OutputFileHints
- getSuggestedSuffix() - Method in enum org.apache.beam.sdk.io.Compression
- getSum() - Method in class org.apache.beam.sdk.metrics.DistributionResult
- getSum() - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
- getSumAndReset() - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
- getSumOfSquaredDeviations() - Method in class org.apache.beam.sdk.util.HistogramData
- getSupertype(Class<? super T>) - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns the generic form of a supertype.
- getTag() - Method in class org.apache.beam.sdk.values.TaggedPValue
-
Returns the local tag associated with the
PValue. - getTag(int) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
-
Returns the tuple tag at the given index.
- getTagInternal() - Method in class org.apache.beam.sdk.util.construction.RunnerPCollectionView
- getTagInternal() - Method in interface org.apache.beam.sdk.values.PCollectionView
-
Deprecated.this method will be removed entirely. The
PCollectionunderlying a side input, is part of the side input's specification with aParDotransform, which will obtain that information via a package-private channel. - getTagInternal() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
-
Returns a unique
TupleTagidentifying thisPCollectionView. - getTempDirectory() - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
- getTempDirectoryProvider() - Method in class org.apache.beam.sdk.io.FileBasedSink
-
Returns the directory inside which temporary files will be written according to the configured
FileBasedSink.FilenamePolicy. - getTempFilename() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
- getTempLocation() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
A pipeline level default location for storing temporary files.
- getTempRoot() - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
- GETTER_WITH_NULL_METHOD_ERROR - Static variable in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
- GetterBasedSchemaProvider - Class in org.apache.beam.sdk.schemas
-
Deprecated.new implementations should extend the
GetterBasedSchemaProviderV2class' methods which receiveTypeDescriptors instead of ordinaryClasses as arguments, which permits to support generic type signatures during schema inference - GetterBasedSchemaProvider() - Constructor for class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
-
Deprecated.
- GetterBasedSchemaProviderV2 - Class in org.apache.beam.sdk.schemas
-
A newer version of
GetterBasedSchemaProvider, which works withTypeDescriptors, and which by default delegates the old,Classbased methods, to the new ones. - GetterBasedSchemaProviderV2() - Constructor for class org.apache.beam.sdk.schemas.GetterBasedSchemaProviderV2
- GetterTypeSupplier() - Constructor for class org.apache.beam.sdk.schemas.JavaBeanSchema.GetterTypeSupplier
- getTestStream(AppliedPTransform<PBegin, PCollection<T>, PTransform<PBegin, PCollection<T>>>) - Static method in class org.apache.beam.sdk.util.construction.TestStreamTranslation
-
Converts an
AppliedPTransform, which may be a rehydrated transform or an originalTestStream, to aTestStream. - getTestTimeoutSeconds() - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
- getThrowable() - Method in class org.apache.beam.sdk.util.SerializableThrowable
- getTimeDomain() - Method in interface org.apache.beam.sdk.state.TimerSpec
- getTimerFamilyId() - Method in class org.apache.beam.sdk.fn.data.LogicalEndpoint
- getTimerFamilyId() - Method in class org.apache.beam.sdk.fn.data.TimerEndpoint
- getTimerFamilySpecOrThrow(DoFnSignature.TimerFamilyDeclaration, DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- getTimers() - Method in interface org.apache.beam.sdk.util.construction.graph.ExecutableStage
-
Returns the set of descriptors that will consume and produce timers by this
ExecutableStage. - getTimers() - Method in class org.apache.beam.sdk.util.construction.graph.ImmutableExecutableStage
- getTimers(PipelineNode.PTransformNode) - Method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
- getTimerSpecOrThrow(DoFnSignature.TimerDeclaration, DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- getTimestamp() - Method in class org.apache.beam.sdk.metrics.GaugeResult.EmptyGaugeResult
- getTimestamp() - Method in class org.apache.beam.sdk.metrics.GaugeResult
- getTimestamp() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow
-
Returns the timestamp of this
FailsafeValueInSingleWindow. - getTimestamp() - Method in class org.apache.beam.sdk.values.TimestampedValue
- getTimestamp() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
-
Returns the timestamp of this
ValueInSingleWindow. - getTimestamp() - Method in interface org.apache.beam.sdk.values.WindowedValue
-
The timestamp of this value in event time.
- getTimestamp() - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- getTimestamp() - Method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
- getTimestampCombiner() - Method in interface org.apache.beam.sdk.state.WatermarkHoldState
-
Return the
TimestampCombinerwhich will be used to determine a watermark hold time given an element timestamp, and to combine watermarks from windows which are about to be merged. - getTimestampCombiner() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- getTimestampTransforms() - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
-
The transforms applied to the arrival time of an element to determine when this trigger allows output.
- getTimeZone() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
- getTimeZone() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
- getTimeZone() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
- getTiming() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
Return the timing of this pane.
- getTo() - Method in class org.apache.beam.sdk.io.range.OffsetRange
- getTokenNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
-
Deprecated.
- getTokenNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
-
Deprecated.
- getToKV() - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
- getTopBucketCount() - Method in class org.apache.beam.sdk.util.HistogramData
- getTopBucketMean() - Method in class org.apache.beam.sdk.util.HistogramData
- getTopologicallyOrderedTransforms() - Method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
- getToRowFunction() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
-
Returns the fromRow conversion function.
- getToRowFunction() - Method in class org.apache.beam.sdk.values.PCollection
-
Returns the attached schema's toRowFunction.
- getToRowFunction(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Retrieve the function that converts an object of the specified type to a
Rowobject. - getToRowFunction(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Retrieve the function that converts an object of the specified type to a
Rowobject. - getTotalBacklogBytes() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
-
Returns the size of the backlog of unread data in the underlying data source represented by all splits of this source.
- getTotalCount() - Method in class org.apache.beam.sdk.util.HistogramData
- getTransform() - Method in class org.apache.beam.sdk.runners.AppliedPTransform
- getTransform() - Method in class org.apache.beam.sdk.runners.PTransformOverrideFactory.PTransformReplacement
- getTransform() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
-
Returns the transform associated with this transform node.
- getTransform() - Method in class org.apache.beam.sdk.util.construction.graph.PipelineNode.PTransformNode
- getTransformId() - Method in class org.apache.beam.sdk.fn.data.DataEndpoint
- getTransformId() - Method in class org.apache.beam.sdk.fn.data.LogicalEndpoint
- getTransformId() - Method in class org.apache.beam.sdk.fn.data.TimerEndpoint
- getTransformingMap(Map<K1, V1>, Function<K1, K2>, Function<V1, V2>) - Static method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils
- getTransformPayloadTranslators() - Method in class org.apache.beam.sdk.io.TFRecordSchemaTransformTranslation.ReadWriteRegistrar
- getTransformPayloadTranslators() - Method in class org.apache.beam.sdk.transforms.Redistribute.Registrar
- getTransformPayloadTranslators() - Method in class org.apache.beam.sdk.util.construction.CombineTranslation.Registrar
- getTransformPayloadTranslators() - Method in class org.apache.beam.sdk.util.construction.CreatePCollectionViewTranslation.Registrar
-
Deprecated.
- getTransformPayloadTranslators() - Method in class org.apache.beam.sdk.util.construction.FlattenTranslator.Registrar
- getTransformPayloadTranslators() - Method in class org.apache.beam.sdk.util.construction.GroupByKeyTranslation.Registrar
- getTransformPayloadTranslators() - Method in class org.apache.beam.sdk.util.construction.GroupIntoBatchesTranslation.Registrar
- getTransformPayloadTranslators() - Method in class org.apache.beam.sdk.util.construction.ImpulseTranslation.Registrar
- getTransformPayloadTranslators() - Method in class org.apache.beam.sdk.util.construction.ReadTranslation.Registrar
- getTransformPayloadTranslators() - Method in class org.apache.beam.sdk.util.construction.ReshuffleTranslation.Registrar
- getTransformPayloadTranslators() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.Registrar
- getTransformPayloadTranslators() - Method in interface org.apache.beam.sdk.util.construction.TransformPayloadTranslatorRegistrar
- getTransformPayloadTranslators() - Method in class org.apache.beam.sdk.util.construction.WindowIntoTranslation.Registrar
- getTransformPayloadTranslators() - Method in class org.apache.beam.sdk.util.construction.WriteFilesTranslation.Registrar
- getTransforms() - Method in interface org.apache.beam.sdk.util.construction.graph.ExecutableStage
-
Get the transforms that perform processing within this
ExecutableStage. - getTransforms() - Method in class org.apache.beam.sdk.util.construction.graph.ImmutableExecutableStage
- getTransforms() - Method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
- getTransformServiceAddress() - Method in interface org.apache.beam.sdk.util.construction.ExternalTranslationOptions
- getTransformServiceBeamVersion() - Method in interface org.apache.beam.sdk.util.construction.ExternalTranslationOptions
- getTransformsToOverride() - Method in interface org.apache.beam.sdk.util.construction.ExternalTranslationOptions
- getTrigger() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- getTruncatedRestriction() - Method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.TruncateResult
- getTupleTag() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple.TaggedKeyedPCollection
-
Returns the TupleTag of this TaggedKeyedPCollection.
- getTupleTagList() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
-
Returns the TupleTagList tuple associated with this schema.
- getType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
Returns the field type.
- getType() - Method in class org.apache.beam.sdk.schemas.Schema.Field
-
Returns the fields
Schema.FieldType. - getType() - Method in interface org.apache.beam.sdk.testing.TestStream.Event
- getType() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
Retrieve the
DisplayData.Typeof display data. - getType() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
The
DisplayData.Typeof display data. - getType() - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns the
Typerepresented by thisTypeDescriptor. - getType(String) - Method in class org.apache.beam.sdk.schemas.Schema.Options
-
Get the type of an option.
- getTypeDescriptor() - Method in class org.apache.beam.sdk.schemas.utils.ReflectUtils.TypeDescriptorWithSchema
- getTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.ViewFn
-
Return the
TypeDescriptordescribing the output of this fn. - getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollection
-
Returns a
TypeDescriptor<T>with some reflective information aboutT, if possible. - getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryListFromMultimapViewFn
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryListViewFn
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMapFromVoidKeyViewFn
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMapViewFn
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMultimapFromVoidKeyViewFn
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMultimapViewFn
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableBackedListViewFn
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn
-
Deprecated.
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn2
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.ListViewFn
-
Deprecated.
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.ListViewFn2
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.MapViewFn
-
Deprecated.
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.MapViewFn2
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn
-
Deprecated.
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn2
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
-
Deprecated.
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn2
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.TupleTag
-
Returns a
TypeDescriptorcapturing what is known statically about the type of thisTupleTaginstance's most-derived class. - getTypeName() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
- getTypeParameter(String) - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns a
TypeVariablefor the named type parameter. - getTypes() - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns a set of
TypeDescriptor, one for each superclass as well as each interface implemented by this class. - getUnderlyingSchemaProvider(Class<T>) - Method in class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProvider
-
Retrieves the underlying
SchemaProviderfor the givenClass. - getUnderlyingSchemaProvider(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProvider
-
Retrieves the underlying
SchemaProviderfor the givenTypeDescriptor. - getUnfinishedEndpoints() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataInboundObserver
-
Get all unfinished data and timers endpoints represented as [transform_id]:data and [transform_id]:timers:[timer_family_id].
- getUnionCoder() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
- getUnionTag() - Method in class org.apache.beam.sdk.transforms.join.RawUnionValue
- getUntilTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
-
The trigger that signals termination of this trigger.
- getUpdateCompatibilityVersion() - Method in interface org.apache.beam.sdk.options.StreamingOptions
- getUrn() - Method in class org.apache.beam.sdk.schemas.transforms.SchemaTransformTranslation.SchemaTransformPayloadTranslator
- getUrn() - Method in interface org.apache.beam.sdk.transforms.Materialization
-
Gets the URN describing this
Materialization. - getUrn() - Method in class org.apache.beam.sdk.util.construction.CombineTranslation.CombineGloballyPayloadTranslator
- getUrn() - Method in class org.apache.beam.sdk.util.construction.CombineTranslation.CombineGroupedValuesPayloadTranslator
- getUrn() - Method in class org.apache.beam.sdk.util.construction.CombineTranslation.CombinePerKeyPayloadTranslator
- getUrn() - Method in class org.apache.beam.sdk.util.construction.FlattenTranslator
- getUrn() - Method in class org.apache.beam.sdk.util.construction.PTransformTranslation.RawPTransform
-
The URN for this transform, if standardized.
- getUrn() - Method in interface org.apache.beam.sdk.util.construction.PTransformTranslation.TransformPayloadTranslator
-
Provides a unique URN for transforms represented by this
TransformPayloadTranslator. - getUrn() - Method in class org.apache.beam.sdk.util.construction.ReadTranslation.BoundedReadPayloadTranslator
- getUrn() - Method in class org.apache.beam.sdk.util.construction.ReadTranslation.UnboundedReadPayloadTranslator
- getUrn() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElementsTranslator
- getUrn() - Method in class org.apache.beam.sdk.util.construction.UnknownCoderWrapper
- getUrn() - Method in class org.apache.beam.sdk.util.construction.WindowIntoTranslation.WindowIntoPayloadTranslator
- getUrn(Combine.PerKey<?, ?, ?>) - Method in class org.apache.beam.sdk.util.construction.CombineTranslation.CombinePerKeyPayloadTranslator
- getUrn(ParDo.MultiOutput<?, ?>) - Method in class org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoTranslator
- getUrn(External.ExpandableTransform) - Method in class org.apache.beam.sdk.util.construction.ExternalTranslation.ExternalTranslator
- getUrn(ProtocolMessageEnum) - Static method in class org.apache.beam.sdk.util.construction.BeamUrns
-
Returns the standard URN of a given enum annotated with [(standard_urn)].
- getUrn(T) - Method in interface org.apache.beam.sdk.util.construction.PTransformTranslation.TransformPayloadTranslator
-
Same as
PTransformTranslation.TransformPayloadTranslator.getUrn()but the returned URN may depend on the transform provided. - getUrn(T) - Method in interface org.apache.beam.sdk.util.construction.PTransformTranslation.TransformTranslator
- getUserAgent() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
A user agent string as per RFC2616, describing the pipeline to external services.
- getUserKey() - Method in class org.apache.beam.sdk.util.construction.Timer
-
Returns the key that the timer is set on.
- getUserStates() - Method in interface org.apache.beam.sdk.util.construction.graph.ExecutableStage
-
Returns the set of descriptors that will consume and produce user state by this
ExecutableStage. - getUserStates() - Method in class org.apache.beam.sdk.util.construction.graph.ImmutableExecutableStage
- getUserStates(PipelineNode.PTransformNode) - Method in class org.apache.beam.sdk.util.construction.graph.QueryablePipeline
- getUUID() - Method in class org.apache.beam.sdk.schemas.Schema
-
Get this schema's UUID.
- getValidate() - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformConfiguration
- getValue() - Method in class org.apache.beam.sdk.coders.StructuralByteArray
- getValue() - Method in class org.apache.beam.sdk.io.range.ByteKey
-
Returns a read-only
ByteBufferrepresenting thisByteKey. - getValue() - Method in class org.apache.beam.sdk.metrics.GaugeResult.EmptyGaugeResult
- getValue() - Method in class org.apache.beam.sdk.metrics.GaugeResult
- getValue() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType.Value
-
Return the integer enum value.
- getValue() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
-
Returns the current value of the OneOf.
- getValue() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
Retrieve the value of the display item.
- getValue() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
The value of the display item.
- getValue() - Method in class org.apache.beam.sdk.transforms.join.RawUnionValue
- getValue() - Method in class org.apache.beam.sdk.util.WeightedValue
- getValue() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow
-
Returns the value of this
FailsafeValueInSingleWindow. - getValue() - Method in class org.apache.beam.sdk.values.KV
-
Returns the value of this
KV. - getValue() - Method in class org.apache.beam.sdk.values.TaggedPValue
-
Returns the
PCollection. - getValue() - Method in class org.apache.beam.sdk.values.TimestampedValue
- getValue() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
-
Returns the value of this
ValueInSingleWindow. - getValue() - Method in class org.apache.beam.sdk.values.ValueWithRecordId
- getValue() - Method in interface org.apache.beam.sdk.values.WindowedValue
-
The primary data for this value.
- getValue() - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- getValue(int) - Method in class org.apache.beam.sdk.values.Row
-
Get value by field index,
ClassCastExceptionis thrown if schema doesn't match. - getValue(int) - Method in class org.apache.beam.sdk.values.RowWithGetters
- getValue(int) - Method in class org.apache.beam.sdk.values.RowWithStorage
- getValue(Class<T>) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
-
Returns the current value of the OneOf as the destination type.
- getValue(String) - Method in class org.apache.beam.sdk.schemas.Schema.Options
-
Get the value of an option.
- getValue(String) - Method in class org.apache.beam.sdk.values.Row
-
Get value by field name,
ClassCastExceptionis thrown if type doesn't match. - getValue(String, Class<T>) - Method in class org.apache.beam.sdk.schemas.Schema.Options
-
Get the value of an option.
- getValueCoder() - Method in class org.apache.beam.sdk.coders.KvCoder
- getValueCoder() - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
-
Gets the value coder that will be prefixed by the length.
- getValueCoder() - Method in class org.apache.beam.sdk.coders.MapCoder
- getValueCoder() - Method in class org.apache.beam.sdk.coders.NullableCoder
-
Returns the inner
Coderwrapped by thisNullableCoderinstance. - getValueCoder() - Method in class org.apache.beam.sdk.coders.OptionalCoder
-
Returns the inner
Coderwrapped by thisOptionalCoderinstance. - getValueCoder() - Method in class org.apache.beam.sdk.coders.SortedMapCoder
- getValueCoder() - Method in class org.apache.beam.sdk.testing.TestStream
- getValueCoder() - Method in class org.apache.beam.sdk.util.construction.Timer.Coder
- getValueCoder() - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
- getValueCoder() - Method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
- getValueCoder() - Method in class org.apache.beam.sdk.values.WindowedValues.WindowedValueCoder
-
Returns the value coder.
- getValueOnlyCoder(Coder<T>) - Static method in class org.apache.beam.sdk.values.WindowedValues
-
Returns the
ValueOnlyCoderfrom the given valueCoder. - getValueOrDefault(String, T) - Method in class org.apache.beam.sdk.schemas.Schema.Options
-
Get the value of an option.
- getValues() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
- getValues() - Method in class org.apache.beam.sdk.values.Row
-
Return the list of raw unmodified data values to enable 0-copy code.
- getValues() - Method in class org.apache.beam.sdk.values.RowWithGetters
-
Return the list of raw unmodified data values to enable 0-copy code.
- getValues() - Method in class org.apache.beam.sdk.values.RowWithStorage
- getValuesMap() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
- getVersion() - Method in class org.apache.beam.sdk.util.ReleaseInfo
-
Provides the BEAM version e.g.
- getVersionName() - Method in class org.apache.beam.sdk.util.GcpSecret
-
Returns the version name of the secret.
- getView() - Method in class org.apache.beam.sdk.transforms.View.CreatePCollectionView
-
Deprecated.This should not be used to obtain the output of any given application of this
PTransform. That should be obtained by inspecting theTransformHierarchy.Nodethat contains thisView.CreatePCollectionView, as this view may have been replaced within pipeline surgery. - getView(AppliedPTransform<PCollection<ElemT>, PCollection<ElemT>, PTransform<PCollection<ElemT>, PCollection<ElemT>>>) - Static method in class org.apache.beam.sdk.util.construction.CreatePCollectionViewTranslation
-
Deprecated.Since
View.CreatePCollectionViewis not a part of the Beam model, there is no SDK-agnostic specification. Using this method means your runner is tied to Java. - getViewFn() - Method in class org.apache.beam.sdk.util.construction.RunnerPCollectionView
- getViewFn() - Method in interface org.apache.beam.sdk.values.PCollectionView
- getViewFn() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
- getVocabulary() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- getVocabulary() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- getWatchInterval() - Method in class org.apache.beam.sdk.io.FileIO.MatchConfiguration
- getWatermark() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
-
Returns a timestamp before or at the timestamps of all future elements read by this reader.
- getWatermark() - Method in class org.apache.beam.sdk.testing.TestStream.WatermarkEvent
- getWatermarkAndState() - Method in interface org.apache.beam.sdk.fn.splittabledofn.WatermarkEstimators.WatermarkAndStateObserver
- getWatermarkEstimatorStateCoder() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.GetWatermarkEstimatorStateCodermethod. - getWatermarkEstimatorStateCoder() - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElements
- GetWatermarkEstimatorStateCoderMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetWatermarkEstimatorStateCoderMethod
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterAll
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterEach
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterFirst
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.Never.NeverTrigger
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.ReshuffleTrigger
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
-
For internal use only; no backwards-compatibility guarantees.
- getWeigher(Coder<InputT>) - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches.BatchingParams
- getWeight() - Method in class org.apache.beam.sdk.fn.data.WeightedList
- getWeight() - Method in interface org.apache.beam.sdk.util.Weighted
-
Returns the weight of the object.
- getWeight() - Method in class org.apache.beam.sdk.util.WeightedValue
- getWidth() - Method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
- getWindow() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
- getWindow() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow
-
Returns the window of this
FailsafeValueInSingleWindow. - getWindow() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
-
Returns the window of this
ValueInSingleWindow. - getWindow() - Method in interface org.apache.beam.sdk.values.WindowedValues.SingleWindowedValue
- getWindowCoder() - Method in class org.apache.beam.sdk.coders.TimestampPrefixingWindowCoder
- getWindowCoder() - Method in class org.apache.beam.sdk.util.construction.Timer.Coder
- getWindowCoder() - Method in class org.apache.beam.sdk.values.WindowedValues.FullWindowedValueCoder
- getWindowedValueCoderComponents(RunnerApi.Coder) - Static method in class org.apache.beam.sdk.util.construction.ModelCoders
- getWindowedWrites() - Method in class org.apache.beam.sdk.io.WriteFiles
- getWindowFn() - Method in class org.apache.beam.sdk.transforms.windowing.Window.Assign
- getWindowFn() - Method in class org.apache.beam.sdk.transforms.windowing.Window
- getWindowFn() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- getWindowFn(AppliedPTransform<?, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.WindowIntoTranslation
- getWindowingStrategy() - Method in class org.apache.beam.sdk.util.AppliedCombineFn
- getWindowingStrategy() - Method in class org.apache.beam.sdk.util.DoFnInfo
- getWindowingStrategy() - Method in class org.apache.beam.sdk.values.PCollection
-
Returns the
WindowingStrategyof thisPCollection. - getWindowingStrategy(String) - Method in class org.apache.beam.sdk.util.construction.RehydratedComponents
-
Returns a
WindowingStrategyrehydrated from the Runner API component with the given ID. - getWindowingStrategyInternal() - Method in class org.apache.beam.sdk.util.construction.RunnerPCollectionView
- getWindowingStrategyInternal() - Method in interface org.apache.beam.sdk.values.PCollectionView
-
Deprecated.this method will be removed entirely. The
PCollectionunderlying a side input, including itsWindowingStrategy, is part of the side input's specification with aParDotransform, which will obtain that information via a package-private channel. - getWindowingStrategyInternal() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
-
Returns the
WindowingStrategyof thisPCollectionView, which should be that of the underlyingPCollection. - getWindowIntoPayload(AppliedPTransform<?, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.WindowIntoTranslation
- getWindowMappingFn() - Method in class org.apache.beam.sdk.util.construction.RunnerPCollectionView
- getWindowMappingFn() - Method in interface org.apache.beam.sdk.values.PCollectionView
-
For internal use only.
- getWindowMappingFn() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
- getWindows() - Method in class org.apache.beam.sdk.util.construction.Timer
-
Returns the windows which are associated with the timer.
- getWindows() - Method in interface org.apache.beam.sdk.values.WindowedValue
-
Returns the windows of this
WindowedValue. - getWindows() - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- getWindows() - Method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
- getWindowsCoder() - Method in class org.apache.beam.sdk.util.construction.Timer.Coder
- getWindowsCoder() - Method in class org.apache.beam.sdk.values.WindowedValues.FullWindowedValueCoder
- getWindowTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
- getWindowTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
Returns a
TypeDescriptorcapturing what is known statically about the window type of thisWindowFninstance's most-derived class. - getWireCoderSettings() - Method in interface org.apache.beam.sdk.util.construction.graph.ExecutableStage
-
Returns a set of
RunnerApi.ExecutableStagePayload.WireCoderSettings this stage executes in. - getWireCoderSettings() - Method in class org.apache.beam.sdk.util.construction.graph.ImmutableExecutableStage
- getWithAutoSharding() - Method in class org.apache.beam.sdk.io.WriteFiles
- getWorkCompleted() - Method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.Progress
-
The known amount of completed work.
- getWorkRemaining() - Method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.Progress
-
The known amount of work remaining.
- getWritableByteChannelFactory() - Method in class org.apache.beam.sdk.io.FileBasedSink
-
Returns the
FileBasedSink.WritableByteChannelFactoryused. - getWriteOperation() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
-
Return the WriteOperation that this Writer belongs to.
- Global() - Constructor for class org.apache.beam.sdk.schemas.transforms.Group.Global
- GLOBAL_WINDOW_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- GLOBAL_WINDOWS_URN - Static variable in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- globalDefault() - Static method in class org.apache.beam.sdk.values.WindowingStrategy
-
Return a fully specified, default windowing strategy.
- globally() - Static method in class org.apache.beam.sdk.schemas.transforms.Group
-
Returns a transform that groups all elements in the input
PCollection. - globally() - Static method in class org.apache.beam.sdk.transforms.Count
-
Returns a
PTransformthat counts the number of elements in its inputPCollection. - globally() - Static method in class org.apache.beam.sdk.transforms.Latest
-
Returns a
PTransformthat takes as input aPCollection<T>and returns aPCollection<T>whose contents is the latest element according to its event time, or null if there are no elements. - globally() - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a
PTransformthat takes an inputPCollection<T>and returns aPCollection<T>whose contents is the maximum according to the natural ordering ofTof the inputPCollection's elements, ornullif there are no elements. - globally() - Static method in class org.apache.beam.sdk.transforms.Mean
-
Returns a
PTransformthat takes an inputPCollection<NumT>and returns aPCollection<Double>whose contents is the mean of the inputPCollection's elements, or0if there are no elements. - globally() - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a
PTransformthat takes an inputPCollection<T>and returns aPCollection<T>whose contents is the minimum according to the natural ordering ofTof the inputPCollection's elements, ornullif there are no elements. - globally(double) - Static method in class org.apache.beam.sdk.transforms.ApproximateUnique
-
Deprecated.Like
ApproximateUnique.globally(int), but specifies the desired maximum estimation error instead of the sample size. - globally(int) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles
-
Like
ApproximateQuantiles.globally(int, Comparator), but sorts using the elements' natural ordering. - globally(int) - Static method in class org.apache.beam.sdk.transforms.ApproximateUnique
-
Deprecated.Returns a
PTransformthat takes aPCollection<T>and returns aPCollection<Long>containing a single value that is an estimate of the number of distinct elements in the inputPCollection. - globally(int, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles
-
Returns a
PTransformthat takes aPCollection<T>and returns aPCollection<List<T>>whose single value is aListof the approximateN-tiles of the elements of the inputPCollection. - globally(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a
PTransformthat takes an inputPCollection<T>and returns aPCollection<T>whose contents is the maximum of the inputPCollection's elements, ornullif there are no elements. - globally(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a
PTransformthat takes an inputPCollection<T>and returns aPCollection<T>whose contents is the minimum of the inputPCollection's elements, ornullif there are no elements. - globally(CombineFnBase.GlobalCombineFn<? super InputT, ?, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.GloballyPTransformthat uses the givenGloballyCombineFnto combine all the elements in each window of the inputPCollectioninto a single value in the outputPCollection. - globally(SerializableBiFunction<V, V, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.GloballyPTransformthat uses the givenSerializableBiFunctionto combine all the elements in each window of the inputPCollectioninto a single value in the outputPCollection. - globally(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.GloballyPTransformthat uses the givenSerializableFunctionto combine all the elements in each window of the inputPCollectioninto a single value in the outputPCollection. - Globally(double) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.Globally
-
Deprecated.
- Globally(int) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.Globally
-
Deprecated.
- GlobalWindow - Class in org.apache.beam.sdk.transforms.windowing
-
The default window into which all data is placed (via
GlobalWindows). - GlobalWindow.Coder - Class in org.apache.beam.sdk.transforms.windowing
-
GlobalWindow.Coderfor encoding and decodingGlobalWindows. - GlobalWindows - Class in org.apache.beam.sdk.transforms.windowing
-
A
WindowFnthat assigns all data to the same window. - GlobalWindows() - Constructor for class org.apache.beam.sdk.transforms.windowing.GlobalWindows
- greaterThan(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.greaterThan(Comparable). - greaterThan(T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.greaterThan(Comparable). - greaterThan(T) - Static method in class org.apache.beam.sdk.transforms.Filter
-
Returns a
PTransformthat takes an inputPCollection<T>and returns aPCollection<T>with elements that are greater than a given value, based on the elements' natural ordering. - greaterThanEq(T) - Static method in class org.apache.beam.sdk.transforms.Filter
-
Returns a
PTransformthat takes an inputPCollection<T>and returns aPCollection<T>with elements that are greater than or equal to a given value, based on the elements' natural ordering. - greaterThanOrEqualTo(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.greaterThanOrEqualTo(Comparable). - greaterThanOrEqualTo(T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.greaterThanOrEqualTo(Comparable). - GreedyPipelineFuser - Class in org.apache.beam.sdk.util.construction.graph
-
Fuses a
RunnerApi.Pipelineinto some set of single-environment executable transforms. - GreedyStageFuser - Class in org.apache.beam.sdk.util.construction.graph
-
A factory class which produces an
ExecutableStageby attempting to fuse all availablePCollectionswhen it is constructed. - Group - Class in org.apache.beam.sdk.schemas.transforms
-
A generic grouping transform for schema
PCollections. - Group() - Constructor for class org.apache.beam.sdk.schemas.transforms.Group
- GROUP_BY_KEY_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- GROUP_BY_KEY_WRAPPER_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- GROUP_INTO_BATCHES_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- GROUP_INTO_BATCHES_WITH_SHARDED_KEY_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- Group.AggregateCombiner<InputT> - Class in org.apache.beam.sdk.schemas.transforms
-
a
PTransformthat does a combine using an aggregation built up by calls to aggregateField and aggregateFields. - Group.ByFields<InputT> - Class in org.apache.beam.sdk.schemas.transforms
-
a
PTransformthat groups schema elements based on the given fields. - Group.CombineFieldsByFields<InputT> - Class in org.apache.beam.sdk.schemas.transforms
-
a
PTransformthat does a per-key combine using an aggregation built up by calls to aggregateField and aggregateFields. - Group.CombineFieldsByFields.Fanout - Class in org.apache.beam.sdk.schemas.transforms
- Group.CombineFieldsByFields.Fanout.Kind - Enum in org.apache.beam.sdk.schemas.transforms
- Group.CombineFieldsGlobally<InputT> - Class in org.apache.beam.sdk.schemas.transforms
-
a
PTransformthat does a global combine using an aggregation built up by calls to aggregateField and aggregateFields. - Group.CombineGlobally<InputT,OutputT> - Class in org.apache.beam.sdk.schemas.transforms
-
a
PTransformthat does a global combine using a providerCombine.CombineFn. - Group.Global<InputT> - Class in org.apache.beam.sdk.schemas.transforms
-
A
PTransformfor doing global aggregations on schema PCollections. - GroupByEncryptedKey<K,V> - Class in org.apache.beam.sdk.transforms
-
A
PTransformthat provides a secure alternative toGroupByKey. - GroupByKey<K,V> - Class in org.apache.beam.sdk.transforms
-
GroupByKey<K, V>takes aPCollection<KV<K, V>>, groups the values by key and windows, and returns aPCollection<KV<K, Iterable<V>>>representing a map from each distinct key and window of the inputPCollectionto anIterableover all the values associated with that key in the input per window. - GroupByKeyTranslation - Class in org.apache.beam.sdk.util.construction
-
Utility methods for translating a
GroupByKeyto and fromRunnerApirepresentations. - GroupByKeyTranslation() - Constructor for class org.apache.beam.sdk.util.construction.GroupByKeyTranslation
- GroupByKeyTranslation.Registrar - Class in org.apache.beam.sdk.util.construction
-
Registers
GroupByKeyTranslation.GroupByKeyTranslator. - groupedValues(CombineFnBase.GlobalCombineFn<? super InputT, ?, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.GroupedValuesPTransformthat takes aPCollectionofKVs where a key maps to anIterableof values, e.g., the result of aGroupByKey, then uses the givenCombineFnto combine all the values associated with a key, ignoring the key. - groupedValues(SerializableBiFunction<V, V, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.GroupedValuesPTransformthat takes aPCollectionofKVs where a key maps to anIterableof values, e.g., the result of aGroupByKey, then uses the givenSerializableFunctionto combine all the values associated with a key, ignoring the key. - groupedValues(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.GroupedValuesPTransformthat takes aPCollectionofKVs where a key maps to anIterableof values, e.g., the result of aGroupByKey, then uses the givenSerializableFunctionto combine all the values associated with a key, ignoring the key. - GroupingState<InputT,OutputT> - Interface in org.apache.beam.sdk.state
-
A
ReadableStatecell that combines multiple input values and outputs a single value of a different type. - groupIntoBatches() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
A
PTransformMatcherwhich matchesGroupIntoBatchestransform. - GroupIntoBatches<K,InputT> - Class in org.apache.beam.sdk.transforms
-
A
PTransformthat batches inputs to a desired batch size. - GroupIntoBatches.BatchingParams<InputT> - Class in org.apache.beam.sdk.transforms
-
Wrapper class for batching parameters supplied by users.
- GroupIntoBatches.WithShardedKey - Class in org.apache.beam.sdk.transforms
- GroupIntoBatchesTranslation - Class in org.apache.beam.sdk.util.construction
- GroupIntoBatchesTranslation() - Constructor for class org.apache.beam.sdk.util.construction.GroupIntoBatchesTranslation
- GroupIntoBatchesTranslation.Registrar - Class in org.apache.beam.sdk.util.construction
-
Registers
GroupIntoBatchesTranslation.GroupIntoBatchesTranslatorandGroupIntoBatchesTranslation.ShardedGroupIntoBatchesTranslator. - groups() - Method in annotation type org.apache.beam.sdk.options.Validation.Required
-
The groups that the annotated attribute is a member of.
- groupWithShardableStates() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
A
PTransformMatcherwhich matchesGroupIntoBatchestransform that allows shardable states. - GrowableOffsetRangeTracker - Class in org.apache.beam.sdk.transforms.splittabledofn
-
An
OffsetRangeTrackerfor tracking a growable offset range. - GrowableOffsetRangeTracker(long, GrowableOffsetRangeTracker.RangeEndEstimator) - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.GrowableOffsetRangeTracker
- GrowableOffsetRangeTracker.RangeEndEstimator - Interface in org.apache.beam.sdk.transforms.splittabledofn
-
Provides the estimated end offset of the range.
- Growth() - Constructor for class org.apache.beam.sdk.transforms.Watch.Growth
- growthOf(Contextful<Watch.Growth.PollFn<InputT, OutputT>>, SerializableFunction<OutputT, KeyT>) - Static method in class org.apache.beam.sdk.transforms.Watch
-
Watches the growth of the given poll function, using the given "key function" to deduplicate outputs.
- growthOf(Watch.Growth.PollFn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Watch
-
Watches the growth of the given poll function.
- growthOf(Watch.Growth.PollFn<InputT, OutputT>, Requirements) - Static method in class org.apache.beam.sdk.transforms.Watch
-
Watches the growth of the given poll function.
- GrpcContextHeaderAccessorProvider - Class in org.apache.beam.sdk.fn.server
-
A HeaderAccessorProvider which intercept the header in a GRPC request and expose the relevant fields.
- GrpcContextHeaderAccessorProvider() - Constructor for class org.apache.beam.sdk.fn.server.GrpcContextHeaderAccessorProvider
- GrpcFnServer<ServiceT extends FnService> - Class in org.apache.beam.sdk.fn.server
-
A
gRPC Serverwhich manages a singleFnService. - guessExpressionType(String, Map<String, Type>) - Static method in class org.apache.beam.sdk.schemas.transforms.providers.StringCompiler
- GZIP - org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.
- GZIP - org.apache.beam.sdk.io.Compression
-
GZip compression.
- GZIP - org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.
- GZIP - org.apache.beam.sdk.io.TextIO.CompressionType
-
Deprecated.
- GZIP - org.apache.beam.sdk.io.TFRecordIO.CompressionType
-
Deprecated.
H
- has(String) - Method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
Returns whether this
PCollectionRowTuplecontains aPCollectionwith the given tag. - has(String) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
Returns whether this
PCollectionTuplecontains aPCollectionwith the given tag. - has(ObjectT) - Method in interface org.apache.beam.sdk.schemas.FieldValueHaver
- has(TupleTag<T>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
Returns whether this
PCollectionTuplecontains aPCollectionwith the given tag. - hasCommitted() - Method in class org.apache.beam.sdk.metrics.MetricResult
- hasDefault() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
-
Deprecated.Returns if a default value was specified.
- hasDefault() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn2
-
Returns if a default value was specified.
- HasDefaultTracker<RestrictionT extends HasDefaultTracker<RestrictionT,TrackerT>,TrackerT extends RestrictionTracker<RestrictionT,?>> - Interface in org.apache.beam.sdk.transforms.splittabledofn
-
Interface for restrictions for which a default implementation of
DoFn.NewTrackeris available, depending only on the restriction itself. - hasDefaultValue() - Method in class org.apache.beam.sdk.transforms.View.AsSingleton
-
Returns whether this transform has a default value.
- HasDefaultWatermarkEstimator<WatermarkEstimatorStateT,WatermarkEstimatorT extends WatermarkEstimator<WatermarkEstimatorStateT>> - Interface in org.apache.beam.sdk.transforms.splittabledofn
-
Interface for watermark estimator state for which a default implementation of
DoFn.NewWatermarkEstimatoris available, depending only on the watermark estimator state itself. - HasDisplayData - Interface in org.apache.beam.sdk.transforms.display
-
Marker interface for
PTransformsand components to specify display data used within UIs and diagnostic tools. - hasExperiment(PipelineOptions, String) - Static method in interface org.apache.beam.sdk.options.ExperimentalOptions
-
Returns true iff the provided pipeline options has the specified experiment enabled.
- hasField(String) - Method in class org.apache.beam.sdk.schemas.Schema
-
Returns true if
fieldNameexists in the schema, false otherwise. - hasGlobWildcard(String) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Checks whether the given spec contains a glob wildcard character.
- hashCode() - Method in class org.apache.beam.sdk.coders.AtomicCoder
-
.
- hashCode() - Method in class org.apache.beam.sdk.coders.Coder.Context
-
Deprecated.
- hashCode() - Method in class org.apache.beam.sdk.coders.DelegateCoder
- hashCode() - Method in class org.apache.beam.sdk.coders.RowCoder
- hashCode() - Method in class org.apache.beam.sdk.coders.SerializableCoder
- hashCode() - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
- hashCode() - Method in class org.apache.beam.sdk.coders.StructuralByteArray
- hashCode() - Method in class org.apache.beam.sdk.coders.StructuredCoder
- hashCode() - Method in class org.apache.beam.sdk.coders.ZstdCoder
- hashCode() - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
- hashCode() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
- hashCode() - Method in class org.apache.beam.sdk.io.range.ByteKey
- hashCode() - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
- hashCode() - Method in class org.apache.beam.sdk.io.range.OffsetRange
- hashCode() - Method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
- hashCode() - Method in class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
- hashCode() - Method in class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
- hashCode() - Method in class org.apache.beam.sdk.schemas.CachingFactory
- hashCode() - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
-
Deprecated.
- hashCode() - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema.GetterTypeSupplier
- hashCode() - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema
- hashCode() - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema.SetterTypeSupplier
- hashCode() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType.Value
- hashCode() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
- hashCode() - Method in class org.apache.beam.sdk.schemas.Schema.Field
- hashCode() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
- hashCode() - Method in class org.apache.beam.sdk.schemas.Schema
- hashCode() - Method in class org.apache.beam.sdk.schemas.Schema.Options
- hashCode() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
- hashCode() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- hashCode() - Method in class org.apache.beam.sdk.testing.PAssert.PAssertionSite
- hashCode() - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
-
Deprecated.
Object.hashCode()is not supported on PAssert objects. - hashCode() - Method in class org.apache.beam.sdk.testing.SuccessOrFailure
- hashCode() - Method in class org.apache.beam.sdk.testing.TestStream
- hashCode() - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique
-
Deprecated.
- hashCode() - Method in class org.apache.beam.sdk.transforms.CombineFns.CoCombineResult
- hashCode() - Method in class org.apache.beam.sdk.transforms.display.DisplayData
- hashCode() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
- hashCode() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
- hashCode() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
- hashCode() - Method in class org.apache.beam.sdk.transforms.join.RawUnionValue
- hashCode() - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
- hashCode() - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHint
- hashCode() - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHints
- hashCode() - Method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
- hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
- hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
- hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
- hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
- hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
- hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindow
- hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
- hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
- hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
- hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
- hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
- hashCode() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
- hashCode() - Method in class org.apache.beam.sdk.util.construction.RunnerPCollectionView
- hashCode() - Method in class org.apache.beam.sdk.util.construction.Timer
- hashCode() - Method in class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter
- hashCode() - Method in class org.apache.beam.sdk.util.HistogramData.ExponentialBuckets
- hashCode() - Method in class org.apache.beam.sdk.util.HistogramData
- hashCode() - Method in class org.apache.beam.sdk.util.SerializableThrowable
- hashCode() - Method in class org.apache.beam.sdk.util.ShardedKey
- hashCode() - Method in class org.apache.beam.sdk.util.UnownedInputStream
- hashCode() - Method in class org.apache.beam.sdk.util.UnownedOutputStream
- hashCode() - Method in class org.apache.beam.sdk.util.WeightedValue
- hashCode() - Method in class org.apache.beam.sdk.values.EncodableThrowable
- hashCode() - Method in class org.apache.beam.sdk.values.KV
- hashCode() - Method in class org.apache.beam.sdk.values.PCollectionList
- hashCode() - Method in class org.apache.beam.sdk.values.PCollectionRowTuple
- hashCode() - Method in class org.apache.beam.sdk.values.PCollectionTuple
- hashCode() - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryListFromMultimapViewFn
- hashCode() - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryListViewFn
- hashCode() - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableBackedListViewFn
- hashCode() - Method in class org.apache.beam.sdk.values.PCollectionViews.ListViewFn
-
Deprecated.
- hashCode() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
- hashCode() - Method in class org.apache.beam.sdk.values.Row
- hashCode() - Method in class org.apache.beam.sdk.values.RowWithGetters
- hashCode() - Method in class org.apache.beam.sdk.values.ShardedKey
-
Deprecated.
- hashCode() - Method in class org.apache.beam.sdk.values.TimestampedValue
- hashCode() - Method in class org.apache.beam.sdk.values.TupleTag
- hashCode() - Method in class org.apache.beam.sdk.values.TypeDescriptor
- hashCode() - Method in class org.apache.beam.sdk.values.TypeParameter
- hashCode() - Method in class org.apache.beam.sdk.values.ValueWithRecordId
- hashCode() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- hashCode(WindowedValue<T>) - Static method in class org.apache.beam.sdk.values.WindowedValues
- hasItem(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.hasItem(Object). - hasItem(SerializableMatcher<? super T>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.hasItem(Matcher). - hasItem(T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.hasItem(Object). - hasNext() - Method in class org.apache.beam.sdk.fn.stream.DataStreams.DataStreamDecoder
- hasOption(String) - Method in class org.apache.beam.sdk.schemas.Schema.Options
- hasOptions() - Method in class org.apache.beam.sdk.schemas.Schema.Options
- hasOutput(ErrorHandling) - Static method in class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling
- hasReplacementJob() - Method in enum org.apache.beam.sdk.PipelineResult.State
- hasReturnValue() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
-
Whether this
DoFnreturns aDoFn.ProcessContinuationor void. - hasSchema() - Method in class org.apache.beam.sdk.values.PCollection
-
Returns whether this
PCollectionhas an attached schema. - hasSize(int) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.hasSize(int). - hasSize(SerializableMatcher<? super Integer>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.hasSize(Matcher). - hasUnresolvedParameters() - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns whether this
TypeDescriptorhas any unresolved type parameters, as opposed to being a concrete type. - HeaderAccessor - Interface in org.apache.beam.sdk.fn.server
-
Interface to access headers in the client request.
- Hidden - Annotation Type in org.apache.beam.sdk.options
-
Methods and/or interfaces annotated with
@Hiddenwill be suppressed from being output when--helpis specified on the command-line. - hints() - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHints
- Histogram - Interface in org.apache.beam.sdk.metrics
-
A metric that reports information about the histogram of reported values.
- HistogramData - Class in org.apache.beam.sdk.util
-
A histogram that supports estimated percentile with linear interpolation.
- HistogramData(MetricsApi.HistogramValue) - Constructor for class org.apache.beam.sdk.util.HistogramData
-
Create a histogram from HistogramValue proto.
- HistogramData(HistogramData.BucketType) - Constructor for class org.apache.beam.sdk.util.HistogramData
-
Create a histogram.
- HistogramData.BucketType - Interface in org.apache.beam.sdk.util
- HistogramData.ExponentialBuckets - Class in org.apache.beam.sdk.util
- HistogramData.HistogramParsingException - Exception in org.apache.beam.sdk.util
- HistogramData.LinearBuckets - Class in org.apache.beam.sdk.util
- HistogramData.UnsupportedBuckets - Class in org.apache.beam.sdk.util
-
Used for testing unsupported Bucket formats.
- HistogramParsingException(String) - Constructor for exception org.apache.beam.sdk.util.HistogramData.HistogramParsingException
- Holder<T> - Class in org.apache.beam.sdk.util
-
A trivial boxing of a value, used when nullability needs to be added to a generic type.
I
- id() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.FieldAccessDeclaration
- id() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerFamilyMethod
-
The id on the method's
DoFn.TimerIdannotation. - id() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerMethod
-
The id on the method's
DoFn.TimerIdannotation. - id() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.StateDeclaration
- id() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TimerDeclaration
- id() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TimerFamilyDeclaration
- identifier() - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformProvider
-
Implementation of the
TypedSchemaTransformProvideridentifier method. - identifier() - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformProvider
-
Implementation of the
TypedSchemaTransformProvideridentifier method. - identifier() - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider
- identifier() - Method in class org.apache.beam.sdk.schemas.io.payloads.JsonPayloadSerializerProvider
- identifier() - Method in interface org.apache.beam.sdk.schemas.io.Providers.Identifyable
-
Returns an id that uniquely represents this among others implementing its derived interface.
- identifier() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIOProvider
-
Returns an id that uniquely represents this IO.
- identifier() - Method in class org.apache.beam.sdk.schemas.transforms.providers.FlattenTransformProvider
- identifier() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider
- identifier() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider
- identifier() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider
- identifier() - Method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider
- identifier() - Method in interface org.apache.beam.sdk.schemas.transforms.SchemaTransformProvider
-
Returns an id that uniquely represents this transform.
- Identifier() - Constructor for class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.Date
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.FixedPrecisionNumeric
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.FixedString
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.NanosDuration
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.NanosInstant
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.PythonCallable
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.SchemaLogicalType
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.Time
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.UuidLogicalType
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.VariableBytes
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.VariableString
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- IDENTIFIER() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
- IDENTIFIER() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.SimpleIdentifierContext
- identity() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
-
Returns the identity element of this operation, i.e.
- identity() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
-
Returns the value that should be used for the combine of the empty set.
- identity() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
-
Returns the identity element of this operation, i.e.
- identity() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
-
Returns the identity element of this operation, i.e.
- identity() - Static method in class org.apache.beam.sdk.transforms.SerializableFunctions
- IDENTITY_ELEMENT - Static variable in class org.apache.beam.sdk.metrics.DistributionResult
-
The IDENTITY_ELEMENT is used to start accumulating distributions.
- IdentityWindowFn<T> - Class in org.apache.beam.sdk.util
-
A
WindowFnthat leaves all associations between elements and windows unchanged. - IdentityWindowFn(Coder<? extends BoundedWindow>) - Constructor for class org.apache.beam.sdk.util.IdentityWindowFn
- IdGenerator - Interface in org.apache.beam.sdk.fn
-
A generator of unique IDs.
- IdGenerators - Class in org.apache.beam.sdk.fn
-
Common
IdGeneratorimplementations. - IdGenerators() - Constructor for class org.apache.beam.sdk.fn.IdGenerators
- IGNORE - org.apache.beam.sdk.schemas.Schema.EquivalenceNullablePolicy
- IGNORE_MISSING_FILES - org.apache.beam.sdk.io.fs.MoveOptions.StandardMoveOptions
- ignoreInput(Watch.Growth.TerminationCondition<?, StateT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
Wraps a given input-independent
Watch.Growth.TerminationConditionas an equivalent condition with a given input type, passingnullto the original condition as input. - IllegalMutationException - Exception in org.apache.beam.sdk.util
-
Thrown when a value appears to have been mutated, but that mutation is forbidden.
- IllegalMutationException(String, Object, Object) - Constructor for exception org.apache.beam.sdk.util.IllegalMutationException
- IllegalMutationException(String, Object, Object, Throwable) - Constructor for exception org.apache.beam.sdk.util.IllegalMutationException
- immediate(T) - Static method in class org.apache.beam.sdk.state.ReadableStates
-
A
ReadableStateconstructed from a constant value, hence immediately available. - ImmutableExecutableStage - Class in org.apache.beam.sdk.util.construction.graph
-
An
ExecutableStagewhich is constructed with all of its initial state. - ImmutableExecutableStage() - Constructor for class org.apache.beam.sdk.util.construction.graph.ImmutableExecutableStage
- immutableNames() - Method in class org.apache.beam.sdk.metrics.MetricsFilter
- immutableNamesBuilder() - Method in class org.apache.beam.sdk.metrics.MetricsFilter.Builder
- immutableSteps() - Method in class org.apache.beam.sdk.metrics.MetricsFilter
- immutableStepsBuilder() - Method in class org.apache.beam.sdk.metrics.MetricsFilter.Builder
- Impulse - Class in org.apache.beam.sdk.transforms
-
For internal use only; no backwards-compatibility guarantees.
- IMPULSE_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- ImpulseTranslation - Class in org.apache.beam.sdk.util.construction
-
Utility methods for translating a
Impulseto and fromRunnerApirepresentations. - ImpulseTranslation() - Constructor for class org.apache.beam.sdk.util.construction.ImpulseTranslation
- ImpulseTranslation.Registrar - Class in org.apache.beam.sdk.util.construction
-
Registers
ImpulseTranslation.ImpulseTranslator. - in(Pipeline) - Static method in class org.apache.beam.sdk.values.PBegin
- in(Pipeline) - Static method in class org.apache.beam.sdk.values.PDone
- inc() - Method in interface org.apache.beam.sdk.metrics.Counter
-
Increment the counter.
- inc() - Method in class org.apache.beam.sdk.metrics.DelegatingCounter
-
Increment the counter.
- inc() - Method in class org.apache.beam.sdk.metrics.NoOpCounter
- inc(long) - Method in interface org.apache.beam.sdk.metrics.Counter
-
Increment the counter by the given amount.
- inc(long) - Method in class org.apache.beam.sdk.metrics.DelegatingCounter
-
Increment the counter by the given amount.
- inc(long) - Method in class org.apache.beam.sdk.metrics.NoOpCounter
- incBottomBucketCount(long) - Method in class org.apache.beam.sdk.util.HistogramData
- incBucketCount(int, long) - Method in class org.apache.beam.sdk.util.HistogramData
- include(String, HasDisplayData) - Method in interface org.apache.beam.sdk.transforms.display.DisplayData.Builder
-
Register display data from the specified subcomponent at the given path.
- includingClass(Class<?>) - Method in class org.apache.beam.sdk.util.ApiSurface
-
Returns an
ApiSurfacelike this one, but also including the given class. - includingPackage(String, ClassLoader) - Method in class org.apache.beam.sdk.util.ApiSurface
-
Returns an
ApiSurfacelike this one, but also including the named package and all of its subpackages. - inCombinedNonLatePanes(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Creates a new
PAssert.IterableAssertlike this one, but with the assertion restricted to only run on the provided window across all panes that were not produced by the arrival of late data. - inCombinedNonLatePanes(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
- IncompatibleWindowException - Exception in org.apache.beam.sdk.transforms.windowing
-
Exception thrown by
WindowFn.verifyCompatibility(WindowFn)if two compared WindowFns are not compatible, including the explanation of incompatibility. - IncompatibleWindowException(WindowFn<?, ?>, String) - Constructor for exception org.apache.beam.sdk.transforms.windowing.IncompatibleWindowException
- incomplete(List<TimestampedValue<OutputT>>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
-
Constructs a
Watch.Growth.PollResultwith the given outputs and declares that new outputs might appear for the current input. - incomplete(Instant, List<OutputT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
-
Like
Watch.Growth.PollResult.incomplete(List), but assigns the same timestamp to all new outputs. - increaseDefaultStreamReadConstraints(int) - Static method in class org.apache.beam.sdk.util.RowJsonUtils
-
Increase the default jackson-databind stream read constraint.
- incrementingLongs() - Static method in class org.apache.beam.sdk.fn.IdGenerators
-
Returns an
IdGeneratorwhich provides successive incrementing longs. - incTopBucketCount(long) - Method in class org.apache.beam.sdk.util.HistogramData
- index() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter
- INDEX_OF_MAX - Static variable in class org.apache.beam.sdk.io.ShardNameTemplate
-
Shard name containing the index and max.
- indexOf(String) - Method in class org.apache.beam.sdk.schemas.Schema
-
Find the index of a given field.
- inEarlyGlobalWindowPanes() - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Creates a new
PAssert.IterableAssertlike this one, but with the assertion restricted to only run on panes in theGlobalWindowthat were emitted before theGlobalWindowclosed. - inEarlyGlobalWindowPanes() - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
- inEarlyPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Creates a new
PAssert.IterableAssertlike this one, but with the assertion restricted to only run on the provided window across all panes that were produced by the arrival of early data. - inEarlyPane(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
- inEarlyPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Creates a new
PAssert.SingletonAssertlike this one, but with the assertion restricted to only run on the provided window, running the checker only on early panes for each key. - InferableFunction<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
A
ProcessFunctionwhich is not a functional interface. - InferableFunction() - Constructor for class org.apache.beam.sdk.transforms.InferableFunction
- InferableFunction(ProcessFunction<InputT, OutputT>) - Constructor for class org.apache.beam.sdk.transforms.InferableFunction
- inferType(Object) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Infer the
DisplayData.Typefor the given object. - inFinalPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Creates a new
PAssert.IterableAssertlike this one, but with the assertion restricted to only run on the provided window, running the checker only on the final pane for each key. - inFinalPane(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
- inFinalPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Creates a new
PAssert.SingletonAssertlike this one, but with the assertion restricted to only run on the provided window, running the checker only on the final pane for each key. - INFO - org.apache.beam.sdk.options.SdkHarnessOptions.LogLevel
-
LogLevel for logging informational messages.
- InjectPackageStrategy(Class<?>) - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.InjectPackageStrategy
- inLatePane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Creates a new
PAssert.IterableAssertwith the assertion restricted to only run on the provided window across all panes that were produced by the arrival of late data. - inLatePane(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
- inLatePane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Creates a new
PAssert.SingletonAssertwith the assertion restricted to only run on the provided window, running the checker only on late panes for each key. - inMemory() - Method in class org.apache.beam.sdk.transforms.View.AsList
-
Returns a PCollection view like this one, but whose resulting list will be entirely cached in memory.
- inMemory() - Method in class org.apache.beam.sdk.transforms.View.AsMap
-
Returns a PCollection view like this one, but whose resulting map will be entirely cached in memory.
- inMemory() - Method in class org.apache.beam.sdk.transforms.View.AsMultimap
-
Returns a PCollection view like this one, but whose resulting map will be entirely cached in memory.
- inMemory(boolean) - Method in class org.apache.beam.sdk.transforms.View.AsList
-
Returns a PCollection view like this one, but whose resulting list will be entirely cached in memory according to the input parameter.
- inMemory(boolean) - Method in class org.apache.beam.sdk.transforms.View.AsMap
-
Returns a PCollection view like this one, but whose resulting map will be entirely cached in memory according to the input parameter.
- inMemory(boolean) - Method in class org.apache.beam.sdk.transforms.View.AsMultimap
-
Returns a PCollection view like this one, but whose resulting map will be entirely cached in memory according to the input parameter.
- InMemoryListFromMultimapViewFn(PCollectionViews.TypeDescriptorSupplier<T>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.InMemoryListFromMultimapViewFn
- inMemoryListView(PCollection<T>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<List<T>>capable of processing elements windowed using the providedWindowingStrategy. - InMemoryListViewFn(PCollectionViews.TypeDescriptorSupplier<T>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.InMemoryListViewFn
- inMemoryListViewUsingVoidKey(PCollection<KV<Void, T>>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<List<T>>capable of processing elements windowed using the providedWindowingStrategy. - InMemoryMapFromVoidKeyViewFn(Coder<K>, Coder<V>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.InMemoryMapFromVoidKeyViewFn
- inMemoryMapView(PCollection<KV<K, V>>, Coder<K>, Coder<V>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<Map<K, V>>capable of processing elements windowed using the providedWindowingStrategy. - InMemoryMapViewFn(Coder<K>, Coder<V>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.InMemoryMapViewFn
- inMemoryMapViewUsingVoidKey(PCollection<KV<Void, KV<K, V>>>, Coder<K>, Coder<V>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<Map<K, V>>capable of processing elements windowed using the providedWindowingStrategy. - InMemoryMultimapFromVoidKeyViewFn(Coder<K>, Coder<V>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.InMemoryMultimapFromVoidKeyViewFn
- inMemoryMultimapView(PCollection<KV<K, V>>, Coder<K>, Coder<V>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<Map<K, Iterable<V>>>capable of processing elements windowed using the providedWindowingStrategy. - InMemoryMultimapViewFn(Coder<K>, Coder<V>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.InMemoryMultimapViewFn
- inMemoryMultimapViewUsingVoidKey(PCollection<KV<Void, KV<K, V>>>, Coder<K>, Coder<V>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<Map<K, Iterable<V>>>capable of processing elements windowed using the providedWindowingStrategy. - inNamespace(Class<?>) - Static method in class org.apache.beam.sdk.metrics.MetricNameFilter
- inNamespace(String) - Static method in class org.apache.beam.sdk.metrics.MetricNameFilter
- Inner() - Constructor for class org.apache.beam.sdk.schemas.transforms.Filter.Inner
- innerBroadcastJoin(PCollection<RhsT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Join
-
Perform an inner join, broadcasting the right side.
- innerJoin(PCollection<RhsT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Join
-
Perform an inner join.
- inOnlyPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Creates a new
PAssert.IterableAssertlike this one, but with the assertion restricted to only run on the provided window. - inOnlyPane(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
- inOnlyPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Creates a new
PAssert.SingletonAssertlike this one, but with the assertion restricted to only run on the provided window. - inOnTimePane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Creates a new
PAssert.IterableAssertlike this one, but with the assertion restricted to only run on the provided window. - inOnTimePane(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
- inOnTimePane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Creates a new
PAssert.SingletonAssertlike this one, but with the assertion restricted to only run on the provided window, running the checker only on the on-time pane for each key. - inOrder(List<Trigger>) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterEach
-
Returns an
AfterEachTriggerwith the given subtriggers. - inOrder(Trigger...) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterEach
-
Returns an
AfterEachTriggerwith the given subtriggers. - InProcessServerFactory - Class in org.apache.beam.sdk.fn.server
- INPUT_ROWS_TAG - Static variable in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider
- INPUT_ROWS_TAG - Static variable in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider
- INPUT_ROWS_TAG - Static variable in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider
- INPUT_ROWS_TAG - Static variable in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider
- inputCollectionNames() - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformProvider
-
Implementation of the
TypedSchemaTransformProviderinputCollectionNames method. - inputCollectionNames() - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider
- inputCollectionNames() - Method in class org.apache.beam.sdk.schemas.transforms.providers.FlattenTransformProvider
- inputCollectionNames() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider
- inputCollectionNames() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider
- inputCollectionNames() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider
- inputCollectionNames() - Method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider
- inputCollectionNames() - Method in interface org.apache.beam.sdk.schemas.transforms.SchemaTransformProvider
-
Returns the input collection names of this transform.
- inputOf(Contextful.Fn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
Like
TypeDescriptors.inputOf(ProcessFunction)but forContextful.Fn. - inputOf(ProcessFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
Returns a type descriptor for the input of the given
ProcessFunction, subject to Java type erasure: may contain unresolved type variables if the type was erased. - inputOf(SerializableFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
Binary compatibility adapter for
TypeDescriptors.inputOf(ProcessFunction). - instance() - Static method in class org.apache.beam.sdk.util.construction.EmptyFlattenAsCreateFactory
- INSTANCE - Static variable in exception org.apache.beam.sdk.fn.data.BeamFnDataInboundObserver.CloseException
- INSTANCE - Static variable in class org.apache.beam.sdk.fn.windowing.EncodedBoundedWindow.Coder
- INSTANCE - Static variable in class org.apache.beam.sdk.schemas.AutoValueSchema.AbstractGetterTypeSupplier
- INSTANCE - Static variable in class org.apache.beam.sdk.schemas.JavaBeanSchema.GetterTypeSupplier
- INSTANCE - Static variable in class org.apache.beam.sdk.schemas.JavaFieldSchema.JavaFieldTypeSupplier
- INSTANCE - Static variable in class org.apache.beam.sdk.transforms.windowing.GlobalWindow.Coder
- INSTANCE - Static variable in class org.apache.beam.sdk.transforms.windowing.GlobalWindow
-
Singleton instance of
GlobalWindow. - INSTANCE - Static variable in class org.apache.beam.sdk.transforms.windowing.PaneInfo.PaneInfoCoder
- INSTANCE - Static variable in class org.apache.beam.sdk.util.common.ReflectHelpers.ObjectsClassComparator
- INSTANCE - Static variable in class org.apache.beam.sdk.util.construction.DefaultArtifactResolver
- InstanceBuilder<T> - Class in org.apache.beam.sdk.util
-
Utility for creating objects dynamically.
- InstantCoder - Class in org.apache.beam.sdk.coders
-
A
Coderfor jodaInstantthat encodes it as a big endianLongshifted such that lexicographic ordering of the bytes corresponds to chronological order. - INT16 - org.apache.beam.sdk.schemas.Schema.TypeName
- INT16 - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
-
The type of int16 fields.
- INT32 - org.apache.beam.sdk.schemas.Schema.TypeName
- INT32 - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
-
The type of int32 fields.
- INT64 - org.apache.beam.sdk.schemas.Schema.TypeName
- INT64 - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
-
The type of int64 fields.
- INT64_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- INTEGER - org.apache.beam.sdk.transforms.display.DisplayData.Type
- integers() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorfor Integer. - integersGlobally() - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a
PTransformthat takes an inputPCollection<Integer>and returns aPCollection<Integer>whose contents is the maximum of the inputPCollection's elements, orInteger.MIN_VALUEif there are no elements. - integersGlobally() - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a
PTransformthat takes an inputPCollection<Integer>and returns aPCollection<Integer>whose contents is a single value that is the minimum of the inputPCollection's elements, orInteger.MAX_VALUEif there are no elements. - integersGlobally() - Static method in class org.apache.beam.sdk.transforms.Sum
-
Returns a
PTransformthat takes an inputPCollection<Integer>and returns aPCollection<Integer>whose contents is the sum of the inputPCollection's elements, or0if there are no elements. - integersPerKey() - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a
PTransformthat takes an inputPCollection<KV<K, Integer>>and returns aPCollection<KV<K, Integer>>that contains an output element mapping each distinct key in the inputPCollectionto the maximum of the values associated with that key in the inputPCollection. - integersPerKey() - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a
PTransformthat takes an inputPCollection<KV<K, Integer>>and returns aPCollection<KV<K, Integer>>that contains an output element mapping each distinct key in the inputPCollectionto the minimum of the values associated with that key in the inputPCollection. - integersPerKey() - Static method in class org.apache.beam.sdk.transforms.Sum
-
Returns a
PTransformthat takes an inputPCollection<KV<K, Integer>>and returns aPCollection<KV<K, Integer>>that contains an output element mapping each distinct key in the inputPCollectionto the sum of the values associated with that key in the inputPCollection. - interceptor() - Static method in class org.apache.beam.sdk.fn.server.GrpcContextHeaderAccessorProvider
- Internal - Annotation Type in org.apache.beam.sdk.annotations
-
Signifies that a publicly accessible API (public class, method or field) is intended for internal use only and not for public consumption.
- interpolate(ValueInSingleWindow<Row>) - Method in class org.apache.beam.sdk.util.RowStringInterpolator
-
Performs string interpolation on the template using values from the input
Rowand its windowing metadata. - interpolateKey(double) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
-
Returns a
ByteKeykeysuch that[startKey, key)represents approximately the specified fraction of the range[startKey, endKey). - intersectAll() - Static method in class org.apache.beam.sdk.transforms.Sets
-
Returns a new
PTransformtransform that follows SET ALL semantics which takes aPCollectionList<PCollection<T>>and returns aPCollection<T>containing the intersection all of collections done in order for all collections inPCollectionList<T>. - intersectAll(PCollection<T>) - Static method in class org.apache.beam.sdk.transforms.Sets
-
Returns a new
PTransformtransform that follows SET ALL semantics to compute the intersection with providedPCollection<T>. - intersectDistinct() - Static method in class org.apache.beam.sdk.transforms.Sets
-
Returns a
PTransformthat takes aPCollectionList<PCollection<T>>and returns aPCollection<T>containing the intersection of collections done in order for all collections inPCollectionList<T>. - intersectDistinct(PCollection<T>) - Static method in class org.apache.beam.sdk.transforms.Sets
-
Returns a new
PTransformtransform that follows SET DISTINCT semantics to compute the intersection with providedPCollection<T>. - intersects(IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
-
Returns whether this window intersects the given window.
- INTERVAL_WINDOW_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- IntervalWindow - Class in org.apache.beam.sdk.transforms.windowing
-
An implementation of
BoundedWindowthat represents an interval fromIntervalWindow.start(inclusive) toIntervalWindow.end(exclusive). - IntervalWindow(Instant, Instant) - Constructor for class org.apache.beam.sdk.transforms.windowing.IntervalWindow
-
Creates a new IntervalWindow that represents the half-open time interval [start, end).
- IntervalWindow(Instant, ReadableDuration) - Constructor for class org.apache.beam.sdk.transforms.windowing.IntervalWindow
- IntervalWindow.IntervalWindowCoder - Class in org.apache.beam.sdk.transforms.windowing
-
Encodes an
IntervalWindowas a pair of its upper bound and duration. - IntervalWindowCoder() - Constructor for class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
- into(WindowFn<? super T, ?>) - Static method in class org.apache.beam.sdk.transforms.windowing.Window
- into(TypeDescriptor<K2>) - Static method in class org.apache.beam.sdk.transforms.MapKeys
-
Returns a new
MapKeystransform with the given type descriptor for the output type, but the mapping function yet to be specified usingMapKeys.via(SerializableFunction). - into(TypeDescriptor<OutputT>) - Static method in class org.apache.beam.sdk.transforms.FlatMapElements
-
Returns a new
FlatMapElementstransform with the given type descriptor for the output type, but the mapping function yet to be specified usingFlatMapElements.via(ProcessFunction). - into(TypeDescriptor<OutputT>) - Static method in class org.apache.beam.sdk.transforms.MapElements
-
Returns a new
MapElementstransform with the given type descriptor for the output type, but the mapping function yet to be specified usingMapElements.via(ProcessFunction). - into(TypeDescriptor<V2>) - Static method in class org.apache.beam.sdk.transforms.MapValues
-
Returns a new
MapValuestransform with the given type descriptor for the output type, but the mapping function yet to be specified usingMapValues.via(SerializableFunction). - InvalidConfigurationException - Exception in org.apache.beam.sdk.schemas.io
-
Exception thrown when the configuration for a
SchemaIOis invalid. - InvalidConfigurationException(String) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidConfigurationException
- InvalidConfigurationException(String, Throwable) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidConfigurationException
- InvalidConfigurationException(Throwable) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidConfigurationException
- InvalidLocationException - Exception in org.apache.beam.sdk.schemas.io
-
Exception thrown when the configuration for a
SchemaIOis invalid. - InvalidLocationException(String) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidLocationException
- InvalidLocationException(String, Throwable) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidLocationException
- InvalidLocationException(Throwable) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidLocationException
- InvalidSchemaException - Exception in org.apache.beam.sdk.schemas.io
-
Exception thrown when the schema for a
SchemaIOis invalid. - InvalidSchemaException(String) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidSchemaException
- InvalidSchemaException(String, Throwable) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidSchemaException
- InvalidSchemaException(Throwable) - Constructor for exception org.apache.beam.sdk.schemas.io.InvalidSchemaException
- invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- invokeFinishBundle(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.FinishBundlemethod on the boundDoFn. - invokeGetInitialRestriction(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.GetInitialRestrictionmethod on the boundDoFn. - invokeGetInitialWatermarkEstimatorState(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.GetInitialWatermarkEstimatorStatemethod on the boundDoFn. - invokeGetRestrictionCoder(CoderRegistry) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.GetRestrictionCodermethod on the boundDoFn. - invokeGetSize(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.GetSizemethod on the boundDoFn. - invokeGetWatermarkEstimatorStateCoder(CoderRegistry) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.GetWatermarkEstimatorStateCodermethod on the boundDoFn. - invokeNewTracker(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.NewTrackermethod on the boundDoFn. - invokeNewWatermarkEstimator(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.NewWatermarkEstimatormethod on the boundDoFn. - invokeOnTimer(String, String, DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the appropriate
DoFn.OnTimermethod on the boundDoFn. - invokeOnTimer(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.OnTimerInvoker
-
Invoke the
DoFn.OnTimermethod in the provided context. - invokeOnWindowExpiration(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.OnWindowExpirationmethod on the boundDoFn. - invokeProcessElement(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.ProcessElementmethod on the boundDoFn. - invokerFor(DoFn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnInvokers
- invokeSetup(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.Setupmethod on the boundDoFn. - invokeSplitRestriction(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.SplitRestrictionmethod on the boundDoFn. - invokeStartBundle(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.StartBundlemethod on the boundDoFn. - invokeTeardown() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.Teardownmethod on the boundDoFn. - invokeTruncateRestriction(DoFnInvoker.ArgumentProvider<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker
-
Invoke the
DoFn.TruncateRestrictionmethod on the boundDoFn. - inWindow(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Creates a new
PAssert.IterableAssertlike this one, but with the assertion restricted to only run on the provided window. - inWindow(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
- inWindow(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Creates a new
PAssert.SingletonAssertlike this one, but with the assertion restricted to only run on the provided window. - isAccessible() - Method in interface org.apache.beam.sdk.options.ValueProvider
-
Whether the contents of this
ValueProvideris currently available viaValueProvider.get(). - isAccessible() - Method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
- isAccessible() - Method in class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
- isAccessible() - Method in class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
- isAllowedLatenessSpecified() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- isAlreadyMerged() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- isArray() - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns true if this type is known to be an array type.
- isAtSplitPoint() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
-
Returns true if the reader is at a split point.
- isAtSplitPoint() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
-
Returns true only for the first record; compressed sources cannot be split.
- isAtSplitPoint() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
-
Returns whether the current record is at a split point (i.e., whether the current record would be the first record to be read by a source with a specified start offset of
OffsetBasedSource.OffsetBasedReader.getCurrentOffset()). - isAutoSharded(AppliedPTransform<PCollection<T>, WriteFilesResult<DestinationT>, ? extends PTransform<PCollection<T>, WriteFilesResult<DestinationT>>>) - Static method in class org.apache.beam.sdk.util.construction.WriteFilesTranslation
- isBlockOnRun() - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
- isBounded() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIOProvider
- isBounded() - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.OutputRangeTracker
- isBounded() - Method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
- isBounded() - Method in class org.apache.beam.sdk.transforms.splittabledofn.GrowableOffsetRangeTracker
- isBounded() - Method in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
- isBounded() - Method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker
-
Return the boundedness of the current restriction.
- isBounded() - Method in class org.apache.beam.sdk.values.PCollection
- isBounded(RunnerApi.PCollection) - Static method in class org.apache.beam.sdk.util.construction.PCollectionTranslation
- isBoundedPerElement() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Whether this
DoFndoes a bounded amount of work per element. - isCancelled(CompletionStage<?>) - Static method in class org.apache.beam.sdk.util.MoreFutures
-
Indicates whether the future is cancelled.
- isClosed() - Method in class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.DefaultErrorHandler
- isClosed() - Method in interface org.apache.beam.sdk.transforms.errorhandling.ErrorHandler
- isClosed() - Method in class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.PTransformErrorHandler
- isCollectionType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
- isCompatible(Trigger) - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
- isCompatible(Trigger) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
- isCompatible(Trigger) - Method in class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
- isCompatible(Trigger) - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
-
For internal use only; no backwards-compatibility guarantees.
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
Deprecated.please override verifyCompatibility to throw a useful error message; we will remove isCompatible at version 3.0.0
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.util.IdentityWindowFn
- isCompositeNode() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
-
Returns true if this node represents a composite transform that does not perform processing of its own, but merely encapsulates a sub-pipeline (which may be empty).
- isCompositeType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
- isCompressed(String) - Static method in enum org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.Returns whether the file's extension matches of one of the known compression formats.
- isCompressed(String) - Method in enum org.apache.beam.sdk.io.Compression
- isConsumingReceivedData() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataInboundObserver
- isDateType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
- isDecimal(Schema.TypeName) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
-
Checks if type is decimal.
- isDevSdkVersion() - Method in class org.apache.beam.sdk.util.ReleaseInfo
-
Returns true if SDK version is a dev version (e.g.
- isDirectory() - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderResourceId
- isDirectory() - Method in interface org.apache.beam.sdk.io.fs.ResourceId
-
Returns
trueif thisResourceIdrepresents a directory, false otherwise. - isDisjoint(IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
-
Returns whether this window is disjoint from the given window.
- isDone() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
-
Returns true if the last call to
OffsetBasedSource.OffsetBasedReader.start()orOffsetBasedSource.OffsetBasedReader.advance()returned false. - isDone() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
- isDone() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
- isDone(CompletionStage<?>) - Static method in class org.apache.beam.sdk.util.MoreFutures
-
Indicates whether the future is done.
- isElementMetadata() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
- isEmpty() - Method in class org.apache.beam.sdk.fn.data.WeightedList
- isEmpty() - Method in class org.apache.beam.sdk.io.range.ByteKey
- isEmpty() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- isEmpty() - Method in interface org.apache.beam.sdk.state.GroupingState
-
Returns a
ReadableStatewhoseReadableState.read()method will return true if this state is empty at the point when thatReadableState.read()call returns. - isEmpty() - Method in interface org.apache.beam.sdk.state.MapState
-
Returns a
ReadableStatewhoseReadableState.read()method will return true if this state is empty at the point when thatReadableState.read()call returns. - isEmpty() - Method in interface org.apache.beam.sdk.state.MultimapState
-
Returns a
ReadableStatewhoseReadableState.read()method will return true if this state is empty at the point when thatReadableState.read()call returns. - isEmpty() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
- isEmpty() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
- isEmpty() - Method in class org.apache.beam.sdk.transforms.Requirements
-
Whether this is an empty set of requirements.
- isEncodingPositionsOverridden() - Method in class org.apache.beam.sdk.schemas.Schema
-
Returns whether encoding positions have been explicitly overridden.
- isEqualTo(T) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Asserts that the value in question is equal to the provided value, according to
Object.equals(java.lang.Object). - isException() - Method in class org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult
- isFirst() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
Return true if this is the first pane produced for the associated window.
- isGetter(Method) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
- isIn(Collection<T>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.isIn(Collection). - isIn(Coder<T>, Collection<T>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.isIn(Collection). - isIn(Coder<T>, T[]) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.isIn(Object[]). - isIn(T[]) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.isIn(Object[]). - isInsertDefault() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
Returns whether or not this transformation applies a default value.
- isIntegral(Schema.TypeName) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
-
Checks if type is integral.
- isKnownCoder(Coder<?>) - Static method in class org.apache.beam.sdk.util.construction.ModelCoderRegistrar
- isLast() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
Return true if this is the last pane that will be produced in the associated window.
- isLogicalType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
- isLogicalType(String) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
- isMapType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
- isMetadata() - Method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadata
- isMetadataSupported() - Static method in class org.apache.beam.sdk.values.WindowedValues.WindowedValueCoder
- isMetricsSupported() - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
-
Indicates whether metrics reporting is supported.
- isModeSpecified() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- isNative(RunnerApi.PTransform) - Static method in class org.apache.beam.sdk.util.construction.NativeTransforms
-
Returns true if an only if the Runner understands this transform and can handle it directly.
- isNonMerging() - Method in class org.apache.beam.sdk.transforms.windowing.NonMergingWindowFn
- isNonMerging() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
Returns true if this
WindowFnnever needs to merge any windows. - isNullable() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
Returns whether the field is nullable.
- isNumericType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
- isOneOf(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.isOneOf(T...). - isOneOf(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.isOneOf(T...). - isOpen() - Method in class org.apache.beam.sdk.util.ShardingWritableByteChannel
- isPrimitiveType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
- isReadSeekEfficient() - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata
- isReady() - Method in class org.apache.beam.sdk.fn.stream.DataStreams.DataStreamDecoder
- isReady() - Method in interface org.apache.beam.sdk.fn.stream.PrefetchableIterator
-
Returns
trueif and only ifIterator.hasNext()andIterator.next()will not require an expensive operation. - isRegisterByteSizeObserverCheap(byte[]) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(T) - Method in class org.apache.beam.sdk.coders.NullableCoder
-
NullableCoderis cheap ifvalueCoderis cheap. - isRegisterByteSizeObserverCheap(IterableT) - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(Boolean) - Method in class org.apache.beam.sdk.coders.BooleanCoder
- isRegisterByteSizeObserverCheap(Byte) - Method in class org.apache.beam.sdk.coders.ByteCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(Double) - Method in class org.apache.beam.sdk.coders.DoubleCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(Float) - Method in class org.apache.beam.sdk.coders.FloatCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(Integer) - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(Integer) - Method in class org.apache.beam.sdk.coders.VarIntCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(Long) - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(Long) - Method in class org.apache.beam.sdk.coders.VarLongCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(Short) - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(Void) - Method in class org.apache.beam.sdk.coders.VoidCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(BigDecimal) - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(BigInteger) - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(Optional<T>) - Method in class org.apache.beam.sdk.coders.OptionalCoder
-
OptionalCoderis cheap ifvalueCoderis cheap. - isRegisterByteSizeObserverCheap(EncodedBoundedWindow) - Method in class org.apache.beam.sdk.fn.windowing.EncodedBoundedWindow.Coder
- isRegisterByteSizeObserverCheap(OffsetRange) - Method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
- isRegisterByteSizeObserverCheap(RawUnionValue) - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
-
Since this coder uses elementCoders.get(index) and coders that are known to run in constant time, we defer the return value to that coder.
- isRegisterByteSizeObserverCheap(IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
- isRegisterByteSizeObserverCheap(ShardedKey<K>) - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
- isRegisterByteSizeObserverCheap(KV<K, V>) - Method in class org.apache.beam.sdk.coders.KvCoder
-
Returns whether both keyCoder and valueCoder are considered not expensive.
- isRegisterByteSizeObserverCheap(Instant) - Method in class org.apache.beam.sdk.coders.InstantCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(ReadableDuration) - Method in class org.apache.beam.sdk.coders.DurationCoder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(T) - Method in class org.apache.beam.sdk.coders.Coder
-
Returns whether
Coder.registerByteSizeObserver(T, org.apache.beam.sdk.util.common.ElementByteSizeObserver)cheap enough to call for every element, that is, if thisCodercan calculate the byte size of the element to be coded in roughly constant time (or lazily). - isRegisterByteSizeObserverCheap(T) - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
-
LengthPrefixCoderis cheap ifvalueCoderis cheap. - isRegisterByteSizeObserverCheap(T) - Method in class org.apache.beam.sdk.coders.TimestampPrefixingWindowCoder
- isRequiresStableInput() - Method in interface org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoLike
- isRequiresTimeSortedInput() - Method in interface org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoLike
- isRootNode() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
- isRowReceiver() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.OutputReceiverParameter
- isRunnerDeterminedSharding(AppliedPTransform<PCollection<T>, WriteFilesResult<DestinationT>, ? extends PTransform<PCollection<T>, WriteFilesResult<DestinationT>>>) - Static method in class org.apache.beam.sdk.util.construction.WriteFilesTranslation
- isSetter(Method) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
- isShutdown() - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- isSignificant() - Method in class org.apache.beam.sdk.util.BucketingFunction
-
Is the current result 'significant'? Ie is it drawn from enough buckets or from enough samples?
- isSignificant() - Method in class org.apache.beam.sdk.util.MovingFunction
-
Is the current result 'significant'? Ie is it drawn from enough buckets or from enough samples?
- isSplittable() - Method in class org.apache.beam.sdk.io.CompressedSource
-
Determines whether a single file represented by this source is splittable.
- isSplittable() - Method in class org.apache.beam.sdk.io.FileBasedSource
-
Determines whether a file represented by this source is can be split into bundles.
- isSplittable() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
-
Whether this
DoFnis splittable. - isSplittable() - Method in interface org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoLike
- isSplittable(AppliedPTransform<?, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- isSplittable(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- isStarted() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
-
Returns true if there has been a call to
OffsetBasedSource.OffsetBasedReader.start(). - isStarted() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
- isStateful() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Deprecated.use
DoFnSignature.usesState(), it's cleaner - isStateful() - Method in interface org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoLike
- isStateful(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- isStreaming() - Method in interface org.apache.beam.sdk.options.StreamingOptions
-
Set to true if running a streaming pipeline.
- isStringType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
- isSubtypeOf(Schema.TypeName) - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
- isSubtypeOf(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Return true if this type is a subtype of the given type.
- isSuccess() - Method in class org.apache.beam.sdk.testing.SuccessOrFailure
- isSupertypeOf(Schema.TypeName) - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
-
Whether this is a super type of the another type.
- isSupertypeOf(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns true if this type is assignable from the given type.
- isTerminal() - Method in enum org.apache.beam.sdk.PipelineResult.State
- isTerminated() - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- isTimer() - Method in class org.apache.beam.sdk.fn.data.LogicalEndpoint
- isTimestampCombinerSpecified() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- isTriggerSpecified() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- isUnknown() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
Return true if there is no timing information for the current
PaneInfo. - isWholeStream - Variable in class org.apache.beam.sdk.coders.Coder.Context
-
Deprecated.Whether the encoded or decoded value fills the remainder of the output or input (resp.) record/stream contents.
- isWindowedWrites(AppliedPTransform<PCollection<T>, WriteFilesResult<DestinationT>, ? extends PTransform<PCollection<T>, WriteFilesResult<DestinationT>>>) - Static method in class org.apache.beam.sdk.util.construction.WriteFilesTranslation
- item(String, Boolean) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and boolean value.
- item(String, Class<T>) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and class value.
- item(String, Double) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and floating point value.
- item(String, Float) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and floating point value.
- item(String, Integer) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and integer value.
- item(String, Long) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and integer value.
- item(String, String) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and string value.
- item(String, ValueProvider<?>) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and
ValueProvider. - item(String, Duration) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and duration value.
- item(String, Instant) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and timestamp value.
- item(String, DisplayData.Type, T) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key, type, and value.
- Item() - Constructor for class org.apache.beam.sdk.transforms.display.DisplayData.Item
- items() - Method in class org.apache.beam.sdk.transforms.display.DisplayData
- ItemSpec() - Constructor for class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
- iterable() - Static method in class org.apache.beam.sdk.transforms.Materializations
-
For internal use only; no backwards-compatibility guarantees.
- iterable(Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
- ITERABLE - org.apache.beam.sdk.schemas.Schema.TypeName
- ITERABLE_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- ITERABLE_MATERIALIZATION_URN - Static variable in class org.apache.beam.sdk.transforms.Materializations
-
The URN for a
Materializationwhere the primitive view type is an iterable of fully specified windowed values. - IterableBackedListViewFn(PCollectionViews.TypeDescriptorSupplier<T>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.IterableBackedListViewFn
- IterableCoder<T> - Class in org.apache.beam.sdk.coders
- IterableCoder(Coder<T>) - Constructor for class org.apache.beam.sdk.coders.IterableCoder
- IterableLikeCoder<T,IterableT extends java.lang.Iterable<T>> - Class in org.apache.beam.sdk.coders
-
An abstract base class with functionality for assembling a
Coderfor a class that implementsIterable. - IterableLikeCoder(Coder<T>, String) - Constructor for class org.apache.beam.sdk.coders.IterableLikeCoder
- iterables() - Static method in class org.apache.beam.sdk.transforms.Flatten
-
Returns a
PTransformthat takes aPCollection<Iterable<T>>and returns aPCollection<T>containing all the elements from all theIterables. - iterables() - Static method in class org.apache.beam.sdk.transforms.ToString
-
Transforms each item in the iterable of the input
PCollectionto aStringusing theObject.toString()method followed by a "," until the last element in the iterable. - iterables(String) - Static method in class org.apache.beam.sdk.transforms.ToString
-
Transforms each item in the iterable of the input
PCollectionto aStringusing theObject.toString()method followed by the specified delimiter until the last element in the iterable. - iterables(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorforIterable. - iterableView(PCollection<T>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<Iterable<T>>capable of processing elements windowed using the providedWindowingStrategy. - IterableViewFn(PCollectionViews.TypeDescriptorSupplier<T>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn
-
Deprecated.
- IterableViewFn2(PCollectionViews.TypeDescriptorSupplier<T>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn2
- iterableViewUsingVoidKey(TupleTag<Materializations.MultimapView<Void, T>>, PCollection<KV<Void, T>>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
- iterableWithSize(int) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.iterableWithSize(int). - iterableWithSize(SerializableMatcher<? super Integer>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.iterableWithSize(Matcher). - iterator() - Method in interface org.apache.beam.sdk.fn.stream.PrefetchableIterable
- iterator() - Method in class org.apache.beam.sdk.fn.stream.PrefetchableIterables.Default
- iterator() - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObservableIterable
-
Returns a new iterator for this iterable.
- iterator() - Method in interface org.apache.beam.sdk.util.common.Reiterable
J
- JAVA_CLASS - org.apache.beam.sdk.transforms.display.DisplayData.Type
- JAVA_SDK_HARNESS_ENVIRONMENT - Static variable in class org.apache.beam.sdk.util.construction.Environments
- JAVA_SERIALIZED_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.CoderTranslation
- java11 - org.apache.beam.sdk.util.construction.Environments.JavaVersion
- java17 - org.apache.beam.sdk.util.construction.Environments.JavaVersion
- java21 - org.apache.beam.sdk.util.construction.Environments.JavaVersion
- java25 - org.apache.beam.sdk.util.construction.Environments.JavaVersion
- JavaBeanSchema - Class in org.apache.beam.sdk.schemas
-
A
SchemaProviderfor Java Bean objects. - JavaBeanSchema() - Constructor for class org.apache.beam.sdk.schemas.JavaBeanSchema
- JavaBeanSchema.GetterTypeSupplier - Class in org.apache.beam.sdk.schemas
-
FieldValueTypeSupplierthat's based on getter methods. - JavaBeanSchema.SetterTypeSupplier - Class in org.apache.beam.sdk.schemas
-
FieldValueTypeSupplierthat's based on setter methods. - JavaBeanUtils - Class in org.apache.beam.sdk.schemas.utils
-
A set of utilities to generate getter and setter classes for JavaBean objects.
- JavaBeanUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
- JavaExplodeTransformProvider - Class in org.apache.beam.sdk.schemas.transforms.providers
-
An implementation of
TypedSchemaTransformProviderfor Explode. - JavaExplodeTransformProvider() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider
- JavaExplodeTransformProvider.Configuration - Class in org.apache.beam.sdk.schemas.transforms.providers
- JavaExplodeTransformProvider.Configuration.Builder - Class in org.apache.beam.sdk.schemas.transforms.providers
- JavaExplodeTransformProvider.ExplodeTransform - Class in org.apache.beam.sdk.schemas.transforms.providers
-
A
SchemaTransformfor Explode. - JavaFieldSchema - Class in org.apache.beam.sdk.schemas
-
A
SchemaProviderfor Java POJO objects. - JavaFieldSchema() - Constructor for class org.apache.beam.sdk.schemas.JavaFieldSchema
- JavaFieldSchema.JavaFieldTypeSupplier - Class in org.apache.beam.sdk.schemas
-
FieldValueTypeSupplierthat's based on public fields. - JavaFieldTypeSupplier() - Constructor for class org.apache.beam.sdk.schemas.JavaFieldSchema.JavaFieldTypeSupplier
- JavaFilterTransformProvider - Class in org.apache.beam.sdk.schemas.transforms.providers
-
An implementation of
TypedSchemaTransformProviderfor Filter for the java language. - JavaFilterTransformProvider() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider
- JavaFilterTransformProvider.Configuration - Class in org.apache.beam.sdk.schemas.transforms.providers
- JavaFilterTransformProvider.Configuration.Builder - Class in org.apache.beam.sdk.schemas.transforms.providers
- JavaFilterTransformProvider.JavaFilterTransform - Class in org.apache.beam.sdk.schemas.transforms.providers
-
A
SchemaTransformfor Filter-java. - JavaMapToFieldsTransformProvider - Class in org.apache.beam.sdk.schemas.transforms.providers
-
An implementation of
TypedSchemaTransformProviderfor MapToFields for the java language. - JavaMapToFieldsTransformProvider() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider
- JavaMapToFieldsTransformProvider.Configuration - Class in org.apache.beam.sdk.schemas.transforms.providers
- JavaMapToFieldsTransformProvider.Configuration.Builder - Class in org.apache.beam.sdk.schemas.transforms.providers
- JavaMapToFieldsTransformProvider.JavaMapToFieldsTransform - Class in org.apache.beam.sdk.schemas.transforms.providers
-
A
SchemaTransformfor MapToFields-java. - JavaRowUdf - Class in org.apache.beam.sdk.schemas.transforms.providers
- JavaRowUdf(JavaRowUdf.Configuration, Schema) - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf
- JavaRowUdf.Configuration - Class in org.apache.beam.sdk.schemas.transforms.providers
- JavaRowUdf.Configuration.Builder - Class in org.apache.beam.sdk.schemas.transforms.providers
- javaTypeForFieldType(Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.FieldTypeDescriptors
-
Get a
TypeDescriptorfrom aSchema.FieldType. - JobNameFactory() - Constructor for class org.apache.beam.sdk.options.PipelineOptions.JobNameFactory
- join(String, CoGroup.By) - Method in class org.apache.beam.sdk.schemas.transforms.CoGroup.ExpandCrossProduct
-
Select the following fields for the specified PCollection with the specified join args.
- join(String, CoGroup.By) - Method in class org.apache.beam.sdk.schemas.transforms.CoGroup.Impl
-
Select the following fields for the specified PCollection with the specified join args.
- join(String, CoGroup.By) - Static method in class org.apache.beam.sdk.schemas.transforms.CoGroup
-
Specify the following join arguments (including fields to join by_ for the specified PCollection.
- join(CoGroup.By) - Static method in class org.apache.beam.sdk.schemas.transforms.CoGroup
-
Join all input PCollections using the same args.
- Join - Class in org.apache.beam.sdk.schemas.transforms
-
A transform that performs equijoins across two schema
PCollections. - Join() - Constructor for class org.apache.beam.sdk.schemas.transforms.Join
- Join.FieldsEqual - Class in org.apache.beam.sdk.schemas.transforms
-
Predicate object to specify fields to compare when doing an equi-join.
- Join.FieldsEqual.Impl - Class in org.apache.beam.sdk.schemas.transforms
-
Implementation class for FieldsEqual.
- Join.Impl<LhsT,RhsT> - Class in org.apache.beam.sdk.schemas.transforms
-
Implementation class .
- jsonBytesLike(String) - Static method in class org.apache.beam.sdk.testing.JsonMatcher
- jsonBytesLike(Map<String, Object>) - Static method in class org.apache.beam.sdk.testing.JsonMatcher
- JsonMatcher<T> - Class in org.apache.beam.sdk.testing
-
Matcher to compare a string or byte[] representing a JSON Object, independent of field order.
- JsonMatcher(Map<String, Object>) - Constructor for class org.apache.beam.sdk.testing.JsonMatcher
- JsonPayloadSerializerProvider - Class in org.apache.beam.sdk.schemas.io.payloads
- JsonPayloadSerializerProvider() - Constructor for class org.apache.beam.sdk.schemas.io.payloads.JsonPayloadSerializerProvider
- jsonSchemaFromBeamSchema(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.JsonUtils
- jsonSchemaStringFromBeamSchema(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.JsonUtils
- jsonStringLike(String) - Static method in class org.apache.beam.sdk.testing.JsonMatcher
- jsonStringLike(Map<String, Object>) - Static method in class org.apache.beam.sdk.testing.JsonMatcher
- jsonStringToByteArray(String) - Static method in class org.apache.beam.sdk.util.StringUtils
-
Converts the given string, encoded using
StringUtils.byteArrayToJsonString(byte[]), into a byte array. - jsonToRow(ObjectMapper, String) - Static method in class org.apache.beam.sdk.util.RowJsonUtils
- JsonToRow - Class in org.apache.beam.sdk.transforms
- JsonToRow() - Constructor for class org.apache.beam.sdk.transforms.JsonToRow
- JsonToRow.JsonToRowWithErrFn - Class in org.apache.beam.sdk.transforms
- JsonToRow.JsonToRowWithErrFn.Builder - Class in org.apache.beam.sdk.transforms
- JsonToRow.JsonToRowWithErrFn.ParseWithError - Class in org.apache.beam.sdk.transforms
- JsonToRow.JsonToRowWithErrFn.ParseWithError.Builder - Class in org.apache.beam.sdk.transforms
- JsonToRow.ParseResult - Class in org.apache.beam.sdk.transforms
-
The result of a
JsonToRow.withExceptionReporting(Schema)transform. - JsonToRow.ParseResult.Builder - Class in org.apache.beam.sdk.transforms
- JsonToRowWithErrFn() - Constructor for class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
- JsonUtils - Class in org.apache.beam.sdk.schemas.utils
-
Utils to convert JSON records to Beam
Row. - JsonUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.JsonUtils
- JvmInitializer - Interface in org.apache.beam.sdk.harness
-
A service interface for defining one-time initialization of the JVM during pipeline execution.
- JvmInitializers - Class in org.apache.beam.sdk.fn
-
Helpers for executing
JvmInitializerimplementations. - JvmInitializers() - Constructor for class org.apache.beam.sdk.fn.JvmInitializers
K
- keep(List<String>) - Method in class org.apache.beam.sdk.util.RowFilter
- KEEP_NESTED_NAME - Static variable in class org.apache.beam.sdk.schemas.utils.SelectHelpers
-
This policy keeps the raw nested field name.
- keepMostNestedFieldName() - Method in class org.apache.beam.sdk.schemas.transforms.Select.Flattened
-
For nested fields, keep just the most-nested field name.
- key() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provide a reference to the input element key in
KVpair. - key() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- key() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- keyCoderId() - Method in class org.apache.beam.sdk.util.construction.ModelCoders.KvCoderComponents
- KeyedPCollectionTuple<K> - Class in org.apache.beam.sdk.transforms.join
-
An immutable tuple of keyed
PCollectionswith key type K. - KeyedPCollectionTuple.TaggedKeyedPCollection<K,V> - Class in org.apache.beam.sdk.transforms.join
-
A utility class to help ensure coherence of tag and input PCollection types.
- keyedValues() - Static method in class org.apache.beam.sdk.transforms.Deduplicate
-
Returns a deduplication transform that deduplicates keyed values using the key for up to 10 mins within the
processing time domain. - keys() - Method in interface org.apache.beam.sdk.state.MapState
-
Returns an
Iterableover the keys contained in this map. - keys() - Method in interface org.apache.beam.sdk.state.MultimapState
-
Returns an
Iterableover the keys contained in this multimap. - Keys<K> - Class in org.apache.beam.sdk.transforms
-
Keys<K>takes aPCollectionofKV<K, V>s and returns aPCollection<K>of the keys. - keySet() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- keyT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.KeyParameter
- keyT(TypeDescriptor<?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
-
Returns a
DoFnSignature.Parameter.KeyParameter. - knownBuilderInstances() - Method in interface org.apache.beam.sdk.expansion.ExternalTransformRegistrar
-
A mapping from URN to an
ExternalTransformBuilderinstance. - knownBuilders() - Method in interface org.apache.beam.sdk.expansion.ExternalTransformRegistrar
-
Deprecated.Prefer implementing 'knownBuilderInstances'. This method will be removed in a future version of Beam.
- knownBuilders() - Method in class org.apache.beam.sdk.io.GenerateSequence.External
- kv(SerializableMatcher<? super K>, SerializableMatcher<? super V>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherthat matches anyKVwith matching key and value. - KV<K,V> - Class in org.apache.beam.sdk.values
-
An immutable key/value pair.
- KV_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- KV.OrderByKey<K extends java.lang.Comparable<? super K>,V> - Class in org.apache.beam.sdk.values
-
A
Comparatorthat ordersKVsby the natural ordering of their keys. - KV.OrderByValue<K,V extends java.lang.Comparable<? super V>> - Class in org.apache.beam.sdk.values
-
A
Comparatorthat ordersKVsby the natural ordering of their values. - kvCoder(String, String) - Static method in class org.apache.beam.sdk.util.construction.ModelCoders
- KvCoder<K extends @Nullable java.lang.Object,V extends @Nullable java.lang.Object> - Class in org.apache.beam.sdk.coders
-
A
KvCoderencodesKVs. - KvCoderComponents() - Constructor for class org.apache.beam.sdk.util.construction.ModelCoders.KvCoderComponents
- kvs() - Static method in class org.apache.beam.sdk.transforms.ToString
-
Transforms each element of the input
PCollectionto aStringby using theObject.toString()on the key followed by a "," followed by theObject.toString()of the value. - kvs(String) - Static method in class org.apache.beam.sdk.transforms.ToString
-
Transforms each element of the input
PCollectionto aStringby using theObject.toString()on the key followed by the specified delimiter followed by theObject.toString()of the value. - kvs(TypeDescriptor<K>, TypeDescriptor<V>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorforKV. - KvSwap<K,V> - Class in org.apache.beam.sdk.transforms
-
KvSwap<K, V>takes aPCollection<KV<K, V>>and returns aPCollection<KV<V, K>>, where all the keys and values have been swapped. - kvWithKey(K) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherthat matches anyKVwith the specified key. - kvWithKey(Coder<K>, K) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherthat matches anyKVwith the specified key. - kvWithKey(SerializableMatcher<? super K>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherthat matches anyKVwith matching key. - kvWithValue(Coder<V>, V) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherthat matches anyKVwith the specified value. - kvWithValue(SerializableMatcher<? super V>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherthat matches anyKVwith matching value. - kvWithValue(V) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherthat matches anyKVwith the specified value.
L
- LabeledMetricNameUtils - Class in org.apache.beam.sdk.metrics
-
Util class for building/parsing labeled
MetricName. - LabeledMetricNameUtils() - Constructor for class org.apache.beam.sdk.metrics.LabeledMetricNameUtils
- LabeledMetricNameUtils.MetricNameBuilder - Class in org.apache.beam.sdk.metrics
-
Builder class for a labeled
MetricName. - LabeledMetricNameUtils.ParsedMetricName - Class in org.apache.beam.sdk.metrics
- LABELLED - Static variable in class org.apache.beam.sdk.util.construction.DisplayDataTranslation
- LargeKeys - Interface in org.apache.beam.sdk.testing
-
Category tags for tests which validate that a Beam runner can handle keys up to a given size.
- LargeKeys.Above100KB - Interface in org.apache.beam.sdk.testing
-
Tests if a runner supports 100KB keys.
- LargeKeys.Above100MB - Interface in org.apache.beam.sdk.testing
-
Tests if a runner supports 100MB keys.
- LargeKeys.Above10KB - Interface in org.apache.beam.sdk.testing
-
Tests if a runner supports 10KB keys.
- LargeKeys.Above10MB - Interface in org.apache.beam.sdk.testing
-
Tests if a runner supports 10MB keys.
- LargeKeys.Above1MB - Interface in org.apache.beam.sdk.testing
-
Tests if a runner supports 1MB keys.
- largest(int) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a
PTransformthat takes an inputPCollection<T>and returns aPCollection<List<T>>with a single element containing the largestcountelements of the inputPCollection<T>, in decreasing order, sorted according to their natural order. - Largest() - Constructor for class org.apache.beam.sdk.transforms.Top.Largest
-
Deprecated.
- largestDoublesFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a
Top.TopCombineFnthat aggregates the largest count double values. - largestFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a
Top.TopCombineFnthat aggregates the largest count values. - largestIntsFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a
Top.TopCombineFnthat aggregates the largest count int values. - largestLongsFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a
Top.TopCombineFnthat aggregates the largest count long values. - largestPerKey(int) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a
PTransformthat takes an inputPCollection<KV<K, V>>and returns aPCollection<KV<K, List<V>>>that contains an output element mapping each distinct key in the inputPCollectionto the largestcountvalues associated with that key in the inputPCollection<KV<K, V>>, in decreasing order, sorted according to their natural order. - LargestUnique(long) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique
-
Deprecated.Creates a heap to track the largest
sampleSizeelements. - last - Variable in class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
- lastAttemptedOffset - Variable in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
- lastClaimedOffset - Variable in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
- lastModifiedMillis() - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata
-
Last modification timestamp in milliseconds since Unix epoch.
- LATE - org.apache.beam.sdk.transforms.windowing.PaneInfo.Timing
-
Pane was fired after the output watermark had progressed past the end of the window.
- Latest - Class in org.apache.beam.sdk.transforms
- LATEST - org.apache.beam.sdk.transforms.windowing.TimestampCombiner
-
The policy of taking the latest of a set of timestamps.
- LEAST_SIGNIFICANT_BITS_FIELD_NAME - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.UuidLogicalType
- leaveCompositeTransform(TransformHierarchy.Node) - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
- leaveCompositeTransform(TransformHierarchy.Node) - Method in interface org.apache.beam.sdk.Pipeline.PipelineVisitor
-
Called for each composite transform after all of its component transforms and their outputs have been visited.
- leaveCompositeTransform(TransformHierarchy.Node) - Method in class org.apache.beam.sdk.util.construction.renderer.PipelineDotRenderer
- leavePipeline(Pipeline) - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
- leavePipeline(Pipeline) - Method in interface org.apache.beam.sdk.Pipeline.PipelineVisitor
-
Called when all values and transforms in a
Pipelinehave been visited. - leavePipeline(Pipeline) - Method in class org.apache.beam.sdk.util.construction.renderer.PipelineDotRenderer
- left(Integer...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual.Impl
- left(Integer...) - Static method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual
- left(String...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual.Impl
- left(String...) - Static method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual
- left(FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual.Impl
- left(FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual
- leftOuterBroadcastJoin(PCollection<RhsT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Join
-
Perform a left outer join, broadcasting the right side.
- leftOuterJoin(PCollection<RhsT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Join
-
Perform a left outer join.
- leftTruncate(Object, int) - Static method in class org.apache.beam.sdk.util.StringUtils
-
Truncate String if length greater than maxLen, and append "..." to the end.
- legacyName() - Method in enum org.apache.beam.sdk.util.construction.Environments.JavaVersion
- LENGTH_PREFIX_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- LengthPrefixCoder<T> - Class in org.apache.beam.sdk.coders
-
A
Coderwhich is able to take any existing coder and wrap it such that it is only invoked in theouter context. - lessThan(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.lessThan(Comparable). - lessThan(T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.lessThan(Comparable). - lessThan(T) - Static method in class org.apache.beam.sdk.transforms.Filter
-
Returns a
PTransformthat takes an inputPCollectionand returns aPCollectionwith elements that are less than a given value, based on the elements' natural ordering. - lessThanEq(T) - Static method in class org.apache.beam.sdk.transforms.Filter
-
Returns a
PTransformthat takes an inputPCollection<T>and returns aPCollection<T>with elements that are less than or equal to a given value, based on the elements' natural ordering. - lessThanOrEqualTo(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.lessThanOrEqualTo(Comparable). - lessThanOrEqualTo(T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.lessThanOrEqualTo(Comparable). - LEVEL_CONFIGURATION - Static variable in enum org.apache.beam.sdk.options.SdkHarnessOptions.LogLevel
-
Map from LogLevel enums to java logging level.
- LHS_TAG - Static variable in class org.apache.beam.sdk.schemas.transforms.Join
- LifecycleMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.LifecycleMethod
- limit(Iterable<T>, int) - Static method in class org.apache.beam.sdk.fn.stream.PrefetchableIterables
-
Limits the
PrefetchableIterableto the specified number of elements. - LimitNumberOfFiles(int) - Constructor for class org.apache.beam.sdk.io.TextRowCountEstimator.LimitNumberOfFiles
- LimitNumberOfTotalBytes(long) - Constructor for class org.apache.beam.sdk.io.TextRowCountEstimator.LimitNumberOfTotalBytes
- Lineage - Class in org.apache.beam.sdk.metrics
-
Standard collection of metrics used to record source and sinks information for lineage tracking.
- LINEAGE_NAMESPACE - Static variable in class org.apache.beam.sdk.metrics.Lineage
- Lineage.Type - Enum in org.apache.beam.sdk.metrics
-
Lineage metrics resource types.
- linear(double, double, int) - Static method in class org.apache.beam.sdk.util.HistogramData
-
TODO(https://github.com/apache/beam/issues/20853): Update this function to define numBuckets total, including the infinite buckets.
- LinearBuckets() - Constructor for class org.apache.beam.sdk.util.HistogramData.LinearBuckets
- LIST - org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier.Kind
- ListCoder<T> - Class in org.apache.beam.sdk.coders
- ListCoder(Coder<T>) - Constructor for class org.apache.beam.sdk.coders.ListCoder
- lists(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorforList. - listView(PCollection<T>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<List<T>>capable of processing elements windowed using the providedWindowingStrategy. - listView(PCollection<T>, TupleTag<Materializations.IterableView<T>>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<List<T>>capable of processing elements windowed using the providedWindowingStrategy. - ListViewFn(PCollectionViews.TypeDescriptorSupplier<T>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.ListViewFn
-
Deprecated.
- ListViewFn2(PCollectionViews.TypeDescriptorSupplier<T>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.ListViewFn2
- listViewUsingVoidKey(PCollection<KV<Void, T>>, TupleTag<Materializations.MultimapView<Void, T>>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
- listViewUsingVoidKey(TupleTag<Materializations.MultimapView<Void, T>>, PCollection<KV<Void, T>>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
- listViewWithRandomAccess(PCollection<KV<Long, PCollectionViews.ValueOrMetadata<T, OffsetRange>>>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<List<T>>capable of processing elements windowed using the providedWindowingStrategy. - listViewWithRandomAccess(PCollection<KV<Long, PCollectionViews.ValueOrMetadata<T, OffsetRange>>>, TupleTag<Materializations.MultimapView<Long, PCollectionViews.ValueOrMetadata<T, OffsetRange>>>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<List<T>>capable of processing elements windowed using the providedWindowingStrategy. - loadFromStream(InputStream) - Static method in class org.apache.beam.sdk.schemas.utils.YamlUtils
- loadProviders(Class<T>) - Static method in class org.apache.beam.sdk.schemas.io.Providers
- loadServicesOrdered(Class<T>) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
-
A version of
loadServicesOrderedthat uses a default class loader. - loadServicesOrdered(Class<T>, ClassLoader) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
-
Returns instances of all implementations of the specified
iface. - LocalFileSystemRegistrar - Class in org.apache.beam.sdk.io
-
AutoServiceregistrar for theLocalFileSystem. - LocalFileSystemRegistrar() - Constructor for class org.apache.beam.sdk.io.LocalFileSystemRegistrar
- localName() - Method in class org.apache.beam.sdk.util.construction.graph.SideInputReference
-
The local name the referencing PTransform uses to refer to this side input.
- localName() - Method in class org.apache.beam.sdk.util.construction.graph.TimerReference
-
The local name the referencing PTransform uses to refer to this timer.
- localName() - Method in class org.apache.beam.sdk.util.construction.graph.UserStateReference
-
The local name the referencing PTransform uses to refer to this user state.
- LocalResources - Class in org.apache.beam.sdk.io
-
Helper functions for producing a
ResourceIdthat references a local file or directory. - lock() - Method in class org.apache.beam.sdk.util.NoopLock
- lockInterruptibly() - Method in class org.apache.beam.sdk.util.NoopLock
- LoggingTransformProvider - Class in org.apache.beam.sdk.schemas.transforms.providers
-
An implementation of
TypedSchemaTransformProviderfor Logging. - LoggingTransformProvider() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider
- LoggingTransformProvider.Configuration - Class in org.apache.beam.sdk.schemas.transforms.providers
- LoggingTransformProvider.Configuration.Builder - Class in org.apache.beam.sdk.schemas.transforms.providers
- LoggingTransformProvider.LoggingTransform - Class in org.apache.beam.sdk.schemas.transforms.providers
-
A
SchemaTransformfor logging. - LOGICAL_TYPE - org.apache.beam.sdk.schemas.Schema.TypeName
- LogicalEndpoint - Class in org.apache.beam.sdk.fn.data
-
A logical endpoint is a pair of an instruction ID corresponding to the
BeamFnApi.ProcessBundleRequestand the transform within the processing graph. - LogicalEndpoint() - Constructor for class org.apache.beam.sdk.fn.data.LogicalEndpoint
- logicalType(Schema.LogicalType<InputT, BaseT>) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Creates a logical type based on a primitive field type.
- longs() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorfor Long. - longsGlobally() - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a
PTransformthat takes an inputPCollection<Long>and returns aPCollection<Long>whose contents is the maximum of the inputPCollection's elements, orLong.MIN_VALUEif there are no elements. - longsGlobally() - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a
PTransformthat takes an inputPCollection<Long>and returns aPCollection<Long>whose contents is the minimum of the inputPCollection's elements, orLong.MAX_VALUEif there are no elements. - longsGlobally() - Static method in class org.apache.beam.sdk.transforms.Sum
-
Returns a
PTransformthat takes an inputPCollection<Long>and returns aPCollection<Long>whose contents is the sum of the inputPCollection's elements, or0if there are no elements. - longsPerKey() - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a
PTransformthat takes an inputPCollection<KV<K, Long>>and returns aPCollection<KV<K, Long>>that contains an output element mapping each distinct key in the inputPCollectionto the maximum of the values associated with that key in the inputPCollection. - longsPerKey() - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a
PTransformthat takes an inputPCollection<KV<K, Long>>and returns aPCollection<KV<K, Long>>that contains an output element mapping each distinct key in the inputPCollectionto the minimum of the values associated with that key in the inputPCollection. - longsPerKey() - Static method in class org.apache.beam.sdk.transforms.Sum
-
Returns a
PTransformthat takes an inputPCollection<KV<K, Long>>and returns aPCollection<KV<K, Long>>that contains an output element mapping each distinct key in the inputPCollectionto the sum of the values associated with that key in the inputPCollection. - LZO - org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.
- LZO - org.apache.beam.sdk.io.Compression
-
LZO compression using LZO codec.
- LZO - org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.
- LzoCompression - Class in org.apache.beam.sdk.util
- LzoCompression() - Constructor for class org.apache.beam.sdk.util.LzoCompression
- LZOP - org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.
- LZOP - org.apache.beam.sdk.io.Compression
-
LZOP compression using LZOP codec.
- LZOP - org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.
M
- makeOutput(FileIO.ReadableFile, OffsetRange, FileBasedSource<InT>, BoundedSource.BoundedReader<InT>) - Method in class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform.AbstractReadFileRangesFn
- MANAGED_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- ManagedChannelFactory - Class in org.apache.beam.sdk.fn.channel
-
A Factory which creates
ManagedChannelinstances. - Manual(Instant) - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.Manual
- ManualDockerEnvironmentOptions - Interface in org.apache.beam.sdk.options
-
Pipeline options to tune DockerEnvironment.
- ManualDockerEnvironmentOptions.Options - Class in org.apache.beam.sdk.options
-
Register the
ManualDockerEnvironmentOptions. - ManualWatermarkEstimator<WatermarkEstimatorStateT> - Interface in org.apache.beam.sdk.transforms.splittabledofn
-
A
WatermarkEstimatorwhich is controlled manually from within aDoFn. - map() - Static method in class org.apache.beam.sdk.state.StateSpecs
- map(Coder<K>, Coder<V>) - Static method in class org.apache.beam.sdk.state.StateSpecs
-
Identical to
StateSpecs.map(), but with key and value coders explicitly supplied. - map(Schema.FieldType, Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Create a map type for the given key and value types.
- map(Schema.FieldType, Schema.FieldType, boolean) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Deprecated.Set the nullability on the valueType instead
- MAP - org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier.Kind
- MAP - org.apache.beam.sdk.schemas.Schema.TypeName
- MAP_TYPES - Static variable in enum org.apache.beam.sdk.schemas.Schema.TypeName
- MAP_WINDOWS_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- MapCoder<K,V> - Class in org.apache.beam.sdk.coders
-
A
CoderforMapsthat encodes them according to provided coders for keys and values. - MapElements<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
PTransforms for mapping a simple function over the elements of aPCollection. - MapElements.MapWithFailures<InputT,OutputT,FailureT> - Class in org.apache.beam.sdk.transforms
-
A
PTransformthat adds exception handling toMapElements. - MapKeys<K1,K2,V> - Class in org.apache.beam.sdk.transforms
-
MapKeysmaps aSerializableFunction<K1,K2>over keys of aPCollection<KV<K1,V>>and returns aPCollection<KV<K2, V>>. - mapOutputs(Map<TupleTag<?>, PCollection<?>>, PCollection<T>) - Method in class org.apache.beam.sdk.util.construction.DeduplicatedFlattenFactory
- mapOutputs(Map<TupleTag<?>, PCollection<?>>, PCollection<T>) - Method in class org.apache.beam.sdk.util.construction.EmptyFlattenAsCreateFactory
- mapOutputs(Map<TupleTag<?>, PCollection<?>>, PCollection<T>) - Method in class org.apache.beam.sdk.util.construction.PrimitiveCreate.Factory
- mapOutputs(Map<TupleTag<?>, PCollection<?>>, PCollectionTuple) - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.OverrideFactory
- mapOutputs(Map<TupleTag<?>, PCollection<?>>, PCollectionTuple) - Method in class org.apache.beam.sdk.util.construction.SplittableParDoNaiveBounded.OverrideFactory
- mapOutputs(Map<TupleTag<?>, PCollection<?>>, OutputT) - Method in interface org.apache.beam.sdk.runners.PTransformOverrideFactory
-
Returns a
Mapfrom the expanded values innewOutputto the values produced by the original transform. - mapOutputs(Map<TupleTag<?>, PCollection<?>>, OutputT) - Method in class org.apache.beam.sdk.util.construction.SingleInputOutputOverrideFactory
- mapOutputs(Map<TupleTag<?>, PCollection<?>>, OutputT) - Method in class org.apache.beam.sdk.util.construction.UnsupportedOverrideFactory
- mapQualifier() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- mapQualifier() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierListContext
- MapQualifierContext(ParserRuleContext, int) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierContext
- MapQualifierListContext(FieldSpecifierNotationParser.QualifierListContext) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierListContext
- maps(TypeDescriptor<K>, TypeDescriptor<V>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorforMap. - MapState<K,V> - Interface in org.apache.beam.sdk.state
-
A
ReadableStatecell mapping keys to values. - MapValues<K,V1,V2> - Class in org.apache.beam.sdk.transforms
-
MapValuesmaps aSerializableFunction<V1,V2>over values of aPCollection<KV<K,V1>>and returns aPCollection<KV<K, V2>>. - mapView(PCollection<KV<K, V>>, PCollectionViews.TypeDescriptorSupplier<K>, PCollectionViews.TypeDescriptorSupplier<V>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<Map<K, V>>capable of processing elements windowed using the providedWindowingStrategy. - MapViewFn(PCollectionViews.TypeDescriptorSupplier<K>, PCollectionViews.TypeDescriptorSupplier<V>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.MapViewFn
-
Deprecated.
- MapViewFn2(PCollectionViews.TypeDescriptorSupplier<K>, PCollectionViews.TypeDescriptorSupplier<V>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.MapViewFn2
- mapViewUsingVoidKey(TupleTag<Materializations.MultimapView<Void, KV<K, V>>>, PCollection<KV<Void, KV<K, V>>>, PCollectionViews.TypeDescriptorSupplier<K>, PCollectionViews.TypeDescriptorSupplier<V>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
- mark(int) - Method in class org.apache.beam.sdk.util.UnownedInputStream
- markDone() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
-
Marks this range tracker as being done.
- markDone() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
-
Marks this range tracker as being done.
- markElementStart() - Method in class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
-
Marks that a new element is being output.
- markSupported() - Method in class org.apache.beam.sdk.util.UnownedInputStream
- match() - Static method in class org.apache.beam.sdk.io.FileIO
-
Matches a filepattern using
FileSystems.match(java.util.List<java.lang.String>)and produces a collection of matched resources (both files and directories) asMatchResult.Metadata. - match(String) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Like
FileSystems.match(List), but for a single resource specification. - match(String, EmptyMatchTreatment) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Like
FileSystems.match(String), but with a configurableEmptyMatchTreatment. - match(List<String>) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
- match(List<String>) - Method in class org.apache.beam.sdk.io.FileSystem
-
This is the entry point to convert user-provided specs to
ResourceIds. - match(List<String>) - Static method in class org.apache.beam.sdk.io.FileSystems
-
This is the entry point to convert user-provided specs to
ResourceIds. - match(List<String>, EmptyMatchTreatment) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Like
FileSystems.match(List), but with a configurableEmptyMatchTreatment. - match(StateSpec.Cases<ResultT>) - Method in interface org.apache.beam.sdk.state.StateSpec
-
For internal use only; no backwards-compatibility guarantees.
- match(DoFnSignature.Parameter.Cases<ResultT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
-
Performs case analysis on this
DoFnSignature.Parameter, processing it with the appropriateDoFnSignature.Parameter.Cases.dispatch(org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.StartBundleContextParameter)case of the providedDoFnSignature.Parameter.Casesobject. - Match() - Constructor for class org.apache.beam.sdk.io.FileIO.Match
- matchAll() - Static method in class org.apache.beam.sdk.io.FileIO
-
Like
FileIO.match(), but matches each filepattern in a collection of filepatterns. - MatchAll() - Constructor for class org.apache.beam.sdk.io.FileIO.MatchAll
- MatchConfiguration() - Constructor for class org.apache.beam.sdk.io.FileIO.MatchConfiguration
- MatcherCheckerFn(SerializableMatcher<T>) - Constructor for class org.apache.beam.sdk.testing.PAssert.MatcherCheckerFn
- matches(Object) - Method in class org.apache.beam.sdk.testing.RegexMatcher
- matches(Object) - Method in class org.apache.beam.sdk.testing.TestPipelineOptions.AlwaysPassMatcher
- matches(String) - Method in enum org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.Returns
trueif the given file name implies that the contents are compressed according to the compression embodied by this factory. - matches(String) - Method in enum org.apache.beam.sdk.io.Compression
- matches(String) - Method in enum org.apache.beam.sdk.io.TextIO.CompressionType
-
Deprecated.
- matches(String) - Method in enum org.apache.beam.sdk.io.TFRecordIO.CompressionType
-
Deprecated.
- matches(String) - Static method in class org.apache.beam.sdk.testing.RegexMatcher
- matches(String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.MatchesPTransformthat checks if the entire line matches the Regex. - matches(String, int) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.MatchesPTransformthat checks if the entire line matches the Regex. - matches(String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.MatchesNamePTransformthat checks if the entire line matches the Regex. - matches(Pattern) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.MatchesPTransformthat checks if the entire line matches the Regex. - matches(Pattern, int) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.MatchesPTransformthat checks if the entire line matches the Regex. - matches(Pattern, String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.MatchesNamePTransformthat checks if the entire line matches the Regex. - matches(MetricsFilter, MetricKey) - Static method in class org.apache.beam.sdk.metrics.MetricFiltering
-
Matching logic is implemented here rather than in MetricsFilter because we would like MetricsFilter to act as a "dumb" value-object, with the possibility of replacing it with a Proto/JSON/etc.
- matches(AppliedPTransform<?, ?, ?>) - Method in interface org.apache.beam.sdk.runners.PTransformMatcher
- Matches(Pattern, int) - Constructor for class org.apache.beam.sdk.transforms.Regex.Matches
- matchesDuringValidation(AppliedPTransform<?, ?, ?>) - Method in interface org.apache.beam.sdk.runners.PTransformMatcher
-
An
AppliedPTransformmatched by aPTransformMatcherwill be replaced during pipeline surgery, and is often expected to be gone in the new pipeline. - matchesKV(String, int, int) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.MatchesKVPTransformthat checks if the entire line matches the Regex. - matchesKV(String, String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.MatchesNameKVPTransformthat checks if the entire line matches the Regex. - matchesKV(Pattern, int, int) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.MatchesKVPTransformthat checks if the entire line matches the Regex. - matchesKV(Pattern, String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.MatchesNameKVPTransformthat checks if the entire line matches the Regex. - MatchesKV(Pattern, int, int) - Constructor for class org.apache.beam.sdk.transforms.Regex.MatchesKV
- MatchesName(Pattern, String) - Constructor for class org.apache.beam.sdk.transforms.Regex.MatchesName
- MatchesNameKV(Pattern, String, String) - Constructor for class org.apache.beam.sdk.transforms.Regex.MatchesNameKV
- matchesSafely(ShardedFile) - Method in class org.apache.beam.sdk.testing.FileChecksumMatcher
- matchesSafely(T) - Method in class org.apache.beam.sdk.testing.JsonMatcher
- matchesScope(String, Set<String>) - Static method in class org.apache.beam.sdk.metrics.MetricFiltering
-
matchesScope(actualScope, scopes)returns true if the scope of a metric is matched by any of the filters inscopes. - matchNewDirectory(String, String...) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Returns a new
ResourceIdthat represents the named directory resource. - matchNewResource(String, boolean) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
- matchNewResource(String, boolean) - Method in class org.apache.beam.sdk.io.FileSystem
-
Returns a new
ResourceIdfor this filesystem that represents the named resource. - matchNewResource(String, boolean) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Returns a new
ResourceIdthat represents the named resource of a type corresponding to the resource type. - matchResources(List<ResourceId>) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Returns
MatchResultsfor the givenresourceIds. - MatchResult - Class in org.apache.beam.sdk.io.fs
-
The result of
FileSystem.match(java.util.List<java.lang.String>). - MatchResult.Metadata - Class in org.apache.beam.sdk.io.fs
-
MatchResult.Metadataof a matched file. - MatchResult.Metadata.Builder - Class in org.apache.beam.sdk.io.fs
-
Builder class for
MatchResult.Metadata. - MatchResult.Status - Enum in org.apache.beam.sdk.io.fs
-
Status of a
MatchResult. - matchSingleFileSpec(String) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Returns the
MatchResult.Metadatafor a single file resource. - Materialization<T> - Interface in org.apache.beam.sdk.transforms
-
For internal use only; no backwards-compatibility guarantees.
- Materializations - Class in org.apache.beam.sdk.transforms
-
For internal use only; no backwards-compatibility guarantees.
- Materializations() - Constructor for class org.apache.beam.sdk.transforms.Materializations
- Materializations.IterableView<V> - Interface in org.apache.beam.sdk.transforms
-
Represents the
PrimitiveViewTsupplied to theViewFnwhen it declares to use theiterable materialization. - Materializations.MultimapView<K,V> - Interface in org.apache.beam.sdk.transforms
-
Represents the
PrimitiveViewTsupplied to theViewFnwhen it declares to use themultimap materialization. - Max - Class in org.apache.beam.sdk.transforms
-
PTransforms for computing the maximum of the elements in aPCollection, or the maximum of the values associated with each key in aPCollectionofKVs. - MAX_STRING_LENGTH - Static variable in class org.apache.beam.sdk.util.RowJsonUtils
- maximumLookback() - Method in class org.apache.beam.sdk.transforms.windowing.WindowMappingFn
-
The maximum distance between the end of any main input window
mainWindowand the end of the side input window returned bygetSideInputWindow(BoundedWindow) - maxTimestamp() - Method in class org.apache.beam.sdk.fn.windowing.EncodedBoundedWindow
- maxTimestamp() - Method in class org.apache.beam.sdk.transforms.windowing.BoundedWindow
-
Returns the inclusive upper bound of timestamps for values in this window.
- maxTimestamp() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindow
- maxTimestamp() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
-
Returns the largest timestamp that can be included in this window.
- mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.AfterEach
- mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
- mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
- mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
- mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
- mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.ReshuffleTrigger
- mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
-
For internal use only; no backwards-compatibility guarantees.
- mayFinish() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger.OnceTrigger
- Mean - Class in org.apache.beam.sdk.transforms
-
PTransforms for computing the arithmetic mean (a.k.a. - MemoizingPerInstantiationSerializableSupplier<T> - Class in org.apache.beam.sdk.util
-
A supplier that memoizes within an instantiation across serialization/deserialization.
- MemoizingPerInstantiationSerializableSupplier(SerializableSupplier<T>) - Constructor for class org.apache.beam.sdk.util.MemoizingPerInstantiationSerializableSupplier
- MemoryMonitorOptions - Interface in org.apache.beam.sdk.options
-
Options that are used to control the Memory Monitor.
- merge(Collection<W>, W) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn.MergeContext
-
Signals to the framework that the windows in
toBeMergedshould be merged together to formmergeResult. - merge(BoundedWindow, Iterable<? extends Instant>) - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
-
Merges the given timestamps, which may have originated in separate windows, into the context of the result window.
- merge(BoundedWindow, Instant...) - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
- MERGE_WINDOWS_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- mergeAccumulator(AccumT) - Method in interface org.apache.beam.sdk.transforms.Combine.AccumulatingCombineFn.Accumulator
-
Adds the input values represented by the given accumulator into this accumulator.
- mergeAccumulators(Iterable<AccumT>) - Method in interface org.apache.beam.sdk.state.CombiningState
-
Merge the given accumulators according to the underlying
Combine.CombineFn. - mergeAccumulators(Iterable<AccumT>) - Method in class org.apache.beam.sdk.transforms.Combine.AccumulatingCombineFn
- mergeAccumulators(Iterable<AccumT>) - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
-
Returns an accumulator representing the accumulation of all the input values accumulated in the merging accumulators.
- mergeAccumulators(Iterable<AccumT>, CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
-
Returns an accumulator representing the accumulation of all the input values accumulated in the merging accumulators.
- mergeAccumulators(Iterable<double[]>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
- mergeAccumulators(Iterable<int[]>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
- mergeAccumulators(Iterable<Object[]>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
- mergeAccumulators(Iterable<Object[]>, CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
- mergeAccumulators(Iterable<List<V>>) - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
- mergeAccumulators(Iterable<long[]>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
- mergeAccumulators(Iterable<ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique>) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
-
Deprecated.
- mergeAccumulators(Iterable<Combine.Holder<V>>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
- mergeAccumulators(Iterable<Top.BoundedHeap<KV<Integer, T>, SerializableComparator<KV<Integer, T>>>>) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
- MergeContext() - Constructor for class org.apache.beam.sdk.transforms.windowing.WindowFn.MergeContext
- mergeFrom(RunnerApi.Components, Collection<String>) - Method in class org.apache.beam.sdk.util.construction.SdkComponents
-
Merge Components proto into this SdkComponents instance.
- MergeOverlappingIntervalWindows - Class in org.apache.beam.sdk.transforms.windowing
-
For internal use only; no backwards compatibility guarantees.
- MergeOverlappingIntervalWindows() - Constructor for class org.apache.beam.sdk.transforms.windowing.MergeOverlappingIntervalWindows
- mergeWideningNullable(Schema, Schema) - Static method in class org.apache.beam.sdk.schemas.SchemaUtils
-
Given two schema that have matching types, return a nullable-widened schema.
- mergeWindows(WindowFn.MergeContext) - Static method in class org.apache.beam.sdk.transforms.windowing.MergeOverlappingIntervalWindows
-
Merge overlapping
IntervalWindows. - mergeWindows(WindowFn.MergeContext) - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
- mergeWindows(WindowFn.MergeContext) - Method in class org.apache.beam.sdk.transforms.windowing.NonMergingWindowFn
- mergeWindows(WindowFn.MergeContext) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
Does whatever merging of windows is necessary.
- mergeWithOuter(ResourceHint, boolean) - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHint
-
Reconciles values of a hint when the hint specified on a transform is also defined in an outer context, for example on a composite transform, or specified in the transform's execution environment.
- mergeWithOuter(ResourceHints) - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHints
- message() - Method in class org.apache.beam.sdk.schemas.transforms.Cast.CompatibilityError
- metadata() - Method in class org.apache.beam.sdk.io.fs.MatchResult
-
MatchResult.Metadataof matched files. - Metadata() - Constructor for class org.apache.beam.sdk.io.fs.MatchResult.Metadata
- MetadataCoder - Class in org.apache.beam.sdk.io.fs
-
A
CoderforMatchResult.Metadata. - MetadataCoderV2 - Class in org.apache.beam.sdk.io.fs
- Metric - Interface in org.apache.beam.sdk.metrics
-
Marker interface for all user-facing metrics.
- MetricFiltering - Class in org.apache.beam.sdk.metrics
-
Implements matching for metrics filters.
- MetricKey - Class in org.apache.beam.sdk.metrics
-
Metrics are keyed by the step name they are associated with and the name of the metric.
- MetricKey() - Constructor for class org.apache.beam.sdk.metrics.MetricKey
- metricName() - Method in class org.apache.beam.sdk.metrics.MetricKey
-
The name of the metric.
- MetricName - Class in org.apache.beam.sdk.metrics
-
The name of a metric consists of a
MetricName.getNamespace()and aMetricName.getName(). - MetricName() - Constructor for class org.apache.beam.sdk.metrics.MetricName
- MetricNameFilter - Class in org.apache.beam.sdk.metrics
-
The name of a metric.
- MetricNameFilter() - Constructor for class org.apache.beam.sdk.metrics.MetricNameFilter
- MetricQueryResults - Class in org.apache.beam.sdk.metrics
-
The results of a query for metrics.
- MetricQueryResults() - Constructor for class org.apache.beam.sdk.metrics.MetricQueryResults
- MetricResult<T> - Class in org.apache.beam.sdk.metrics
-
The results of a single current metric.
- MetricResult() - Constructor for class org.apache.beam.sdk.metrics.MetricResult
- MetricResults - Class in org.apache.beam.sdk.metrics
-
Methods for interacting with the metrics of a pipeline that has been executed.
- MetricResults() - Constructor for class org.apache.beam.sdk.metrics.MetricResults
- metrics() - Method in interface org.apache.beam.sdk.PipelineResult
-
Returns the object to access metrics from the pipeline.
- Metrics - Class in org.apache.beam.sdk.metrics
-
The
Metricsis a utility class for producing various kinds of metrics for reporting properties of an executing pipeline. - MetricsContainer - Interface in org.apache.beam.sdk.metrics
-
Holds the metrics for a single step.
- MetricsContainerHolder() - Constructor for class org.apache.beam.sdk.metrics.MetricsEnvironment.MetricsContainerHolder
- MetricsEnvironment - Class in org.apache.beam.sdk.metrics
-
Manages and provides the metrics container associated with each thread.
- MetricsEnvironment() - Constructor for class org.apache.beam.sdk.metrics.MetricsEnvironment
- MetricsEnvironment.MetricsContainerHolder - Class in org.apache.beam.sdk.metrics
- MetricsEnvironment.MetricsEnvironmentState - Interface in org.apache.beam.sdk.metrics
-
Set the
MetricsContainerfor the associatedMetricsEnvironment. - MetricsFilter - Class in org.apache.beam.sdk.metrics
-
Simple POJO representing a filter for querying metrics.
- MetricsFilter() - Constructor for class org.apache.beam.sdk.metrics.MetricsFilter
- MetricsFilter.Builder - Class in org.apache.beam.sdk.metrics
-
Builder for creating a
MetricsFilter. - MetricsOptions - Interface in org.apache.beam.sdk.metrics
-
Extension of
PipelineOptionsthat definesMetricsSinkspecific options. - MetricsOptions.NoOpMetricsSink - Class in org.apache.beam.sdk.metrics
-
A
DefaultValueFactorythat obtains the class of theNoOpMetricsSinkif it exists on the classpath, and throws an exception otherwise. - MetricsSink - Interface in org.apache.beam.sdk.metrics
-
Interface for all metric sinks.
- MicrosInstant - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A timestamp represented as microseconds since the epoch.
- MicrosInstant() - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
- migrate(SdkComponents) - Method in class org.apache.beam.sdk.util.construction.PTransformTranslation.RawPTransform
-
Build a new payload set in the context of the given
SdkComponents, if applicable. - mimeType() - Method in class org.apache.beam.sdk.io.fs.CreateOptions
-
The file-like resource mime type.
- MimeTypes - Class in org.apache.beam.sdk.util
-
Constants representing various mime types.
- MimeTypes() - Constructor for class org.apache.beam.sdk.util.MimeTypes
- Min - Class in org.apache.beam.sdk.transforms
-
PTransforms for computing the minimum of the elements in aPCollection, or the minimum of the values associated with each key in aPCollectionofKVs. - MM - Static variable in class org.apache.beam.sdk.util.RowStringInterpolator
- MOCK_ARTIFACT_PREFIX - Static variable in class org.apache.beam.sdk.util.construction.Environments
- ModelCoderRegistrar - Class in org.apache.beam.sdk.util.construction
-
The
CoderTranslatorRegistrarfor coders which are shared across languages. - ModelCoderRegistrar() - Constructor for class org.apache.beam.sdk.util.construction.ModelCoderRegistrar
- ModelCoders - Class in org.apache.beam.sdk.util.construction
-
Utilities and constants ot interact with coders that are part of the Beam Model.
- ModelCoders.KvCoderComponents - Class in org.apache.beam.sdk.util.construction
-
Components of a KV
RunnerApi.Coderwith names. - ModelCoders.WindowedValueCoderComponents - Class in org.apache.beam.sdk.util.construction
-
Components of a Windowed Value
RunnerApi.Coderwith names. - modeNames - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- MonotonicallyIncreasing(Instant) - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.MonotonicallyIncreasing
- months(int) - Static method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows
-
Returns a
WindowFnthat windows elements into periods measured by months. - MoreFutures - Class in org.apache.beam.sdk.util
-
Utilities to do future programming with Java 8.
- MoreFutures() - Constructor for class org.apache.beam.sdk.util.MoreFutures
- MoreFutures.ExceptionOrResult<T> - Class in org.apache.beam.sdk.util
-
An object that represents either a result or an exceptional termination.
- MoreFutures.ExceptionOrResult.IsException - Enum in org.apache.beam.sdk.util
-
Describes whether the result was an exception.
- MOST_SIGNIFICANT_BITS_FIELD_NAME - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.UuidLogicalType
- MoveOptions - Interface in org.apache.beam.sdk.io.fs
-
An object that configures
FileSystems.copy(java.util.List<org.apache.beam.sdk.io.fs.ResourceId>, java.util.List<org.apache.beam.sdk.io.fs.ResourceId>, org.apache.beam.sdk.io.fs.MoveOptions...),FileSystems.rename(java.util.List<org.apache.beam.sdk.io.fs.ResourceId>, java.util.List<org.apache.beam.sdk.io.fs.ResourceId>, org.apache.beam.sdk.io.fs.MoveOptions...), andFileSystems.delete(java.util.Collection<org.apache.beam.sdk.io.fs.ResourceId>, org.apache.beam.sdk.io.fs.MoveOptions...). - MoveOptions.StandardMoveOptions - Enum in org.apache.beam.sdk.io.fs
-
Defines the standard
MoveOptions. - MovingFunction - Class in org.apache.beam.sdk.util
-
Keep track of the moving minimum/maximum/sum of sampled long values.
- MovingFunction(long, long, int, int, Combine.BinaryCombineLongFn) - Constructor for class org.apache.beam.sdk.util.MovingFunction
- multimap() - Static method in class org.apache.beam.sdk.state.StateSpecs
-
Create a
StateSpecfor aMultimapState, optimized for key lookups, key puts, and clear. - multimap() - Static method in class org.apache.beam.sdk.transforms.Materializations
-
For internal use only; no backwards-compatibility guarantees.
- multimap(Coder<K>, Coder<V>) - Static method in class org.apache.beam.sdk.state.StateSpecs
-
Identical to
StateSpecs.multimap(), but with key and value coders explicitly supplied. - MULTIMAP_MATERIALIZATION_URN - Static variable in class org.apache.beam.sdk.transforms.Materializations
-
The URN for a
Materializationwhere the primitive view type is a multimap of fully specified windowed values. - MULTIMAP_USER_STATE - Static variable in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
Represents a user state specification that supports a multimap.
- MultimapState<K,V> - Interface in org.apache.beam.sdk.state
-
A
ReadableStatecell mapping keys to bags of values. - multimapView(PCollection<KV<K, V>>, PCollectionViews.TypeDescriptorSupplier<K>, PCollectionViews.TypeDescriptorSupplier<V>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<Map<K, Iterable<V>>>capable of processing elements windowed using the providedWindowingStrategy. - MultimapViewFn(PCollectionViews.TypeDescriptorSupplier<K>, PCollectionViews.TypeDescriptorSupplier<V>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn
-
Deprecated.
- MultimapViewFn2(PCollectionViews.TypeDescriptorSupplier<K>, PCollectionViews.TypeDescriptorSupplier<V>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn2
- multimapViewUsingVoidKey(TupleTag<Materializations.MultimapView<Void, KV<K, V>>>, PCollection<KV<Void, KV<K, V>>>, PCollectionViews.TypeDescriptorSupplier<K>, PCollectionViews.TypeDescriptorSupplier<V>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
- multiplexElements(Iterator<BeamFnApi.Elements.Data>, Iterator<BeamFnApi.Elements.Timers>) - Method in class org.apache.beam.sdk.fn.data.BeamFnDataInboundObserver
-
Dispatches the data and timers from the elements to corresponding receivers.
- MUST_BE_CONSISTENT_IF_SUCCEEDS - org.apache.beam.sdk.testing.SourceTestUtils.ExpectedSplitOutcome
-
The operation must either fail, or succeed and the results be consistent.
- MUST_FAIL - org.apache.beam.sdk.testing.SourceTestUtils.ExpectedSplitOutcome
-
The operation must fail (return
null). - MUST_SUCCEED_AND_BE_CONSISTENT - org.apache.beam.sdk.testing.SourceTestUtils.ExpectedSplitOutcome
-
The operation must succeed and the results must be consistent.
- MutationDetector - Interface in org.apache.beam.sdk.util
-
An object for detecting illegal mutations.
- MutationDetectors - Class in org.apache.beam.sdk.util
-
Static methods for creating and working with
MutationDetector.
N
- name - Variable in class org.apache.beam.sdk.transforms.PTransform
-
The base name of this
PTransform, e.g., from defaults, ornullif not yet assigned. - name() - Method in interface org.apache.beam.sdk.schemas.FieldValueGetter
- name() - Method in interface org.apache.beam.sdk.schemas.FieldValueHaver
- name() - Method in interface org.apache.beam.sdk.schemas.FieldValueSetter
-
Returns the name of the field.
- name(TypeDescription) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.InjectPackageStrategy
- named(Class<?>, String) - Static method in class org.apache.beam.sdk.metrics.MetricName
- named(Class<?>, String) - Static method in class org.apache.beam.sdk.metrics.MetricNameFilter
- named(Class<?>, String, Map<String, String>) - Static method in class org.apache.beam.sdk.metrics.MetricName
- named(String, String) - Static method in class org.apache.beam.sdk.metrics.MetricName
- named(String, String) - Static method in class org.apache.beam.sdk.metrics.MetricNameFilter
- named(String, String, Map<String, String>) - Static method in class org.apache.beam.sdk.metrics.MetricName
- nameOf(int) - Method in class org.apache.beam.sdk.schemas.Schema
-
Return the name of field by index.
- names() - Method in class org.apache.beam.sdk.metrics.MetricsFilter
- NameUtils - Class in org.apache.beam.sdk.util
-
Helpers for extracting the name of objects and classes.
- NameUtils() - Constructor for class org.apache.beam.sdk.util.NameUtils
- NameUtils.NameOverride - Interface in org.apache.beam.sdk.util
-
Classes may implement this interface to change how names are generated for their instances.
- NanosDuration - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A duration represented in nanoseconds.
- NanosDuration() - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.NanosDuration
- NanosInstant - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A timestamp represented as nanoseconds since the epoch.
- NanosInstant() - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.NanosInstant
- narrowing(Schema) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
- Narrowing() - Constructor for class org.apache.beam.sdk.schemas.transforms.Cast.Narrowing
- NativeTransforms - Class in org.apache.beam.sdk.util.construction
-
An extension point for users to define their own native transforms for usage with specific runners.
- NativeTransforms() - Constructor for class org.apache.beam.sdk.util.construction.NativeTransforms
- NativeTransforms.IsNativeTransform - Interface in org.apache.beam.sdk.util.construction
-
A predicate which returns true if and only if the transform is a native transform.
- Natural() - Constructor for class org.apache.beam.sdk.transforms.Top.Natural
- naturalOrder() - Static method in class org.apache.beam.sdk.transforms.Max
- naturalOrder() - Static method in class org.apache.beam.sdk.transforms.Min
- naturalOrder(T) - Static method in class org.apache.beam.sdk.transforms.Max
- naturalOrder(T) - Static method in class org.apache.beam.sdk.transforms.Min
- needsMerge() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- NeedsRunner - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize
TestPipelinefor execution and expect to be executed by aPipelineRunner. - nested() - Method in class org.apache.beam.sdk.coders.Coder.Context
-
Deprecated.
- NESTED - Static variable in class org.apache.beam.sdk.coders.Coder.Context
-
Deprecated.The nested context: the value being encoded or decoded is (potentially) a part of a larger record/stream contents, and may have other parts encoded or decoded after it.
- nestedFieldsById() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Return the nested fields keyed by field ids.
- nestedFieldsByName() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Return the nested fields keyed by field name.
- Networks - Class in org.apache.beam.sdk.util.construction.graph
-
Static utility methods for
Networkinstances that are directed. - Networks.TypeSafeNodeFunction<NodeT,T extends NodeT> - Class in org.apache.beam.sdk.util.construction.graph
-
An abstract class that can be extended to apply a function in a type safe manner.
- never() - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
Returns a
Watch.Growth.TerminationConditionthat never holds (i.e., poll each input until its output is complete). - Never - Class in org.apache.beam.sdk.transforms.windowing
-
A
Triggerwhich never fires. - Never() - Constructor for class org.apache.beam.sdk.transforms.windowing.Never
- Never.NeverTrigger - Class in org.apache.beam.sdk.transforms.windowing
-
The actual trigger class for
Nevertriggers. - newBuilder() - Static method in class org.apache.beam.sdk.schemas.io.Failure
- newCondition() - Method in class org.apache.beam.sdk.util.NoopLock
- newDlqTransform(String) - Method in interface org.apache.beam.sdk.schemas.io.GenericDlqProvider
-
Generate a DLQ output from the provided config value.
- newObjectMapperWith(RowJson.RowJsonDeserializer) - Static method in class org.apache.beam.sdk.util.RowJsonUtils
- newObjectMapperWith(RowJson.RowJsonSerializer) - Static method in class org.apache.beam.sdk.util.RowJsonUtils
- newProvider(T) - Method in class org.apache.beam.sdk.testing.TestPipeline
-
Returns a new
ValueProviderthat is inaccessible beforeTestPipeline.run(), but will be accessible while the pipeline runs. - newTracker() - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
- newTracker() - Method in class org.apache.beam.sdk.io.range.OffsetRange
- newTracker() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.NewTrackermethod. - newTracker() - Method in interface org.apache.beam.sdk.transforms.splittabledofn.HasDefaultTracker
-
Creates a new tracker for
this. - newTracker(Watch.GrowthState) - Method in class org.apache.beam.sdk.transforms.Watch.WatchGrowthFn
- NewTrackerMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewTrackerMethod
- newWatermarkEstimator() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.NewWatermarkEstimatormethod. - newWatermarkEstimator() - Method in interface org.apache.beam.sdk.transforms.splittabledofn.HasDefaultWatermarkEstimator
-
Creates a new watermark estimator for
this. - newWatermarkEstimator(Instant) - Method in class org.apache.beam.sdk.transforms.Watch.WatchGrowthFn
- NewWatermarkEstimatorMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewWatermarkEstimatorMethod
- next() - Method in class org.apache.beam.sdk.fn.stream.DataStreams.DataStreamDecoder
- next(Sleeper, BackOff) - Static method in class org.apache.beam.sdk.util.BackOffUtils
-
Runs the next iteration of the back-off policy, and returns whether to continue to retry the operation.
- nextBackOffMillis() - Method in interface org.apache.beam.sdk.util.BackOff
-
Gets the number of milliseconds to wait before retrying the operation or
BackOff.STOPto indicate that no retries should be made. - nextFieldId() - Method in class org.apache.beam.sdk.values.Row.Builder
- NO_FIRING - Static variable in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
PaneInfoto use for elements on (and before) initial window assignment (including elements read from sources) before they have passed through aGroupByKeyand are associated with a particular trigger firing. - nonAdditionalInputs(AppliedPTransform<?, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.TransformInputs
-
Gets all inputs of the
AppliedPTransformthat are not returned byPTransform.getAdditionalInputs(). - NonDeterministicException(Coder<?>, String) - Constructor for exception org.apache.beam.sdk.coders.Coder.NonDeterministicException
- NonDeterministicException(Coder<?>, String, Coder.NonDeterministicException) - Constructor for exception org.apache.beam.sdk.coders.Coder.NonDeterministicException
- NonDeterministicException(Coder<?>, List<String>) - Constructor for exception org.apache.beam.sdk.coders.Coder.NonDeterministicException
- NonDeterministicException(Coder<?>, List<String>, Coder.NonDeterministicException) - Constructor for exception org.apache.beam.sdk.coders.Coder.NonDeterministicException
- none() - Static method in class org.apache.beam.sdk.schemas.Schema.Options
- none() - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Default empty
DisplayDatainstance. - NONE - org.apache.beam.sdk.io.TFRecordIO.CompressionType
-
Deprecated.
- NONE - Static variable in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.Progress
-
Constant Progress instance to be used when no work has been completed yet.
- NonMergingWindowFn<T,W extends BoundedWindow> - Class in org.apache.beam.sdk.transforms.windowing
-
Abstract base class for
WindowFnsthat do not merge windows. - NonMergingWindowFn() - Constructor for class org.apache.beam.sdk.transforms.windowing.NonMergingWindowFn
- NOOP_CHECKPOINT_MARK - Static variable in interface org.apache.beam.sdk.io.UnboundedSource.CheckpointMark
- NoopCheckpointMark() - Constructor for class org.apache.beam.sdk.io.UnboundedSource.CheckpointMark.NoopCheckpointMark
- NoOpCounter - Class in org.apache.beam.sdk.metrics
-
A no-op implementation of Counter.
- NoOpHistogram - Class in org.apache.beam.sdk.metrics
-
A no-op implementation of Histogram.
- NoopLock - Class in org.apache.beam.sdk.util
-
A lock which can always be acquired.
- NoOpMetricsSink() - Constructor for class org.apache.beam.sdk.metrics.MetricsOptions.NoOpMetricsSink
- noopMutationDetector() - Static method in class org.apache.beam.sdk.util.MutationDetectors
-
Creates a new
MutationDetectorthat always succeeds. - NoSuchSchemaException - Exception in org.apache.beam.sdk.schemas
-
Indicates that we are missing a schema for a type.
- NoSuchSchemaException() - Constructor for exception org.apache.beam.sdk.schemas.NoSuchSchemaException
- not(SerializableMatcher<T>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.not(org.hamcrest.Matcher<T>). - NOT_FOUND - org.apache.beam.sdk.io.fs.MatchResult.Status
- notEqualTo(T) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Asserts that the value in question is not equal to the provided value, according to
Object.equals(java.lang.Object). - notifyValueReturned(long) - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObservableIterator
- NotSerializable() - Constructor for class org.apache.beam.sdk.util.construction.PTransformTranslation.TransformPayloadTranslator.NotSerializable
- nullable(String, Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.Schema.Field
-
Return's a nullable field with the give name and type.
- NULLABLE_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- NullableCoder<T> - Class in org.apache.beam.sdk.coders
-
A
NullableCoderencodes nullable values of typeTusing a nestedCoder<T>that does not toleratenullvalues. - nullContext() - Static method in class org.apache.beam.sdk.state.StateContexts
-
Returns a fake
StateContext. - nullContext() - Static method in class org.apache.beam.sdk.util.CombineContextFactory
-
Returns a fake
Combine.Contextfor tests. - nullRow(Schema) - Static method in class org.apache.beam.sdk.values.Row
-
Creates a new record filled with nulls.
- nulls() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorfor nulls/Void. - nullValue() - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.nullValue(). - NUMBER - org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields.Fanout.Kind
- NumberedShardedFile - Class in org.apache.beam.sdk.util
-
Utility methods for working with sharded files.
- NumberedShardedFile(String) - Constructor for class org.apache.beam.sdk.util.NumberedShardedFile
-
Constructor that uses default shard template.
- NumberedShardedFile(String, Pattern) - Constructor for class org.apache.beam.sdk.util.NumberedShardedFile
-
Constructor.
- NUMERIC_TYPES - Static variable in enum org.apache.beam.sdk.schemas.Schema.TypeName
O
- ObjectsClassComparator() - Constructor for class org.apache.beam.sdk.util.common.ReflectHelpers.ObjectsClassComparator
- observe(RestrictionTracker<RestrictionT, PositionT>, RestrictionTrackers.ClaimObserver<PositionT>) - Static method in class org.apache.beam.sdk.fn.splittabledofn.RestrictionTrackers
-
Returns a thread safe
RestrictionTrackerwhich reports all claim attempts to the specifiedRestrictionTrackers.ClaimObserver. - observesWindow() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.MethodWithExtraParameters
-
Whether this method observes - directly or indirectly - the window that an element resides in.
- observeTimestamp(Instant) - Method in interface org.apache.beam.sdk.transforms.splittabledofn.TimestampObservingWatermarkEstimator
-
Update watermark estimate with latest output timestamp.
- observeTimestamp(Instant) - Method in class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.MonotonicallyIncreasing
- of() - Static method in class org.apache.beam.sdk.coders.BigDecimalCoder
- of() - Static method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
- of() - Static method in class org.apache.beam.sdk.coders.BigEndianLongCoder
- of() - Static method in class org.apache.beam.sdk.coders.BigEndianShortCoder
- of() - Static method in class org.apache.beam.sdk.coders.BigIntegerCoder
- of() - Static method in class org.apache.beam.sdk.coders.BitSetCoder
- of() - Static method in class org.apache.beam.sdk.coders.BooleanCoder
-
Returns the singleton instance of
BooleanCoder. - of() - Static method in class org.apache.beam.sdk.coders.ByteArrayCoder
- of() - Static method in class org.apache.beam.sdk.coders.ByteCoder
- of() - Static method in class org.apache.beam.sdk.coders.DoubleCoder
- of() - Static method in class org.apache.beam.sdk.coders.DurationCoder
- of() - Static method in class org.apache.beam.sdk.coders.FloatCoder
- of() - Static method in class org.apache.beam.sdk.coders.InstantCoder
- of() - Static method in class org.apache.beam.sdk.coders.StringUtf8Coder
- of() - Static method in class org.apache.beam.sdk.coders.TextualIntegerCoder
- of() - Static method in class org.apache.beam.sdk.coders.VarIntCoder
- of() - Static method in class org.apache.beam.sdk.coders.VarLongCoder
- of() - Static method in class org.apache.beam.sdk.coders.VoidCoder
- of() - Static method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.ParamsCoder
- of() - Static method in class org.apache.beam.sdk.io.fs.MetadataCoder
-
Returns the singleton
MetadataCoderinstance. - of() - Static method in class org.apache.beam.sdk.io.fs.MetadataCoderV2
-
Returns the singleton
MetadataCoderV2instance. - of() - Static method in class org.apache.beam.sdk.io.fs.ResourceIdCoder
-
Creates a
ResourceIdCoder. - of() - Static method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
- of() - Static method in class org.apache.beam.sdk.io.ReadableFileCoder
- of() - Static method in class org.apache.beam.sdk.schemas.transforms.Cast.Narrowing
- of() - Static method in class org.apache.beam.sdk.schemas.transforms.Cast.Widening
- of() - Static method in class org.apache.beam.sdk.transforms.Mean
-
A
Combine.CombineFnthat computes the arithmetic mean (a.k.a. - of() - Static method in class org.apache.beam.sdk.transforms.Reshuffle
- of() - Static method in class org.apache.beam.sdk.transforms.ToJson
- of() - Static method in class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
-
Returns the default trigger.
- of() - Static method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
- of() - Static method in class org.apache.beam.sdk.transforms.windowing.PaneInfo.PaneInfoCoder
- of() - Static method in class org.apache.beam.sdk.util.BitSetCoder
-
Deprecated.
- of() - Static method in class org.apache.beam.sdk.util.construction.TransformUpgrader
- of() - Static method in class org.apache.beam.sdk.util.HistogramData.UnsupportedBuckets
- of(double, double, int) - Static method in class org.apache.beam.sdk.util.HistogramData.LinearBuckets
- of(int) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
-
Return an instance of FixedBytes with specified byte array length.
- of(int) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.FixedPrecisionNumeric
-
Create a FixedPrecisionNumeric instance with specified scale and unspecified precision.
- of(int) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.FixedString
-
Return an instance of FixedString with specified string length.
- of(int) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.VariableBytes
-
Return an instance of VariableBytes with specified max byte array length.
- of(int) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.VariableString
-
Return an instance of VariableString with specified max string length.
- of(int) - Static method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields.Fanout
- of(int...) - Static method in class org.apache.beam.sdk.io.range.ByteKey
-
Creates a new
ByteKeybacked by a copy of the specifiedint[]. - of(int, int) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.FixedPrecisionNumeric
-
Create a FixedPrecisionNumeric instance with specified precision and scale.
- of(int, int) - Static method in class org.apache.beam.sdk.util.HistogramData.ExponentialBuckets
- of(int, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a
PTransformthat takes an inputPCollection<T>and returns aPCollection<List<T>>with a single element containing the largestcountelements of the inputPCollection<T>, in decreasing order, sorted using the givenComparator<T>. - of(int, Partition.PartitionFn<? super T>) - Static method in class org.apache.beam.sdk.transforms.Partition
-
Returns a new
PartitionPTransformthat divides its inputPCollectioninto the given number of partitions, using the given partitioning function. - of(int, Partition.PartitionWithSideInputsFn<? super T>, Requirements) - Static method in class org.apache.beam.sdk.transforms.Partition
-
Returns a new
PartitionPTransformthat divides its inputPCollectioninto the given number of partitions, using the given partitioning function. - of(String, int) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
-
Return an instance of FixedBytes with specified byte array length.
- of(String, int) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.FixedString
-
Return an instance of FixedString with specified string length.
- of(String, int) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.VariableBytes
-
Return an instance of VariableBytes with specified max byte array length.
- of(String, int) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.VariableString
-
Return an instance of VariableString with specified max string length.
- of(K) - Static method in class org.apache.beam.sdk.transforms.WithKeys
-
Returns a
PTransformthat takes aPCollection<V>and returns aPCollection<KV<K, V>>, where each of the values in the inputPCollectionhas been paired with the given key. - of(RestrictionT, RestrictionT) - Static method in class org.apache.beam.sdk.transforms.splittabledofn.SplitResult
-
Returns a
SplitResultfor the specified primary and residual restrictions. - of(T, T...) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns a new
Create.Valuestransform that produces aPCollectioncontaining the specified elements. - of(ClosureT, Requirements) - Static method in class org.apache.beam.sdk.transforms.Contextful
-
Constructs a pair of the given closure and its requirements.
- of(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Max
-
A
CombineFnthat computes the maximum of a collection of elements of typeTusing an arbitraryComparator, useful as an argument toCombine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>)orCombine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>). - of(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Min
-
A
CombineFnthat computes the minimum of a collection of elements of typeTusing an arbitraryComparator, useful as an argument toCombine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>)orCombine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>). - of(InputT, PTransform<InputT, OutputT>) - Static method in class org.apache.beam.sdk.runners.PTransformOverrideFactory.PTransformReplacement
- of(Class<T>) - Static method in class org.apache.beam.sdk.coders.SerializableCoder
-
Returns a
SerializableCoderinstance for the provided element class. - of(Class<T>) - Static method in class org.apache.beam.sdk.coders.StringDelegateCoder
- of(Class<T>) - Static method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns a
TypeDescriptorrepresenting the given type. - of(Class<T>, TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.coders.StringDelegateCoder
- of(Iterable<PCollection<T>>) - Static method in class org.apache.beam.sdk.values.PCollectionList
-
Returns a
PCollectionListcontaining the givenPCollections, in order. - of(Iterable<T>) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns a new
Create.Valuestransform that produces aPCollectioncontaining elements of the providedIterable. - of(Type) - Static method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns a
TypeDescriptorrepresenting the given type. - of(String) - Static method in class org.apache.beam.sdk.util.PythonCallableSource
- of(String, byte[]) - Static method in class org.apache.beam.sdk.util.construction.UnknownCoderWrapper
- of(String, byte[], String) - Static method in class org.apache.beam.sdk.util.construction.External
- of(String, byte[], String, ExpansionServiceClientFactory) - Static method in class org.apache.beam.sdk.util.construction.External
- of(String, Map<TupleTag<?>, PCollection<?>>, Map<TupleTag<?>, PCollection<?>>, TransformT, ResourceHints, Pipeline) - Static method in class org.apache.beam.sdk.runners.AppliedPTransform
- of(String, Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.Schema.Field
-
Return's a field with the give name and type.
- of(String, PCollection<KV<K, InputT>>) - Static method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
A version of
KeyedPCollectionTuple.of(TupleTag, PCollection)that takes in a string instead of a TupleTag. - of(String, PCollection<Row>) - Static method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
Returns a singleton
PCollectionRowTuplecontaining the givenPCollectionkeyed by the given tag. - of(String, PCollection<Row>, String, PCollection<Row>) - Static method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
A version of
PCollectionRowTuple.of(String, PCollection)that takes in two PCollections of the same type. - of(String, PCollection<Row>, String, PCollection<Row>, String, PCollection<Row>) - Static method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
A version of
PCollectionRowTuple.of(String, PCollection)that takes in three PCollections of the same type. - of(String, PCollection<Row>, String, PCollection<Row>, String, PCollection<Row>, String, PCollection<Row>) - Static method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
A version of
PCollectionRowTuple.of(String, PCollection)that takes in four PCollections of the same type. - of(String, PCollection<Row>, String, PCollection<Row>, String, PCollection<Row>, String, PCollection<Row>, String, PCollection<Row>) - Static method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
A version of
PCollectionRowTuple.of(String, PCollection)that takes in five PCollections of the same type. - of(String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
A version of
PCollectionTuple.of(TupleTag, PCollection)that takes in a String instead of aTupleTag. - of(String, PCollection<T>, String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
A version of
PCollectionTuple.of(String, PCollection)that takes in two PCollections of the same type. - of(String, PCollection<T>, String, PCollection<T>, String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
A version of
PCollectionTuple.of(String, PCollection)that takes in three PCollections of the same type. - of(String, PCollection<T>, String, PCollection<T>, String, PCollection<T>, String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
A version of
PCollectionTuple.of(String, PCollection)that takes in four PCollections of the same type. - of(String, PCollection<T>, String, PCollection<T>, String, PCollection<T>, String, PCollection<T>, String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
A version of
PCollectionTuple.of(String, PCollection)that takes in five PCollections of the same type. - of(Consumer<PCollection<T>>) - Static method in class org.apache.beam.sdk.transforms.Tee
-
Returns a new Tee PTransform that will apply an auxilary transform to the input as well as pass it on.
- of(List<Coder<?>>) - Static method in class org.apache.beam.sdk.transforms.join.UnionCoder
-
Builds a union coder with the given list of element coders.
- of(List<Trigger>) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterAll
-
Returns an
AfterAllTriggerwith the given subtriggers. - of(List<Trigger>) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterFirst
-
Returns an
AfterFirstTriggerwith the given subtriggers. - of(List<TupleTag<?>>) - Static method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
- of(List<TupleTag<?>>) - Static method in class org.apache.beam.sdk.values.TupleTagList
-
Returns a
TupleTagListcontaining the givenTupleTags, in order. - of(List<T>, long) - Static method in class org.apache.beam.sdk.fn.data.WeightedList
- of(Map<K, V>) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns a new
Create.Valuestransform that produces aPCollectionofKVs corresponding to the keys and values of the specifiedMap. - of(K, byte[]) - Static method in class org.apache.beam.sdk.util.ShardedKey
-
Creates a ShardedKey with given key and shard id.
- of(K, int) - Static method in class org.apache.beam.sdk.values.ShardedKey
-
Deprecated.
- of(K, String, Collection<? extends BoundedWindow>, Instant, Instant, PaneInfo) - Static method in class org.apache.beam.sdk.util.construction.Timer
-
Returns a non-cleared timer for the given
userKey,dynamicTimerTag,fireTimestamp,holdTimestamp,windowsandpane. - of(K, V) - Static method in class org.apache.beam.sdk.values.KV
-
Returns a
KVwith the given key and value. - of(RunnerApi.Components, RunnerApi.Environment, PipelineNode.PCollectionNode, Collection<SideInputReference>, Collection<UserStateReference>, Collection<TimerReference>, Collection<PipelineNode.PTransformNode>, Collection<PipelineNode.PCollectionNode>, Collection<RunnerApi.ExecutableStagePayload.WireCoderSetting>) - Static method in class org.apache.beam.sdk.util.construction.graph.ImmutableExecutableStage
- of(Coder<IntermediateT>, DelegateCoder.CodingFunction<T, IntermediateT>, DelegateCoder.CodingFunction<IntermediateT, T>) - Static method in class org.apache.beam.sdk.coders.DelegateCoder
- of(Coder<IntermediateT>, DelegateCoder.CodingFunction<T, IntermediateT>, DelegateCoder.CodingFunction<IntermediateT, T>, TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.coders.DelegateCoder
- of(Coder<K>) - Static method in class org.apache.beam.sdk.util.ShardedKey.Coder
- of(Coder<K>, Coder<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.util.construction.Timer.Coder
- of(Coder<K>, Coder<V>) - Static method in class org.apache.beam.sdk.coders.KvCoder
- of(Coder<K>, Coder<V>) - Static method in class org.apache.beam.sdk.coders.MapCoder
-
Produces a MapCoder with the given keyCoder and valueCoder.
- of(Coder<K>, Coder<V>) - Static method in class org.apache.beam.sdk.coders.SortedMapCoder
-
Produces a MapCoder with the given keyCoder and valueCoder.
- of(Coder<KeyT>) - Static method in class org.apache.beam.sdk.coders.ShardedKeyCoder
- of(Coder<MatchResult.Metadata>) - Static method in class org.apache.beam.sdk.io.ReadableFileCoder
- of(Coder<BoundedWindow>, Coder<DestinationT>) - Static method in class org.apache.beam.sdk.io.FileBasedSink.FileResultCoder
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.CollectionCoder
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.DequeCoder
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.IterableCoder
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.LengthPrefixCoder
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.ListCoder
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.NullableCoder
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.OptionalCoder
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.SetCoder
-
Produces a
SetCoderwith the givenelementCoder. - of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.SnappyCoder
-
Wraps the given coder into a
SnappyCoder. - of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.TimestampPrefixingWindowCoder
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.ZstdCoder
-
Wraps the given coder into a
ZstdCoder. - of(Coder<T>) - Static method in class org.apache.beam.sdk.testing.TestStream.TestStreamCoder
- of(Coder<T>) - Static method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
- of(Coder<T>) - Static method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
-
Returns the
WindowedValues.ParamWindowedValueCoderfor the given valueCoder andGlobalWindow.Coder.INSTANCEusingBoundedWindow.TIMESTAMP_MIN_VALUEas the timestamp,WindowedValues.GLOBAL_WINDOWSas the window andPaneInfo.NO_FIRINGas the pane info for parameters. - of(Coder<T>) - Static method in class org.apache.beam.sdk.values.WindowedValues.ValueOnlyWindowedValueCoder
-
Deprecated.
- of(Coder<T>, byte[]) - Static method in class org.apache.beam.sdk.coders.ZstdCoder
-
Wraps the given coder into a
ZstdCoder. - of(Coder<T>, byte[], int) - Static method in class org.apache.beam.sdk.coders.ZstdCoder
-
Wraps the given coder into a
ZstdCoder. - of(Coder<T>, int) - Static method in class org.apache.beam.sdk.coders.ZstdCoder
-
Wraps the given coder into a
ZstdCoder. - of(Coder<T>, Coder<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
- of(Coder<T>, Coder<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.values.WindowedValues.FullWindowedValueCoder
- of(Coder<T>, Coder<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
-
Returns the
WindowedValues.ParamWindowedValueCoderfor the given valueCoder and windowCoder usingBoundedWindow.TIMESTAMP_MIN_VALUEas the timestamp,WindowedValues.GLOBAL_WINDOWSas the window andPaneInfo.NO_FIRINGas the pane info for parameters. - of(Coder<T>, Coder<? extends BoundedWindow>, Instant, Collection<? extends BoundedWindow>, PaneInfo) - Static method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
-
Returns the
WindowedValues.ParamWindowedValueCoderfor the given valueCoder and windowCoder using the supplied parameterized timestamp, windows and pane info forWindowedValues. - of(Coder<T>, Coder<ErrorT>, Coder<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow.Coder
- of(Coder<ValueT>) - Static method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
- of(ByteKeyRange) - Static method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
-
Instantiates a new
ByteKeyRangeTrackerwith the specified range. - of(ByteKeyRange) - Static method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
- of(ByteKey, ByteKey) - Static method in class org.apache.beam.sdk.io.range.ByteKeyRange
-
Creates a new
ByteKeyRangewith the given start and end keys. - of(ValueProvider<X>, SerializableFunction<X, T>) - Static method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
-
Creates a
ValueProvider.NestedValueProviderthat wraps the provided value. - of(PTransformMatcher, PTransformOverrideFactory<?, ?, ?>) - Static method in class org.apache.beam.sdk.runners.PTransformOverride
- of(FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.transforms.WithKeys
- of(FieldAccessDescriptor.FieldDescriptor.ListQualifier) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
- of(FieldAccessDescriptor.FieldDescriptor.MapQualifier) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
- of(Schema) - Static method in class org.apache.beam.sdk.coders.RowCoder
- of(Schema) - Static method in class org.apache.beam.sdk.schemas.SchemaCoder
- of(Schema.Field...) - Static method in class org.apache.beam.sdk.schemas.Schema
- of(Schema.TypeName) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Create a
Schema.FieldTypefor the given type. - of(Schema, Cast.Validator) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
- of(Schema, TypeDescriptor<T>, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Static method in class org.apache.beam.sdk.schemas.SchemaCoder
-
Returns a
SchemaCoderfor the specified class. - of(DisplayData.Path, Class<?>, String) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
- of(DoFn<?, ?>, TupleTag<?>, Map<String, PCollectionView<?>>, DoFnSchemaInformation) - Static method in class org.apache.beam.sdk.util.DoFnWithExecutionInformation
- of(DoFn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - of(DoFn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.ParDo
- of(CoGbkResultSchema, UnionCoder) - Static method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
-
Returns a
CoGbkResult.CoGbkResultCoderfor the given schema andUnionCoder. - of(PTransform<PCollection<T>, ?>) - Static method in class org.apache.beam.sdk.transforms.Tee
-
Returns a new Tee PTransform that will apply an auxilary transform to the input as well as pass it on.
- of(SerializableBiFunction<V, V, V>) - Static method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
-
Returns a
CombineFnthat uses the givenSerializableBiFunctionto combine values. - of(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
-
Returns a
CombineFnthat uses the givenSerializableFunctionto combine values. - of(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine.SimpleCombineFn
-
Deprecated.Returns a
CombineFnthat uses the givenSerializableFunctionto combine values. - of(SerializableFunction<Iterable<V>, V>, int) - Static method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
-
Returns a
CombineFnthat uses the givenSerializableFunctionto combine values, attempting to buffer at leastbufferSizevalues between invocations. - of(SerializableFunction<Row, byte[]>, SerializableFunction<byte[], Row>) - Static method in interface org.apache.beam.sdk.schemas.io.payloads.PayloadSerializer
- of(SerializableFunction<Row, Integer>) - Static method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields.Fanout
- of(SerializableFunction<T, Instant>) - Static method in class org.apache.beam.sdk.transforms.WithTimestamps
-
For a
SerializableFunctionfnfromTtoInstant, outputs aPTransformthat takes an inputPCollection<T>and outputs aPCollection<T>containing every elementvin the input where each element is output with a timestamp obtained as the result offn.apply(v). - of(SerializableFunction<V, K>) - Static method in class org.apache.beam.sdk.transforms.WithKeys
-
Returns a
PTransformthat takes aPCollection<V>and returns aPCollection<KV<K, V>>, where each of the values in the inputPCollectionhas been paired with a key computed from the value by invoking the givenSerializableFunction. - of(Trigger.OnceTrigger...) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterAll
-
Returns an
AfterAllTriggerwith the given subtriggers. - of(Trigger.OnceTrigger...) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterFirst
-
Returns an
AfterFirstTriggerwith the given subtriggers. - of(WindowFn<T, W>) - Static method in class org.apache.beam.sdk.values.WindowingStrategy
- of(PipelineNode.PTransformNode, String) - Static method in class org.apache.beam.sdk.util.construction.graph.TimerReference
-
Create a timer reference.
- of(PipelineNode.PTransformNode, String, PipelineNode.PCollectionNode) - Static method in class org.apache.beam.sdk.util.construction.graph.SideInputReference
-
Create a side input reference.
- of(PipelineNode.PTransformNode, String, PipelineNode.PCollectionNode) - Static method in class org.apache.beam.sdk.util.construction.graph.UserStateReference
-
Create a user state reference.
- of(PCollection<OutputElementT>, PCollection<FailureElementT>) - Static method in class org.apache.beam.sdk.transforms.WithFailures.Result
- of(PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionList
-
Returns a singleton
PCollectionListcontaining the givenPCollection. - of(PCollectionTuple, TupleTag<OutputElementT>, TupleTag<FailureElementT>) - Static method in class org.apache.beam.sdk.transforms.WithFailures.Result
- of(PCollectionView<ViewT>) - Static method in class org.apache.beam.sdk.transforms.View.CreatePCollectionView
- of(Row) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.FixedPrecisionNumeric
-
Create a FixedPrecisionNumeric instance with specified argument row.
- of(TaggedPValue, TaggedPValue) - Static method in class org.apache.beam.sdk.runners.PTransformOverrideFactory.ReplacementOutput
- of(TupleTag<?>) - Static method in class org.apache.beam.sdk.values.TupleTagList
-
Returns a singleton
TupleTagListcontaining the givenTupleTag. - of(TupleTag<?>, PCollection<?>) - Static method in class org.apache.beam.sdk.values.TaggedPValue
- of(TupleTag<InputT>, PCollection<KV<K, InputT>>) - Static method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
Returns a new
KeyedPCollectionTuple<K>with the given tag and initial PCollection. - of(TupleTag<T>, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
- of(TupleTag<V>, List<V>) - Static method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
Returns a new CoGbkResult that contains just the given tag and given data.
- of(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.coders.SerializableCoder
-
Returns a
SerializableCoderinstance for the provided element type. - of(Duration) - Static method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
-
Partitions the timestamp space into half-open intervals of the form [N * size, (N + 1) * size), where 0 is the epoch.
- of(Duration) - Static method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
-
Assigns timestamps into half-open intervals of the form [N * period, N * period + size), where 0 is the epoch.
- of(OutputT, PCollection<FailureElementT>) - Static method in class org.apache.beam.sdk.transforms.WithFailures.Result
- of(RestrictionT) - Static method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.TruncateResult
-
Returns a
RestrictionTracker.TruncateResultfor the given restriction. - of(T) - Static method in class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
-
Creates a
ValueProvider.StaticValueProviderthat wraps the provided value. - of(T, long) - Static method in class org.apache.beam.sdk.util.WeightedValue
- of(T, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Max
-
A
CombineFnthat computes the maximum of a collection of elements of typeTusing an arbitraryComparatorandidentity, useful as an argument toCombine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>)orCombine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>). - of(T, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Min
-
A
CombineFnthat computes the minimum of a collection of elements of typeTusing an arbitraryComparatorand anidentity, useful as an argument toCombine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>)orCombine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>). - of(T, Exception) - Static method in class org.apache.beam.sdk.transforms.WithFailures.ExceptionElement
- of(T, Instant, Collection<? extends BoundedWindow>, PaneInfo) - Static method in class org.apache.beam.sdk.values.WindowedValues
- of(T, Instant, Collection<? extends BoundedWindow>, PaneInfo, String, Long) - Static method in class org.apache.beam.sdk.values.WindowedValues
-
Returns a
WindowedValuewith the given value, timestamp, and windows. - of(T, Instant, BoundedWindow, PaneInfo) - Static method in class org.apache.beam.sdk.values.ValueInSingleWindow
- of(T, Instant, BoundedWindow, PaneInfo) - Static method in class org.apache.beam.sdk.values.WindowedValues
-
Returns a
WindowedValuewith the given value, timestamp, and window. - of(T, Instant, BoundedWindow, PaneInfo, String, Long) - Static method in class org.apache.beam.sdk.values.ValueInSingleWindow
- of(T, Instant, BoundedWindow, PaneInfo, ErrorT) - Static method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow
- of(ValueT) - Static method in class org.apache.beam.sdk.util.Holder
- of(V, Instant) - Static method in class org.apache.beam.sdk.values.TimestampedValue
-
Returns a new
TimestampedValuewith the given value and timestamp. - ofByteSize(long) - Static method in class org.apache.beam.sdk.transforms.GroupIntoBatches
-
Aim to create batches each with the specified byte size.
- ofByteSize(long, SerializableFunction<InputT, Long>) - Static method in class org.apache.beam.sdk.transforms.GroupIntoBatches
-
Aim to create batches each with the specified byte size.
- ofClass(Class<?>) - Static method in class org.apache.beam.sdk.util.ApiSurface
-
Returns an
ApiSurfaceobject representing just the surface of the given class. - ofDoubles() - Static method in class org.apache.beam.sdk.transforms.Max
-
A
CombineFnthat computes the maximum of a collection ofDoubles, useful as an argument toCombine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>)orCombine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>). - ofDoubles() - Static method in class org.apache.beam.sdk.transforms.Min
-
A
CombineFnthat computes the minimum of a collection ofDoubles, useful as an argument toCombine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>)orCombine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>). - ofDoubles() - Static method in class org.apache.beam.sdk.transforms.Sum
-
A
SerializableFunctionthat computes the sum of anIterableofDoubles, useful as an argument toCombine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>)orCombine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>). - ofExpandedValue(PCollection<?>) - Static method in class org.apache.beam.sdk.values.TaggedPValue
- OFF - org.apache.beam.sdk.options.PipelineOptions.CheckEnabled
- OFF - org.apache.beam.sdk.options.SdkHarnessOptions.LogLevel
-
Special level used to turn off logging.
- offerCoders(Coder[]) - Method in interface org.apache.beam.sdk.state.StateSpec
-
For internal use only; no backwards-compatibility guarantees.
- ofFirstElement() - Static method in class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
- offset(Duration) - Method in interface org.apache.beam.sdk.state.Timer
-
Offsets the target timestamp used by
Timer.setRelative()by the given duration. - OFFSET_INFINITY - Static variable in class org.apache.beam.sdk.io.range.OffsetRangeTracker
-
Offset corresponding to infinity.
- offsetBasedDeduplicationSupported() - Method in class org.apache.beam.sdk.io.UnboundedSource
-
If offsetBasedDeduplicationSupported returns true, then the UnboundedSource needs to provide the following: UnboundedReader which provides offsets that are unique for each element and lexicographically ordered.
- OffsetBasedReader(OffsetBasedSource<T>) - Constructor for class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
- OffsetBasedSource<T> - Class in org.apache.beam.sdk.io
-
A
BoundedSourcethat uses offsets to define starting and ending positions. - OffsetBasedSource(long, long, long) - Constructor for class org.apache.beam.sdk.io.OffsetBasedSource
- OffsetBasedSource.OffsetBasedReader<T> - Class in org.apache.beam.sdk.io
-
A
Source.Readerthat implements code common to readers of allOffsetBasedSources. - OffsetRange - Class in org.apache.beam.sdk.io.range
-
A restriction represented by a range of integers [from, to).
- OffsetRange(long, long) - Constructor for class org.apache.beam.sdk.io.range.OffsetRange
- OffsetRange.Coder - Class in org.apache.beam.sdk.io.range
-
A coder for
OffsetRanges. - OffsetRangeTracker - Class in org.apache.beam.sdk.io.range
-
A
RangeTrackerfor non-negative positions of typelong. - OffsetRangeTracker - Class in org.apache.beam.sdk.transforms.splittabledofn
-
A
RestrictionTrackerfor claiming offsets in anOffsetRangein a monotonically increasing fashion. - OffsetRangeTracker(long, long) - Constructor for class org.apache.beam.sdk.io.range.OffsetRangeTracker
-
Creates an
OffsetRangeTrackerfor the specified range. - OffsetRangeTracker(OffsetRange) - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
- ofFullComponents(RunnerApi.Components, RunnerApi.Environment, PipelineNode.PCollectionNode, Collection<SideInputReference>, Collection<UserStateReference>, Collection<TimerReference>, Collection<PipelineNode.PTransformNode>, Collection<PipelineNode.PCollectionNode>, Collection<RunnerApi.ExecutableStagePayload.WireCoderSetting>) - Static method in class org.apache.beam.sdk.util.construction.graph.ImmutableExecutableStage
- ofIntegers() - Static method in class org.apache.beam.sdk.transforms.Max
-
A
CombineFnthat computes the maximum of a collection ofIntegers, useful as an argument toCombine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>)orCombine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>). - ofIntegers() - Static method in class org.apache.beam.sdk.transforms.Min
-
A
CombineFnthat computes the minimum of a collection ofIntegers, useful as an argument toCombine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>)orCombine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>). - ofIntegers() - Static method in class org.apache.beam.sdk.transforms.Sum
-
A
SerializableFunctionthat computes the sum of anIterableofIntegers, useful as an argument toCombine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>)orCombine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>). - ofLongs() - Static method in class org.apache.beam.sdk.transforms.Max
-
A
CombineFnthat computes the maximum of a collection ofLongs, useful as an argument toCombine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>)orCombine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>). - ofLongs() - Static method in class org.apache.beam.sdk.transforms.Min
-
A
CombineFnthat computes the minimum of a collection ofLongs, useful as an argument toCombine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>)orCombine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>). - ofLongs() - Static method in class org.apache.beam.sdk.transforms.Sum
-
A
SerializableFunctionthat computes the sum of anIterableofLongs, useful as an argument toCombine.globally(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>)orCombine.perKey(org.apache.beam.sdk.transforms.SerializableFunction<java.lang.Iterable<V>, V>). - ofPackage(Package, ClassLoader) - Static method in class org.apache.beam.sdk.util.ApiSurface
-
Returns an
ApiSurfaceobject representing the given package and all subpackages. - ofPackage(String, ClassLoader) - Static method in class org.apache.beam.sdk.util.ApiSurface
-
Returns an
ApiSurfaceobject representing the given package and all subpackages. - ofPrimitiveOutputsInternal(Pipeline, TupleTagList, Map<TupleTag<?>, Coder<?>>, WindowingStrategy<?, ?>, PCollection.IsBounded) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
For internal use only; no backwards-compatibility guarantees.
- ofProvider(ValueProvider<T>, Coder<T>) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns an
Create.OfValueProvidertransform that produces aPCollectionof a single element provided by the givenValueProvider. - ofSize(long) - Static method in class org.apache.beam.sdk.transforms.GroupIntoBatches
-
Aim to create batches each with the specified element count.
- ofType(Class<T>) - Static method in class org.apache.beam.sdk.util.InstanceBuilder
-
Create an InstanceBuilder for the given type.
- ofType(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.util.InstanceBuilder
-
Create an InstanceBuilder for the given type.
- OK - org.apache.beam.sdk.io.fs.MatchResult.Status
- on(List<PCollection<?>>) - Static method in class org.apache.beam.sdk.transforms.Wait
-
Waits on the given signal collections.
- on(Join.FieldsEqual.Impl) - Method in class org.apache.beam.sdk.schemas.transforms.Join.Impl
-
Join the PCollections using the provided predicate.
- on(PCollection<?>...) - Static method in class org.apache.beam.sdk.transforms.Wait
-
Waits on the given signal collections.
- ON_TIME - org.apache.beam.sdk.transforms.windowing.PaneInfo.Timing
-
Pane was fired by a
AfterWatermark.pastEndOfWindow()trigger because the input watermark progressed after the end of the window. - ON_TIME_AND_ONLY_FIRING - Static variable in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
PaneInfoto use when there will be exactly one firing and it is on time. - onAdvance(int, int) - Method in class org.apache.beam.sdk.fn.stream.AdvancingPhaser
- onBundleSuccess() - Method in interface org.apache.beam.sdk.transforms.DoFn.BundleFinalizer.Callback
- OnceTrigger(List<Trigger>) - Constructor for class org.apache.beam.sdk.transforms.windowing.Trigger.OnceTrigger
- onClaimed(PositionT) - Method in interface org.apache.beam.sdk.fn.splittabledofn.RestrictionTrackers.ClaimObserver
-
Called when
RestrictionTracker.tryClaim(PositionT)returns true. - onClaimFailed(PositionT) - Method in interface org.apache.beam.sdk.fn.splittabledofn.RestrictionTrackers.ClaimObserver
-
Called when
RestrictionTracker.tryClaim(PositionT)returns false. - onCompleted() - Method in class org.apache.beam.sdk.fn.stream.BufferingStreamObserver
- onCompleted() - Method in class org.apache.beam.sdk.fn.stream.DirectStreamObserver
- onCompleted() - Method in class org.apache.beam.sdk.fn.stream.ForwardingClientResponseObserver
- onCompleted() - Method in class org.apache.beam.sdk.fn.stream.SynchronizedStreamObserver
- OneOfType - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A logical type representing a union of fields.
- OneOfType.Value - Class in org.apache.beam.sdk.schemas.logicaltypes
-
Represents a single OneOf value.
- onError(Throwable) - Method in class org.apache.beam.sdk.fn.stream.BufferingStreamObserver
- onError(Throwable) - Method in class org.apache.beam.sdk.fn.stream.DirectStreamObserver
- onError(Throwable) - Method in class org.apache.beam.sdk.fn.stream.ForwardingClientResponseObserver
- onError(Throwable) - Method in class org.apache.beam.sdk.fn.stream.SynchronizedStreamObserver
- only(String) - Method in class org.apache.beam.sdk.util.RowFilter
-
Configures this
RowFilterto only output the contents of a single row field. - onNext(ReqT) - Method in class org.apache.beam.sdk.fn.stream.ForwardingClientResponseObserver
- onNext(T) - Method in class org.apache.beam.sdk.fn.stream.BufferingStreamObserver
- onNext(T) - Method in class org.apache.beam.sdk.fn.stream.DirectStreamObserver
- onNext(V) - Method in class org.apache.beam.sdk.fn.stream.SynchronizedStreamObserver
- onPollComplete(StateT) - Method in interface org.apache.beam.sdk.transforms.Watch.Growth.TerminationCondition
-
Called by the
Watchtransform to compute a new termination state after every poll completion. - onSeenNewOutput(Instant, StateT) - Method in interface org.apache.beam.sdk.transforms.Watch.Growth.TerminationCondition
-
Called by the
Watchtransform to compute a new termination state, in case after calling theWatch.Growth.PollFnfor the current input, theWatch.Growth.PollResultincluded a previously unseenOutputT. - onStartup() - Method in interface org.apache.beam.sdk.harness.JvmInitializer
-
Implement onStartup to run some custom initialization immediately after the JVM is launched for pipeline execution.
- onTimerContext() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- onTimerContext(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provide a
DoFn.OnTimerContextto use with the givenDoFn. - onTimerContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- onTimerContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- OnTimerContext() - Constructor for class org.apache.beam.sdk.transforms.DoFn.OnTimerContext
- OnTimerFamilyMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerFamilyMethod
- onTimerFamilyMethods() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.OnTimerFamilymethods. - OnTimerInvoker<InputT,OutputT> - Interface in org.apache.beam.sdk.transforms.reflect
-
Interface for invoking the
DoFn.OnTimermethod for a particular timer. - OnTimerMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerMethod
- onTimerMethods() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.OnTimermethods. - onWindowExpiration() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.OnWindowExpirationmethod. - onWindowExpirationContext() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- OnWindowExpirationContext() - Constructor for class org.apache.beam.sdk.transforms.DoFn.OnWindowExpirationContext
- OnWindowExpirationMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnWindowExpirationMethod
- open() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
-
Returns a
ReadableByteChannelreading the data from this file, potentially decompressing it usingFileIO.ReadableFile.getCompression(). - open(String) - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
-
Opens a uniquely named temporary file and initializes the writer using
FileBasedSink.Writer.prepareWrite(java.nio.channels.WritableByteChannel). - open(WritableByteChannel) - Method in interface org.apache.beam.sdk.io.FileIO.Sink
-
Initializes writing to the given channel.
- open(WritableByteChannel) - Method in class org.apache.beam.sdk.io.TextIO.Sink
- open(WritableByteChannel) - Method in class org.apache.beam.sdk.io.TFRecordIO.Sink
- open(ClassLoaderFileSystem.ClassLoaderResourceId) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
- open(ResourceId) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Returns a read channel for the given
ResourceId. - open(ResourceIdT) - Method in class org.apache.beam.sdk.io.FileSystem
-
Returns a read channel for the given
FileSystem. - openSeekable() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
-
Returns a
SeekableByteChannelequivalent toFileIO.ReadableFile.open(), but fails if this file is notseekable. - optimize(Pipeline) - Static method in class org.apache.beam.sdk.util.construction.graph.ProjectionPushdownOptimizer
-
Performs all known projection pushdown optimizations in-place on a Pipeline.
- OptionalCoder<T> - Class in org.apache.beam.sdk.coders
- Options() - Constructor for class org.apache.beam.sdk.options.ManualDockerEnvironmentOptions.Options
- Options() - Constructor for class org.apache.beam.sdk.options.RemoteEnvironmentOptions.Options
- Options() - Constructor for class org.apache.beam.sdk.transforms.resourcehints.ResourceHintsOptions.Options
- or(PTransformMatcher) - Method in interface org.apache.beam.sdk.runners.PTransformMatcher
- OrderByKey() - Constructor for class org.apache.beam.sdk.values.KV.OrderByKey
- OrderByValue() - Constructor for class org.apache.beam.sdk.values.KV.OrderByValue
- ORDERED_LIST_USER_STATE - Static variable in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
Represents a user state specification that supports an ordered list.
- orderedList(Coder<T>) - Static method in class org.apache.beam.sdk.state.StateSpecs
- OrderedListState<T> - Interface in org.apache.beam.sdk.state
-
A
ReadableStatecell containing a list of values sorted by timestamp. - orFinally(Trigger.OnceTrigger) - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
-
Specify an ending condition for this trigger.
- OrFinallyTrigger - Class in org.apache.beam.sdk.transforms.windowing
-
A
Triggerthat executes according to its main trigger until its "finally" trigger fires. - org.apache.beam.sdk - package org.apache.beam.sdk
-
Provides a simple, powerful model for building both batch and streaming parallel data processing
Pipelines. - org.apache.beam.sdk.annotations - package org.apache.beam.sdk.annotations
-
Defines annotations used across the SDK.
- org.apache.beam.sdk.coders - package org.apache.beam.sdk.coders
-
Defines
Codersto specify how data is encoded to and decoded from byte strings. - org.apache.beam.sdk.expansion - package org.apache.beam.sdk.expansion
-
Contains classes needed to expose transforms to other SDKs.
- org.apache.beam.sdk.fn - package org.apache.beam.sdk.fn
-
The top level package for the Fn Execution Java libraries.
- org.apache.beam.sdk.fn.channel - package org.apache.beam.sdk.fn.channel
-
gRPC channel management.
- org.apache.beam.sdk.fn.data - package org.apache.beam.sdk.fn.data
-
Classes to interact with the portability framework data plane.
- org.apache.beam.sdk.fn.server - package org.apache.beam.sdk.fn.server
-
gPRC server factory.
- org.apache.beam.sdk.fn.splittabledofn - package org.apache.beam.sdk.fn.splittabledofn
-
Defines utilities related to executing splittable
DoFn. - org.apache.beam.sdk.fn.stream - package org.apache.beam.sdk.fn.stream
-
gRPC stream management.
- org.apache.beam.sdk.fn.test - package org.apache.beam.sdk.fn.test
-
Utilities for testing use of this package.
- org.apache.beam.sdk.fn.windowing - package org.apache.beam.sdk.fn.windowing
-
Common utilities related to windowing during execution of a pipeline.
- org.apache.beam.sdk.function - package org.apache.beam.sdk.function
-
Java 8 functional interface extensions.
- org.apache.beam.sdk.harness - package org.apache.beam.sdk.harness
-
Utilities for configuring worker environment.
- org.apache.beam.sdk.io - package org.apache.beam.sdk.io
-
Defines transforms for reading and writing common storage formats, including
org.apache.beam.sdk.io.AvroIO, andTextIO. - org.apache.beam.sdk.io.fs - package org.apache.beam.sdk.io.fs
-
Apache Beam FileSystem interfaces and their default implementations.
- org.apache.beam.sdk.io.range - package org.apache.beam.sdk.io.range
-
Provides thread-safe helpers for implementing dynamic work rebalancing in position-based bounded sources.
- org.apache.beam.sdk.metrics - package org.apache.beam.sdk.metrics
-
Metrics allow exporting information about the execution of a pipeline.
- org.apache.beam.sdk.options - package org.apache.beam.sdk.options
-
Defines
PipelineOptionsfor configuring pipeline execution. - org.apache.beam.sdk.providers - package org.apache.beam.sdk.providers
-
Defines
SchemaTransformProviders for transforms in the core module. - org.apache.beam.sdk.runners - package org.apache.beam.sdk.runners
-
For internal use only; no backwards compatibility guarantees.
- org.apache.beam.sdk.schemas - package org.apache.beam.sdk.schemas
- org.apache.beam.sdk.schemas.annotations - package org.apache.beam.sdk.schemas.annotations
- org.apache.beam.sdk.schemas.io - package org.apache.beam.sdk.schemas.io
-
Provides abstractions for schema-aware IOs.
- org.apache.beam.sdk.schemas.io.payloads - package org.apache.beam.sdk.schemas.io.payloads
-
Provides abstractions for schema-aware IOs.
- org.apache.beam.sdk.schemas.logicaltypes - package org.apache.beam.sdk.schemas.logicaltypes
-
A set of common LogicalTypes for use with schemas.
- org.apache.beam.sdk.schemas.parser - package org.apache.beam.sdk.schemas.parser
-
Defines utilities for deailing with schemas.
- org.apache.beam.sdk.schemas.parser.generated - package org.apache.beam.sdk.schemas.parser.generated
-
Defines utilities for deailing with schemas.
- org.apache.beam.sdk.schemas.transforms - package org.apache.beam.sdk.schemas.transforms
-
Defines transforms that work on PCollections with schemas..
- org.apache.beam.sdk.schemas.transforms.providers - package org.apache.beam.sdk.schemas.transforms.providers
-
Defines transforms that work on PCollections with schemas..
- org.apache.beam.sdk.schemas.utils - package org.apache.beam.sdk.schemas.utils
-
Defines utilities for deailing with schemas.
- org.apache.beam.sdk.state - package org.apache.beam.sdk.state
-
Classes and interfaces for interacting with state.
- org.apache.beam.sdk.testing - package org.apache.beam.sdk.testing
-
Defines utilities for unit testing Apache Beam pipelines.
- org.apache.beam.sdk.transforms - package org.apache.beam.sdk.transforms
-
Defines
PTransforms for transforming data in a pipeline. - org.apache.beam.sdk.transforms.display - package org.apache.beam.sdk.transforms.display
-
Defines
HasDisplayDatafor annotating components which providedisplay dataused within UIs and diagnostic tools. - org.apache.beam.sdk.transforms.errorhandling - package org.apache.beam.sdk.transforms.errorhandling
-
Provides utilities for handling errors in Pipelines.
- org.apache.beam.sdk.transforms.join - package org.apache.beam.sdk.transforms.join
-
Defines the
CoGroupByKeytransform for joining multiple PCollections. - org.apache.beam.sdk.transforms.reflect - package org.apache.beam.sdk.transforms.reflect
-
For internal use only; no backwards-compatibility guarantees.
- org.apache.beam.sdk.transforms.resourcehints - package org.apache.beam.sdk.transforms.resourcehints
-
Defines
ResourceHintsfor configuring pipeline execution. - org.apache.beam.sdk.transforms.splittabledofn - package org.apache.beam.sdk.transforms.splittabledofn
-
Defines utilities related to splittable
DoFn. - org.apache.beam.sdk.transforms.windowing - package org.apache.beam.sdk.transforms.windowing
- org.apache.beam.sdk.util - package org.apache.beam.sdk.util
-
For internal use only; no backwards compatibility guarantees.
- org.apache.beam.sdk.util.common - package org.apache.beam.sdk.util.common
-
Defines utilities shared by multiple PipelineRunner implementations.
- org.apache.beam.sdk.util.construction - package org.apache.beam.sdk.util.construction
-
Provides utilities for Beam runner authors, prior to execution.
- org.apache.beam.sdk.util.construction.graph - package org.apache.beam.sdk.util.construction.graph
-
Graph-manipulation utilities.
- org.apache.beam.sdk.util.construction.renderer - package org.apache.beam.sdk.util.construction.renderer
-
Classes used to render Pipelines.
- org.apache.beam.sdk.util.construction.resources - package org.apache.beam.sdk.util.construction.resources
-
Classes used to render Pipelines.
- org.apache.beam.sdk.values - package org.apache.beam.sdk.values
-
Defines
PCollectionand other classes for representing data in aPipeline. - outbound(DataStreams.OutputChunkConsumer<ByteString>) - Static method in class org.apache.beam.sdk.fn.stream.DataStreams
-
Converts a single element delimited
OutputStreaminto multipleByteStrings. - outbound(DataStreams.OutputChunkConsumer<ByteString>, int) - Static method in class org.apache.beam.sdk.fn.stream.DataStreams
-
Converts a single element delimited
OutputStreaminto multipleByteStringsusing the specified maximum chunk size. - OutboundObserverFactory - Class in org.apache.beam.sdk.fn.stream
-
Creates factories which determine an underlying
StreamObserverimplementation to use in to interact with fn execution APIs. - OutboundObserverFactory() - Constructor for class org.apache.beam.sdk.fn.stream.OutboundObserverFactory
- OutboundObserverFactory.BasicFactory<ReqT,RespT> - Interface in org.apache.beam.sdk.fn.stream
-
Creates an outbound observer for the given inbound observer.
- outboundObserverFor(OutboundObserverFactory.BasicFactory<ReqT, RespT>, StreamObserver<ReqT>) - Method in class org.apache.beam.sdk.fn.stream.OutboundObserverFactory
-
Creates an outbound observer for the given inbound observer by potentially inserting hooks into the inbound and outbound observers.
- outboundObserverFor(StreamObserver<ReqT>) - Method in interface org.apache.beam.sdk.fn.stream.OutboundObserverFactory.BasicFactory
- OUTER - Static variable in class org.apache.beam.sdk.coders.Coder.Context
-
Deprecated.The outer context: the value being encoded or decoded takes up the remainder of the record/stream contents.
- output() - Method in class org.apache.beam.sdk.transforms.WithFailures.Result
- output() - Method in interface org.apache.beam.sdk.values.OutputBuilder
- output() - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- output(TupleTag<OutputT>, WindowedValue<OutputT>) - Method in interface org.apache.beam.sdk.util.WindowedValueMultiReceiver
-
Outputs to the given
TupleTag. - output(TupleTag<T>, T) - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
-
Adds the given element to the output
PCollectionwith the given tag. - output(TupleTag<T>, T, Instant, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFn.FinishBundleContext
-
Adds the given element to the output
PCollectionwith the given tag at the given timestamp in the given window. - output(WindowedValue<OutputT>) - Method in interface org.apache.beam.sdk.util.WindowedValueReceiver
-
Outputs a value with windowing information.
- output(OutputT) - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
-
Adds the given element to the main output
PCollection. - output(OutputT, Instant, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFn.FinishBundleContext
-
Adds the given element to the main output
PCollectionat the given timestamp in the given window. - output(T) - Method in interface org.apache.beam.sdk.transforms.DoFn.OutputReceiver
- OUTPUT_ROWS_TAG - Static variable in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider
- OUTPUT_ROWS_TAG - Static variable in class org.apache.beam.sdk.schemas.transforms.providers.FlattenTransformProvider
- OUTPUT_ROWS_TAG - Static variable in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider
- OUTPUT_ROWS_TAG - Static variable in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider
- OUTPUT_ROWS_TAG - Static variable in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider
- OUTPUT_ROWS_TAG - Static variable in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider
- OUTPUT_SCHEMA - Static variable in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider
- OUTPUT_TAG - Static variable in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformProvider
- OUTPUT_TAG - Static variable in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformProvider
- OutputBuilder<T> - Interface in org.apache.beam.sdk.values
-
A builder for an output, to set all the fields and extended metadata of a Beam value.
- OutputBuilderSupplier - Interface in org.apache.beam.sdk.util
- OutputBuilderSuppliers - Class in org.apache.beam.sdk.util
-
Implementations of
OutputBuilderSupplier. - outputCollectionNames() - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformProvider
-
Implementation of the
TypedSchemaTransformProvideroutputCollectionNames method. - outputCollectionNames() - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformProvider
-
Implementation of the
TypedSchemaTransformProvideroutputCollectionNames method. - outputCollectionNames() - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider
- outputCollectionNames() - Method in class org.apache.beam.sdk.schemas.transforms.providers.FlattenTransformProvider
- outputCollectionNames() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider
- outputCollectionNames() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider
- outputCollectionNames() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider
- outputCollectionNames() - Method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider
- outputCollectionNames() - Method in interface org.apache.beam.sdk.schemas.transforms.SchemaTransformProvider
-
Returns the output collection names of this transform.
- outputOf(Contextful.Fn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
Like
TypeDescriptors.outputOf(ProcessFunction)but forContextful.Fn. - outputOf(ProcessFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
Returns a type descriptor for the output of the given
ProcessFunction, subject to Java type erasure: may contain unresolved type variables if the type was erased. - outputOf(SerializableFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
Binary compatibility adapter for
TypeDescriptors.outputOf(ProcessFunction). - OutputRangeTracker(OffsetRange) - Constructor for class org.apache.beam.sdk.transforms.PeriodicSequence.OutputRangeTracker
- outputReceiver(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provide a
DoFn.OutputReceiverfor outputting to the default output. - outputReceiver(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- outputReceiver(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- outputReceiverParameter(boolean) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- outputRowReceiver(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provide a
DoFn.OutputReceiverfor outputting rows to the default output. - outputRowReceiver(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- outputRowReceiver(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- outputRuntimeOptions() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
Returns a map of properties which correspond to
ValueProvider.RuntimeValueProvider, keyed by the property name. - outputSchema() - Method in class org.apache.beam.sdk.schemas.transforms.Cast
- outputSchema() - Method in class org.apache.beam.sdk.util.RowFilter
- outputSchemaCoder - Variable in class org.apache.beam.sdk.schemas.utils.ConvertHelpers.ConvertedSchemaInformation
- outputWindowedValue(TupleTag<T>, T, Instant, Collection<? extends BoundedWindow>, PaneInfo) - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
-
Adds the given element to the main output
PCollection, with the given windowing metadata. - outputWindowedValue(OutputT, Instant, Collection<? extends BoundedWindow>, PaneInfo) - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
-
Adds the given element to the main output
PCollection, with the given windowing metadata. - outputWindowedValue(T, Instant, Collection<? extends BoundedWindow>, PaneInfo) - Method in interface org.apache.beam.sdk.transforms.DoFn.OutputReceiver
- outputWithTimestamp(TupleTag<T>, T, Instant) - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
-
Adds the given element to the specified output
PCollection, with the given timestamp. - outputWithTimestamp(OutputT, Instant) - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
-
Adds the given element to the main output
PCollection, with the given timestamp. - outputWithTimestamp(T, Instant) - Method in interface org.apache.beam.sdk.transforms.DoFn.OutputReceiver
- OVER_SPECIFIED - org.apache.beam.sdk.coders.CannotProvideCoderException.ReasonCode
-
The reason a coder could not be provided is because the type variable
Tis over specified with multiple incompatible coders. - overlaps(ByteKeyRange) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
-
Returns
trueif the specifiedByteKeyRangeoverlaps this range. - overrideEncodingPositions(UUID, Map<String, Integer>) - Static method in class org.apache.beam.sdk.coders.RowCoder
-
Override encoding positions for the given schema.
- overrideEncodingPositions(UUID, Map<String, Integer>) - Static method in class org.apache.beam.sdk.coders.RowCoderGenerator
- overrideEncodingPositions(UUID, Map<String, Integer>) - Static method in class org.apache.beam.sdk.schemas.SchemaCoder
-
Override encoding positions for the given schema.
- OverrideFactory() - Constructor for class org.apache.beam.sdk.util.construction.SplittableParDo.OverrideFactory
- OverrideFactory() - Constructor for class org.apache.beam.sdk.util.construction.SplittableParDoNaiveBounded.OverrideFactory
P
- p50() - Method in class org.apache.beam.sdk.util.HistogramData
- p90() - Method in class org.apache.beam.sdk.util.HistogramData
- p99() - Method in class org.apache.beam.sdk.util.HistogramData
- pane() - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContext
-
Returns information about the pane within this window into which the input element has been assigned.
- PANE_INDEX - Static variable in class org.apache.beam.sdk.util.RowStringInterpolator
- paneInfo(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provides a
PaneInfo. - paneInfo(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- paneInfo(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- PaneInfo - Class in org.apache.beam.sdk.transforms.windowing
-
Provides information about the pane an element belongs to.
- PaneInfo.PaneInfoCoder - Class in org.apache.beam.sdk.transforms.windowing
-
A Coder for encoding PaneInfo instances.
- PaneInfo.Timing - Enum in org.apache.beam.sdk.transforms.windowing
-
Enumerates the possibilities for the timing of this pane firing related to the input and output watermarks for its computation.
- paneInfoParameter() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- PAR_DO_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- PARAM_WINDOWED_VALUE_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- Params() - Constructor for class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
-
Construct a default Params object.
- ParamsCoder() - Constructor for class org.apache.beam.sdk.io.DefaultFilenamePolicy.ParamsCoder
- paramWindowedValueCoder(String, String, byte[]) - Static method in class org.apache.beam.sdk.util.construction.ModelCoders
- ParDo - Class in org.apache.beam.sdk.transforms
-
ParDois the core element-wise transform in Apache Beam, invoking a user-specified function on each of the elements of the inputPCollectionto produce zero or more output elements, all of which are collected into the outputPCollection. - ParDo() - Constructor for class org.apache.beam.sdk.transforms.ParDo
- ParDo.MultiOutput<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
A
PTransformthat, when applied to aPCollection<InputT>, invokes a user-specifiedDoFn<InputT, OutputT>on all its elements, which can emit elements to any of thePTransform's outputPCollections, which are bundled into a resultPCollectionTuple. - ParDo.SingleOutput<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
A
PTransformthat, when applied to aPCollection<InputT>, invokes a user-specifiedDoFn<InputT, OutputT>on all its elements, with all its outputs collected into an outputPCollection<OutputT>. - ParDoLikeTimerFamilySpecs() - Constructor for class org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoLikeTimerFamilySpecs
- ParDoTranslation - Class in org.apache.beam.sdk.util.construction
-
Utilities for interacting with
ParDoinstances andRunnerApi.ParDoPayloadprotos. - ParDoTranslation() - Constructor for class org.apache.beam.sdk.util.construction.ParDoTranslation
- ParDoTranslation.ParDoLike - Interface in org.apache.beam.sdk.util.construction
-
These methods drive to-proto translation from Java and from rehydrated ParDos.
- ParDoTranslation.ParDoLikeTimerFamilySpecs - Class in org.apache.beam.sdk.util.construction
- ParDoTranslation.ParDoTranslator - Class in org.apache.beam.sdk.util.construction
- parDoWithFnType(Class<? extends DoFn>) - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
A
PTransformMatcherwhich matches aParDo.SingleOutputorParDo.MultiOutputwhere theDoFnis of the provided type. - parent() - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
-
Type of parent node in a tree.
- parse(String) - Static method in class org.apache.beam.sdk.schemas.parser.FieldAccessDescriptorParser
- parse(T) - Method in class org.apache.beam.sdk.testing.JsonMatcher
- ParsedMetricName() - Constructor for class org.apache.beam.sdk.metrics.LabeledMetricNameUtils.ParsedMetricName
- parseMetricName(String) - Static method in class org.apache.beam.sdk.metrics.LabeledMetricNameUtils
-
Parse a 'metric name' String that was created with 'MetricNameBuilder'.
- ParseResult() - Constructor for class org.apache.beam.sdk.transforms.JsonToRow.ParseResult
- parseSecretOption(String) - Static method in interface org.apache.beam.sdk.util.Secret
- ParseWithError() - Constructor for class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError
- Partition<T> - Class in org.apache.beam.sdk.transforms
-
Partitiontakes aPCollection<T>and aPartitionFn, uses thePartitionFnto split the elements of the inputPCollectionintoNpartitions, and returns aPCollectionList<T>that bundlesNPCollection<T>s containing the split elements. - Partition.PartitionFn<T> - Interface in org.apache.beam.sdk.transforms
-
A function object that chooses an output partition for an element.
- Partition.PartitionWithSideInputsFn<T> - Interface in org.apache.beam.sdk.transforms
-
A function object that chooses an output partition for an element.
- partitionFor(T, int) - Method in interface org.apache.beam.sdk.transforms.Partition.PartitionFn
-
Chooses the partition into which to put the given element.
- partitionFor(T, int, Contextful.Fn.Context) - Method in interface org.apache.beam.sdk.transforms.Partition.PartitionWithSideInputsFn
-
Chooses the partition into which to put the given element.
- PartitioningWindowFn<T,W extends BoundedWindow> - Class in org.apache.beam.sdk.transforms.windowing
-
A
WindowFnthat places each value into exactly one window based on its timestamp and never merges windows. - PartitioningWindowFn() - Constructor for class org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn
- PAssert - Class in org.apache.beam.sdk.testing
-
An assertion on the contents of a
PCollectionincorporated into the pipeline. - PAssert.DefaultConcludeTransform - Class in org.apache.beam.sdk.testing
-
Default transform to check that a PAssert was successful.
- PAssert.GroupThenAssert<T> - Class in org.apache.beam.sdk.testing
-
A transform that applies an assertion-checking function over iterables of
ActualTto the entirety of the contents of its input. - PAssert.GroupThenAssertForSingleton<T> - Class in org.apache.beam.sdk.testing
-
A transform that applies an assertion-checking function to the sole element of a
PCollection. - PAssert.IterableAssert<T> - Interface in org.apache.beam.sdk.testing
-
Builder interface for assertions applicable to iterables and PCollection contents.
- PAssert.MatcherCheckerFn<T> - Class in org.apache.beam.sdk.testing
-
Check that the passed-in matchers match the existing data.
- PAssert.OneSideInputAssert<ActualT> - Class in org.apache.beam.sdk.testing
-
An assertion checker that takes a single
PCollectionView<ActualT>and an assertion overActualT, and checks it within a Beam pipeline. - PAssert.PAssertionSite - Class in org.apache.beam.sdk.testing
-
Track the place where an assertion is defined.
- PAssert.PCollectionContentsAssert<T> - Class in org.apache.beam.sdk.testing
-
An
PAssert.IterableAssertabout the contents of aPCollection. - PAssert.PCollectionListContentsAssert<T> - Class in org.apache.beam.sdk.testing
-
An assert about the contents of each
PCollectionin the givenPCollectionList. - PAssert.SingletonAssert<T> - Interface in org.apache.beam.sdk.testing
-
Builder interface for assertions applicable to a single value.
- PassThroughLogicalType<T> - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A base class for LogicalTypes that use the same Java type as the underlying base type.
- PassThroughLogicalType(String, Schema.FieldType, Object, Schema.FieldType) - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
- pastEndOfWindow() - Static method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark
-
Creates a trigger that fires when the watermark passes the end of the window.
- pastFirstElementInPane() - Static method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
-
Creates a trigger that fires when the current processing time passes the processing time at which this trigger saw the first element in a pane.
- path() - Method in class org.apache.beam.sdk.schemas.transforms.Cast.CompatibilityError
- path() - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
-
Field path from a root of a schema.
- payloadForParDoLike(ParDoTranslation.ParDoLike, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- payloadForWriteFilesLike(WriteFilesTranslation.WriteFilesLike, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.WriteFilesTranslation
- PayloadSerializer - Interface in org.apache.beam.sdk.schemas.io.payloads
- PayloadSerializerProvider - Interface in org.apache.beam.sdk.schemas.io.payloads
- PayloadSerializers - Class in org.apache.beam.sdk.schemas.io.payloads
- PBegin - Class in org.apache.beam.sdk.values
- PBegin(Pipeline) - Constructor for class org.apache.beam.sdk.values.PBegin
- pCollection(String, RunnerApi.PCollection) - Static method in interface org.apache.beam.sdk.util.construction.graph.PipelineNode
- PCollection<T> - Class in org.apache.beam.sdk.values
-
A
PCollection<T>is an immutable collection of values of typeT. - PCollection.IsBounded - Enum in org.apache.beam.sdk.values
-
The enumeration of cases for whether a
PCollectionis bounded. - PCollectionContentsAssert(PCollection<T>, PAssert.AssertionWindows, SimpleFunction<Iterable<ValueInSingleWindow<T>>, Iterable<T>>, PAssert.PAssertionSite) - Constructor for class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
- PCollectionContentsAssert(PCollection<T>, PAssert.PAssertionSite) - Constructor for class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
- PCollectionList<T> - Class in org.apache.beam.sdk.values
-
A
PCollectionList<T>is an immutable list of homogeneously typedPCollection<T>s. - PCollectionListContentsAssert(PCollectionList<T>) - Constructor for class org.apache.beam.sdk.testing.PAssert.PCollectionListContentsAssert
- PCollectionNode() - Constructor for class org.apache.beam.sdk.util.construction.graph.PipelineNode.PCollectionNode
- PCollectionRowTuple - Class in org.apache.beam.sdk.values
-
A
PCollectionRowTupleis an immutable tuple ofPCollection, "keyed" by a string tag.s
- pCollections() - Static method in class org.apache.beam.sdk.transforms.Flatten
-
Returns a
PTransformthat flattens aPCollectionListinto aPCollectioncontaining all the elements of all thePCollections in its input. - PCollectionTranslation - Class in org.apache.beam.sdk.util.construction
-
Utility methods for translating
PCollectionsto and from Runner API protos. - PCollectionTuple - Class in org.apache.beam.sdk.values
-
A
PCollectionTupleis an immutable tuple of heterogeneously-typedPCollections, "keyed" byTupleTags. - PCollectionView<T> - Interface in org.apache.beam.sdk.values
-
A
PCollectionView<T>is an immutable view of aPCollectionas a value of typeTthat can be accessed as a side input to aParDotransform. - PCollectionViews - Class in org.apache.beam.sdk.values
-
For internal use only; no backwards compatibility guarantees.
- PCollectionViews() - Constructor for class org.apache.beam.sdk.values.PCollectionViews
- PCollectionViews.HasDefaultValue<T> - Interface in org.apache.beam.sdk.values
- PCollectionViews.InMemoryListFromMultimapViewFn<T> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt a multimap materialization to an in-memory
List<T>. - PCollectionViews.InMemoryListViewFn<T> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt an iterable materialization to an in-memory
List<T>. - PCollectionViews.InMemoryMapFromVoidKeyViewFn<K,V> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt a multimap materialization to an in-memory
Map<K, V>. - PCollectionViews.InMemoryMapViewFn<K,V> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt an iterable materialization to an in-memory
Map<K, V>. - PCollectionViews.InMemoryMultimapFromVoidKeyViewFn<K,V> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt a multimap materialization to an in-memory
Map<K, Iterable<V>>. - PCollectionViews.InMemoryMultimapViewFn<K,V> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt an iterable materialization to an in-memory
Map<K, Iterable<V>>. - PCollectionViews.IsSingletonView<T> - Interface in org.apache.beam.sdk.values
- PCollectionViews.IterableBackedListViewFn<T> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt an iterable materialization to a
List<T>. - PCollectionViews.IterableViewFn<T> - Class in org.apache.beam.sdk.values
-
Deprecated.
- PCollectionViews.IterableViewFn2<T> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt an iterable materialization to a
Iterable<T>. - PCollectionViews.ListViewFn<T> - Class in org.apache.beam.sdk.values
-
Deprecated.
- PCollectionViews.ListViewFn2<T> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt a multimap materialization to a
List<T>. - PCollectionViews.MapViewFn<K,V> - Class in org.apache.beam.sdk.values
-
Deprecated.
- PCollectionViews.MapViewFn2<K,V> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt a multimap materialization to a
Map<K, V>. - PCollectionViews.MultimapViewFn<K,V> - Class in org.apache.beam.sdk.values
-
Deprecated.
- PCollectionViews.MultimapViewFn2<K,V> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt a multimap materialization to a
Map<K, Iterable<V>>. - PCollectionViews.SimplePCollectionView<ElemT,PrimitiveViewT,ViewT,W extends BoundedWindow> - Class in org.apache.beam.sdk.values
-
A class for
PCollectionViewimplementations, with additional type parameters that are not visible at pipeline assembly time when the view is used as a side input. - PCollectionViews.SingletonViewFn<T> - Class in org.apache.beam.sdk.values
-
Deprecated.
- PCollectionViews.SingletonViewFn2<T> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt an iterable materialization to a
T. - PCollectionViews.TypeDescriptorSupplier<T> - Interface in org.apache.beam.sdk.values
- PCollectionViews.ValueOrMetadata<T,MetaT> - Class in org.apache.beam.sdk.values
-
Stores values or metadata about values.
- PCollectionViews.ValueOrMetadataCoder<T,MetaT> - Class in org.apache.beam.sdk.values
-
A coder for
PCollectionViews.ValueOrMetadata. - PCollectionViewTranslation - Class in org.apache.beam.sdk.util.construction
-
Utilities for interacting with PCollection view protos.
- PCollectionViewTranslation() - Constructor for class org.apache.beam.sdk.util.construction.PCollectionViewTranslation
- PDone - Class in org.apache.beam.sdk.values
- peekOutputElements() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - peekOutputElements(TupleTag<T>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - peekOutputElementsInWindow(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - peekOutputElementsInWindow(TupleTag<OutputT>, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - peekOutputElementsWithTimestamp() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - perElement() - Static method in class org.apache.beam.sdk.transforms.Count
-
Returns a
PTransformthat counts the number of occurrences of each element in its inputPCollection. - PeriodicImpulse - Class in org.apache.beam.sdk.transforms
-
A
PTransformwhich produces a sequence of elements at fixed runtime intervals. - PeriodicSequence - Class in org.apache.beam.sdk.transforms
-
A
PTransformwhich generates a sequence of timestamped elements at given runtime intervals. - PeriodicSequence.OutputRangeTracker - Class in org.apache.beam.sdk.transforms
- PeriodicSequence.SequenceDefinition - Class in org.apache.beam.sdk.transforms
- perKey() - Static method in class org.apache.beam.sdk.transforms.Count
-
Returns a
PTransformthat counts the number of elements associated with each key of its inputPCollection. - perKey() - Static method in class org.apache.beam.sdk.transforms.Latest
-
Returns a
PTransformthat takes as input aPCollection<KV<K, V>>and returns aPCollection<KV<K, V>>whose contents is the latest element per-key according to its event time. - perKey() - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a
PTransformthat takes an inputPCollection<KV<K, T>>and returns aPCollection<KV<K, T>>that contains an output element mapping each distinct key in the inputPCollectionto the maximum according to the natural ordering ofTof the values associated with that key in the inputPCollection. - perKey() - Static method in class org.apache.beam.sdk.transforms.Mean
-
Returns a
PTransformthat takes an inputPCollection<KV<K, N>>and returns aPCollection<KV<K, Double>>that contains an output element mapping each distinct key in the inputPCollectionto the mean of the values associated with that key in the inputPCollection. - perKey() - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a
PTransformthat takes an inputPCollection<KV<K, T>>and returns aPCollection<KV<K, T>>that contains an output element mapping each distinct key in the inputPCollectionto the minimum according to the natural ordering ofTof the values associated with that key in the inputPCollection. - perKey(double) - Static method in class org.apache.beam.sdk.transforms.ApproximateUnique
-
Deprecated.Like
ApproximateUnique.perKey(int), but specifies the desired maximum estimation error instead of the sample size. - perKey(int) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles
-
Like
ApproximateQuantiles.perKey(int, Comparator), but sorts values using their natural ordering. - perKey(int) - Static method in class org.apache.beam.sdk.transforms.ApproximateUnique
-
Deprecated.Returns a
PTransformthat takes aPCollection<KV<K, V>>and returns aPCollection<KV<K, Long>>that contains an output element mapping each distinct key in the inputPCollectionto an estimate of the number of distinct values associated with that key in the inputPCollection. - perKey(int, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles
-
Returns a
PTransformthat takes aPCollection<KV<K, V>>and returns aPCollection<KV<K, List<V>>>that contains an output element mapping each distinct key in the inputPCollectionto aListof the approximateN-tiles of the values associated with that key in the inputPCollection. - perKey(int, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a
PTransformthat takes an inputPCollection<KV<K, V>>and returns aPCollection<KV<K, List<V>>>that contains an output element mapping each distinct key in the inputPCollectionto the largestcountvalues associated with that key in the inputPCollection<KV<K, V>>, in decreasing order, sorted using the givenComparator<V>. - perKey(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a
PTransformthat takes an inputPCollection<KV<K, T>>and returns aPCollection<KV<K, T>>that contains one output element per key mapping each to the maximum of the values associated with that key in the inputPCollection. - perKey(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a
PTransformthat takes an inputPCollection<KV<K, T>>and returns aPCollection<KV<K, T>>that contains one output element per key mapping each to the minimum of the values associated with that key in the inputPCollection. - perKey(CombineFnBase.GlobalCombineFn<? super InputT, ?, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.PerKeyPTransformthat first groups its inputPCollectionofKVs by keys and windows, then invokes the given function on each of the values lists to produce a combined value, and then returns aPCollectionofKVs mapping each distinct key to its combined value for each window. - perKey(SerializableBiFunction<V, V, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.PerKeyPTransformthat first groups its inputPCollectionofKVs by keys and windows, then invokes the given function on each of the values lists to produce a combined value, and then returns aPCollectionofKVs mapping each distinct key to its combined value for each window. - perKey(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.PerKeyPTransformthat first groups its inputPCollectionofKVs by keys and windows, then invokes the given function on each of the values lists to produce a combined value, and then returns aPCollectionofKVs mapping each distinct key to its combined value for each window. - PerKey(double) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.PerKey
-
Deprecated.
- PerKey(int) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.PerKey
-
Deprecated.
- PInput - Interface in org.apache.beam.sdk.values
-
The interface for things that might be input to a
PTransform. - Pipeline - Class in org.apache.beam.sdk
-
A
Pipelinemanages a directed acyclic graph ofPTransforms, and thePCollectionsthat thePTransformsconsume and produce. - Pipeline(PipelineOptions) - Constructor for class org.apache.beam.sdk.Pipeline
- PIPELINE_OPTIONS_URN_PREFIX - Static variable in class org.apache.beam.sdk.util.construction.PipelineOptionsTranslation
- PIPELINE_OPTIONS_URN_SUFFIX - Static variable in class org.apache.beam.sdk.util.construction.PipelineOptionsTranslation
- Pipeline.PipelineExecutionException - Exception in org.apache.beam.sdk
- Pipeline.PipelineVisitor - Interface in org.apache.beam.sdk
-
For internal use only; no backwards-compatibility guarantees.
- Pipeline.PipelineVisitor.CompositeBehavior - Enum in org.apache.beam.sdk
-
Control enum for indicating whether or not a traversal should process the contents of a composite transform or not.
- Pipeline.PipelineVisitor.Defaults - Class in org.apache.beam.sdk
-
Default no-op
Pipeline.PipelineVisitorthat enters all composite transforms. - PipelineDotRenderer - Class in org.apache.beam.sdk.util.construction.renderer
-
A DOT renderer for BEAM
PipelineDAG. - PipelineExecutionException(Throwable) - Constructor for exception org.apache.beam.sdk.Pipeline.PipelineExecutionException
-
Wraps
causeinto aPipeline.PipelineExecutionException. - PipelineNode - Interface in org.apache.beam.sdk.util.construction.graph
-
A graph node which contains some pipeline element.
- PipelineNode.PCollectionNode - Class in org.apache.beam.sdk.util.construction.graph
-
A
PipelineNodewhich contains aRunnerApi.PCollection. - PipelineNode.PTransformNode - Class in org.apache.beam.sdk.util.construction.graph
-
A
PipelineNodewhich contains aRunnerApi.PTransform. - pipelineOptions() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provide
PipelineOptions. - pipelineOptions() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- pipelineOptions() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- pipelineOptions() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- PipelineOptions - Interface in org.apache.beam.sdk.options
-
PipelineOptions are used to configure Pipelines.
- PipelineOptions.AtomicLongFactory - Class in org.apache.beam.sdk.options
-
DefaultValueFactorywhich supplies an ID that is guaranteed to be unique within the given process. - PipelineOptions.CheckEnabled - Enum in org.apache.beam.sdk.options
-
Enumeration of the possible states for a given check.
- PipelineOptions.DirectRunner - Class in org.apache.beam.sdk.options
-
A
DefaultValueFactorythat obtains the class of theDirectRunnerif it exists on the classpath, and throws an exception otherwise. - PipelineOptions.JobNameFactory - Class in org.apache.beam.sdk.options
-
Returns a normalized job name constructed from
ApplicationNameOptions.getAppName(), the local system user name (if available), the current time, and a random integer. - PipelineOptions.UserAgentFactory - Class in org.apache.beam.sdk.options
-
Returns a user agent string constructed from
ReleaseInfo.getName()andReleaseInfo.getVersion(), in the format[name]/[version]. - PipelineOptionsFactory - Class in org.apache.beam.sdk.options
-
Constructs a
PipelineOptionsor any derived interface that is composable to any other derived interface ofPipelineOptionsvia thePipelineOptions.as(java.lang.Class<T>)method. - PipelineOptionsFactory() - Constructor for class org.apache.beam.sdk.options.PipelineOptionsFactory
- PipelineOptionsFactory.Builder - Class in org.apache.beam.sdk.options
-
A fluent
PipelineOptionsbuilder. - PipelineOptionsRegistrar - Interface in org.apache.beam.sdk.options
-
PipelineOptionscreators have the ability to automatically have theirPipelineOptionsregistered with this SDK by creating aServiceLoaderentry and a concrete implementation of this interface. - PipelineOptionsTranslation - Class in org.apache.beam.sdk.util.construction
-
Utilities for going to/from Runner API pipeline options.
- PipelineOptionsTranslation() - Constructor for class org.apache.beam.sdk.util.construction.PipelineOptionsTranslation
- PipelineOptionsValidator - Class in org.apache.beam.sdk.options
-
Validates that the
PipelineOptionsconforms to all theValidationcriteria. - PipelineOptionsValidator() - Constructor for class org.apache.beam.sdk.options.PipelineOptionsValidator
- PipelineResources - Class in org.apache.beam.sdk.util.construction.resources
-
Utilities for working with classpath resources for pipelines.
- PipelineResources() - Constructor for class org.apache.beam.sdk.util.construction.resources.PipelineResources
- PipelineResourcesDetector - Interface in org.apache.beam.sdk.util.construction.resources
-
Interface for an algorithm detecting classpath resources for pipelines.
- PipelineResourcesDetector.Factory - Interface in org.apache.beam.sdk.util.construction.resources
-
Provides pipeline resources detection algorithm.
- PipelineResourcesDetectorFactory() - Constructor for class org.apache.beam.sdk.util.construction.resources.PipelineResourcesOptions.PipelineResourcesDetectorFactory
- PipelineResourcesOptions - Interface in org.apache.beam.sdk.util.construction.resources
-
Pipeline options dedicated to detecting classpath resources.
- PipelineResourcesOptions.ClasspathScanningResourcesDetectorFactory - Class in org.apache.beam.sdk.util.construction.resources
-
Constructs the default
PipelineResourcesDetectorinstance. - PipelineResourcesOptions.PipelineResourcesDetectorFactory - Class in org.apache.beam.sdk.util.construction.resources
-
Creates
PipelineResourcesDetectorinstance based on provided pipeline options or default values set for them. - PipelineResult - Interface in org.apache.beam.sdk
-
Result of
Pipeline.run(). - PipelineResult.State - Enum in org.apache.beam.sdk
-
Possible job states, for both completed and ongoing jobs.
- PipelineRunner<ResultT extends PipelineResult> - Class in org.apache.beam.sdk
-
A
PipelineRunnerruns aPipeline. - PipelineRunner() - Constructor for class org.apache.beam.sdk.PipelineRunner
- PipelineRunnerRegistrar - Interface in org.apache.beam.sdk.runners
-
For internal use only; no backwards-compatibility guarantees.
- PipelineTranslation - Class in org.apache.beam.sdk.util.construction
-
Utilities for going to/from Runner API pipelines.
- PipelineTranslation() - Constructor for class org.apache.beam.sdk.util.construction.PipelineTranslation
- PipelineValidator - Class in org.apache.beam.sdk.util.construction.graph
-
Validates well-formedness of a pipeline.
- PipelineValidator() - Constructor for class org.apache.beam.sdk.util.construction.graph.PipelineValidator
- plusDelayOf(Duration) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
-
Adds some delay to the original target time.
- poisonInstructionId(String) - Method in class org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer
-
Poisons an instruction id.
- POJOUtils - Class in org.apache.beam.sdk.schemas.utils
-
A set of utilities to generate getter and setter classes for POJOs.
- POJOUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.POJOUtils
- PollFn() - Constructor for class org.apache.beam.sdk.transforms.Watch.Growth.PollFn
- popNode() - Method in class org.apache.beam.sdk.runners.TransformHierarchy
-
Pops the current node off the top of the stack, finishing it.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.BoundedReadFromUnboundedSource
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.CompressedSource
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
-
Populates the display data.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileBasedSink.FilenamePolicy
-
Populates the display data.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileBasedSink
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileBasedSource
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileIO.Match
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileIO.MatchAll
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileIO.MatchConfiguration
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileIO.ReadMatches
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.GenerateSequence
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.OffsetBasedSource
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.Read.Bounded
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.Read.Unbounded
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.Source
-
Register display data for the given transform or component.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.Read
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
-
Deprecated.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.ReadFiles
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.Write
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.WriteFiles
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.Globally
-
Deprecated.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.PerKey
-
Deprecated.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.Globally
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.GloballyAsSingletonView
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.PerKeyWithHotKeyFanout
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
- populateDisplayData(DisplayData.Builder) - Method in interface org.apache.beam.sdk.transforms.display.HasDisplayData
-
Register display data for the given transform or component.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.DoFn
-
Register display data for the given transform or component.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Filter
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.FlatMapElements.FlatMapWithFailures
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.GroupByKey
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.InferableFunction
-
Register display data for the given transform or component.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.MapElements.MapWithFailures
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.MapElements
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
-
Register display data for the given transform or component.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Partition
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.PTransform
-
Register display data for the given transform or component.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Top.TopCombineFn
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.Window.Assign
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.Window
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
Register display data for the given transform or component.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.util.construction.ForwardingPTransform
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource
- PortablePipelineOptions - Interface in org.apache.beam.sdk.options
-
Pipeline options common to all portable runners.
- POutput - Interface in org.apache.beam.sdk.values
-
The interface for things that might be output from a
PTransform. - Preconditions - Class in org.apache.beam.sdk.util
-
Beam-specific variants of
Preconditionsthat throws more appropriate exception classes while being static analysis friendly. - Preconditions() - Constructor for class org.apache.beam.sdk.util.Preconditions
- prefetch() - Method in class org.apache.beam.sdk.fn.stream.DataStreams.DataStreamDecoder
- prefetch() - Method in interface org.apache.beam.sdk.fn.stream.PrefetchableIterable
-
Ensures that the next iterator returned has been prefetched.
- prefetch() - Method in class org.apache.beam.sdk.fn.stream.PrefetchableIterables.Default
- prefetch() - Method in interface org.apache.beam.sdk.fn.stream.PrefetchableIterator
-
If not
PrefetchableIterator.isReady(), schedules the next expensive operation such that at some point in time in the futurePrefetchableIterator.isReady()will return true. - PrefetchableIterable<T> - Interface in org.apache.beam.sdk.fn.stream
-
An
Iterablethat returnsPrefetchableIterators. - PrefetchableIterables - Class in org.apache.beam.sdk.fn.stream
-
This class contains static utility functions that operate on or return objects of type
PrefetchableIterable. - PrefetchableIterables() - Constructor for class org.apache.beam.sdk.fn.stream.PrefetchableIterables
- PrefetchableIterables.Default<T> - Class in org.apache.beam.sdk.fn.stream
-
A default implementation that caches an iterator to be returned when
PrefetchableIterables.Default.prefetch()is invoked. - PrefetchableIterator<T> - Interface in org.apache.beam.sdk.fn.stream
-
Iteratorthat supports prefetching the next set of records. - PrefetchableIterators - Class in org.apache.beam.sdk.fn.stream
- PrefetchableIterators() - Constructor for class org.apache.beam.sdk.fn.stream.PrefetchableIterators
- PREFIX - Static variable in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TimerDeclaration
- PREFIX - Static variable in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TimerFamilyDeclaration
- prepareFilesForStaging(List<String>, String) - Static method in class org.apache.beam.sdk.util.construction.resources.PipelineResources
-
Goes through the list of files that need to be staged on runner.
- prepareFilesForStaging(FileStagingOptions) - Static method in class org.apache.beam.sdk.util.construction.resources.PipelineResources
-
Goes through the list of files that need to be staged on runner.
- prepareForProcessing() - Method in class org.apache.beam.sdk.transforms.DoFn
-
Deprecated.use
DoFn.SetuporDoFn.StartBundleinstead. This method will be removed in a future release. - prepareWrite(WritableByteChannel) - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
-
Called with the channel that a subclass will write its header, footer, and values to.
- PRIMITIVE_BOUNDED_READ_OVERRIDE - Static variable in class org.apache.beam.sdk.util.construction.SplittableParDo
-
A transform override for
Read.Boundedthat converts it to aSplittableParDo.PrimitiveBoundedRead. - PRIMITIVE_UNBOUNDED_READ_OVERRIDE - Static variable in class org.apache.beam.sdk.util.construction.SplittableParDo
-
A transform override for
Read.Unboundedthat converts it to aSplittableParDo.PrimitiveUnboundedRead. - PrimitiveBoundedRead(Read.Bounded<T>) - Constructor for class org.apache.beam.sdk.util.construction.SplittableParDo.PrimitiveBoundedRead
- PrimitiveCreate<T> - Class in org.apache.beam.sdk.util.construction
-
An implementation of
Createthat returns a primitivePCollection. - PrimitiveCreate.Factory<T> - Class in org.apache.beam.sdk.util.construction
-
A
PTransformOverrideFactorythat creates instances ofPrimitiveCreate. - PrimitiveUnboundedRead(Read.Unbounded<T>) - Constructor for class org.apache.beam.sdk.util.construction.SplittableParDo.PrimitiveUnboundedRead
- printHelp(PrintStream) - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
-
Outputs the set of registered options with the PipelineOptionsFactory with a description for each one if available to the output stream.
- printHelp(PrintStream, Class<? extends PipelineOptions>) - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
-
Outputs the set of options available to be set for the passed in
PipelineOptionsinterface. - process(byte[], DoFn.MultiOutputReceiver) - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformProvider.ErrorFn
- process(DoFn.ProcessContext, RestrictionTracker<Watch.GrowthState, KV<Watch.Growth.PollResult<OutputT>, TerminationStateT>>, ManualWatermarkEstimator<Instant>) - Method in class org.apache.beam.sdk.transforms.Watch.WatchGrowthFn
- process(DoFn.ProcessContext) - Method in class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform.SplitIntoRangesFn
- process(DoFn.ProcessContext, BoundedWindow, DoFn.OutputReceiver<OutputT>) - Method in class org.apache.beam.sdk.util.construction.SplittableParDoNaiveBounded.NaiveProcessFn
- process(DoFn.ProcessContext) - Method in class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform.AbstractReadFileRangesFn
- process(Row, DoFn.MultiOutputReceiver) - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformProvider.ErrorFn
- processBundle(InputT...) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - processBundle(Iterable<? extends InputT>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - processContext() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- processContext(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provide a
DoFn.ProcessContextto use with the givenDoFn. - processContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- processContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- ProcessContext() - Constructor for class org.apache.beam.sdk.transforms.DoFn.ProcessContext
- ProcessContinuation() - Constructor for class org.apache.beam.sdk.transforms.DoFn.ProcessContinuation
- processElement() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.ProcessElementmethod. - processElement(ErrorT, DoFn.OutputReceiver<ErrorT>) - Method in class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.PTransformErrorHandler.WriteErrorMetrics.CountErrors
- processElement(InputT) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - processElement(String, DoFn.MultiOutputReceiver) - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError
- processElement(DoFn.ProcessContext) - Method in class org.apache.beam.sdk.values.ValueWithRecordId.StripIdsDoFn
- processElement(DoFn.ProcessContext, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.View.ToListViewDoFn
- processElement(T, DoFn.OutputReceiver<KV<Integer, T>>) - Method in class org.apache.beam.sdk.transforms.Reshuffle.AssignShardFn
- ProcessElementMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
- ProcessFunction<InputT,OutputT> - Interface in org.apache.beam.sdk.transforms
-
A function that computes an output value of type
OutputTfrom an input value of typeInputTand isSerializable. - PROCESSING_TIME - org.apache.beam.sdk.state.TimeDomain
-
The
TimeDomain.PROCESSING_TIMEdomain corresponds to the current (system) time. - PROCESSING_TIME - org.apache.beam.sdk.testing.TestStream.EventType
- ProcessingTimeEvent() - Constructor for class org.apache.beam.sdk.testing.TestStream.ProcessingTimeEvent
- ProcessKeyedElements(DoFn<InputT, OutputT>, Coder<InputT>, Coder<RestrictionT>, Coder<WatermarkEstimatorStateT>, WindowingStrategy<InputT, ?>, List<PCollectionView<?>>, TupleTag<OutputT>, TupleTagList, Map<TupleTag<?>, Coder<?>>, Map<String, PCollectionView<?>>) - Constructor for class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElements
- processTimestampedElement(TimestampedValue<InputT>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - processWindowedElement(InputT, Instant, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - Progress() - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.Progress
- PROHIBIT - org.apache.beam.sdk.io.FileIO.ReadMatches.DirectoryTreatment
- ProjectionConsumer - Interface in org.apache.beam.sdk.schemas
-
A
ProjectionConsumeris aSchema-aware operation (such as aDoFnorPTransform) that has aFieldAccessDescriptordescribing which fields the operation accesses. - ProjectionProducer<T> - Interface in org.apache.beam.sdk.schemas
-
A factory for operations that execute a projection on a
Schema-awarePCollection. - ProjectionPushdownOptimizer - Class in org.apache.beam.sdk.util.construction.graph
- ProjectionPushdownOptimizer() - Constructor for class org.apache.beam.sdk.util.construction.graph.ProjectionPushdownOptimizer
- PROPERTY_BEAM_TEST_PIPELINE_OPTIONS - Static variable in class org.apache.beam.sdk.testing.TestPipeline
-
System property used to set
TestPipelineOptions. - propertyName() - Method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
-
Returns the property name associated with this provider.
- propertyName() - Method in class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
-
Returns the property name that corresponds to this provider.
- ProtoOverrides - Class in org.apache.beam.sdk.util.construction.graph
-
A way to apply a Proto-based
PTransformOverride. - ProtoOverrides() - Constructor for class org.apache.beam.sdk.util.construction.graph.ProtoOverrides
- ProtoOverrides.TransformReplacement - Interface in org.apache.beam.sdk.util.construction.graph
-
A Function that takes a transform and the existing components and returns the new composite PTransform and additional components.
- provider() - Method in class org.apache.beam.sdk.io.TFRecordSchemaTransformTranslation.TFRecordReadSchemaTransformTranslator
- provider() - Method in class org.apache.beam.sdk.io.TFRecordSchemaTransformTranslation.TFRecordWriteSchemaTransformTranslator
- provider() - Method in class org.apache.beam.sdk.schemas.transforms.SchemaTransformTranslation.SchemaTransformPayloadTranslator
- Providers - Class in org.apache.beam.sdk.schemas.io
-
Helpers for implementing the "Provider" pattern.
- Providers.Identifyable - Interface in org.apache.beam.sdk.schemas.io
- pruningClass(Class<?>) - Method in class org.apache.beam.sdk.util.ApiSurface
-
Returns an
ApiSurfacelike this one, but pruning references from the provided class. - pruningClassName(String) - Method in class org.apache.beam.sdk.util.ApiSurface
-
Returns an
ApiSurfacelike this one, but pruning references from the named class. - pruningPattern(String) - Method in class org.apache.beam.sdk.util.ApiSurface
- pruningPattern(Pattern) - Method in class org.apache.beam.sdk.util.ApiSurface
-
Returns an
ApiSurfacelike this one, but pruning transitive references from classes whose full name (including package) begins with the provided prefix. - pruningPrefix(String) - Method in class org.apache.beam.sdk.util.ApiSurface
-
Returns an
ApiSurfacelike this one, but pruning transitive references from classes whose full name (including package) begins with the provided prefix. - pTransform(String, RunnerApi.PTransform) - Static method in interface org.apache.beam.sdk.util.construction.graph.PipelineNode
- PTransform<InputT extends PInput,OutputT extends POutput> - Class in org.apache.beam.sdk.transforms
- PTransform() - Constructor for class org.apache.beam.sdk.transforms.PTransform
- PTransform(String) - Constructor for class org.apache.beam.sdk.transforms.PTransform
- PTransformErrorHandler(PTransform<PCollection<ErrorT>, OutputT>, Pipeline, Coder<ErrorT>) - Constructor for class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.PTransformErrorHandler
-
Constructs a new ErrorHandler, but should not be called directly.
- PTransformMatcher - Interface in org.apache.beam.sdk.runners
-
For internal use only; no backwards-compatibility guarantees.
- PTransformMatchers - Class in org.apache.beam.sdk.util.construction
-
A
PTransformMatcherthat matchesPTransformsbased on the class of the transform. - PTransformNode() - Constructor for class org.apache.beam.sdk.util.construction.graph.PipelineNode.PTransformNode
- PTransformOverride - Class in org.apache.beam.sdk.runners
-
For internal use only; no backwards-compatibility guarantees.
- PTransformOverride() - Constructor for class org.apache.beam.sdk.runners.PTransformOverride
- PTransformOverrideFactory<InputT extends PInput,OutputT extends POutput,TransformT extends PTransform<? super InputT,OutputT>> - Interface in org.apache.beam.sdk.runners
-
For internal use only; no backwards-compatibility guarantees.
- PTransformOverrideFactory.PTransformReplacement<InputT extends PInput,OutputT extends POutput> - Class in org.apache.beam.sdk.runners
-
A
PTransformthat replaces anAppliedPTransform, and the input required to do so. - PTransformOverrideFactory.ReplacementOutput - Class in org.apache.beam.sdk.runners
-
A mapping between original
TaggedPValueoutputs and their replacements. - PTransformReplacement() - Constructor for class org.apache.beam.sdk.runners.PTransformOverrideFactory.PTransformReplacement
- PTransformReplacements - Class in org.apache.beam.sdk.util.construction
- PTransformReplacements() - Constructor for class org.apache.beam.sdk.util.construction.PTransformReplacements
- PTransformTranslation - Class in org.apache.beam.sdk.util.construction
-
Utilities for converting
PTransformstoRunner API protocol buffers. - PTransformTranslation.RawPTransform<InputT extends PInput,OutputT extends POutput> - Class in org.apache.beam.sdk.util.construction
-
A
PTransformthat indicates its URN and payload directly. - PTransformTranslation.TransformPayloadTranslator<T extends PTransform<?,?>> - Interface in org.apache.beam.sdk.util.construction
-
A translator between a Java-based
PTransformand a protobuf payload for that transform. - PTransformTranslation.TransformPayloadTranslator.NotSerializable<T extends PTransform<?,?>> - Class in org.apache.beam.sdk.util.construction
-
A
PTransformTranslation.TransformPayloadTranslatorfor transforms that contain no references to components, so they do not need a specialized rehydration. - PTransformTranslation.TransformTranslator<T extends PTransform<?,?>> - Interface in org.apache.beam.sdk.util.construction
-
A translator between a Java-based
PTransformand a protobuf for that transform. - PUBSUB_READ - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- PUBSUB_WRITE - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- PUBSUB_WRITE_DYNAMIC - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- pushNode(String, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.runners.TransformHierarchy
-
Adds the named
PTransformconsuming the providedPInputas a node in thisTransformHierarchyas a child of the current node, and sets it to be the current node. - put(K2, V2) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- put(K, V) - Method in interface org.apache.beam.sdk.state.MapState
-
Associates the specified value with the specified key in this state.
- put(K, V) - Method in interface org.apache.beam.sdk.state.MultimapState
-
Associates the specified value with the specified key in this multimap.
- put(T) - Method in class org.apache.beam.sdk.fn.CancellableQueue
-
Adds an element to this queue.
- putAll(Map<? extends K2, ? extends V2>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- putIfAbsent(K, V) - Method in interface org.apache.beam.sdk.state.MapState
-
A deferred read-followed-by-write.
- PValue - Interface in org.apache.beam.sdk.values
-
For internal use.
- PValueBase - Class in org.apache.beam.sdk.values
-
For internal use.
- PValueBase() - Constructor for class org.apache.beam.sdk.values.PValueBase
-
No-arg constructor to allow subclasses to implement
Serializable. - PValueBase(Pipeline) - Constructor for class org.apache.beam.sdk.values.PValueBase
- PValues - Class in org.apache.beam.sdk.values
-
For internal use.
- PythonCallable - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A logical type for PythonCallableSource objects.
- PythonCallable() - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.PythonCallable
- PythonCallableSource - Class in org.apache.beam.sdk.util
-
A wrapper object storing a Python function definition that can be evaluated to Python callables in Python SDK.
Q
- qualifiedComponent() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- qualifiedComponent() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifyComponentContext
- QualifiedComponentContext(ParserRuleContext, int) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
- Qualifier() - Constructor for class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
- qualifierList() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierListContext
- qualifierList() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierListContext
- qualifierList() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
- qualifierList() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- qualifierList(int) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierListContext
- qualifierList(int) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierListContext
- QualifierListContext() - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifierListContext
- QualifierListContext(ParserRuleContext, int) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifierListContext
- QualifyComponentContext(FieldSpecifierNotationParser.DotExpressionComponentContext) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifyComponentContext
- query(MetricResults, Lineage.Type) - Static method in class org.apache.beam.sdk.metrics.Lineage
-
Query
BoundedTriemetrics fromMetricResults. - query(MetricResults, Lineage.Type, String) - Static method in class org.apache.beam.sdk.metrics.Lineage
-
Query
BoundedTriemetrics fromMetricResults. - QueryablePipeline - Class in org.apache.beam.sdk.util.construction.graph
-
A
RunnerApi.Pipelinewhich has additional methods to relate nodes in the graph relative to each other. - queryMetrics(MetricsFilter) - Method in class org.apache.beam.sdk.metrics.MetricResults
-
Query for all metric values that match a given filter.
R
- range - Variable in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
- RangeTracker<PositionT> - Interface in org.apache.beam.sdk.io.range
-
A
RangeTrackeris a thread-safe helper object for implementing dynamic work rebalancing in position-basedBoundedSource.BoundedReadersubclasses. - Rate() - Constructor for class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate
- RawPTransform() - Constructor for class org.apache.beam.sdk.util.construction.PTransformTranslation.RawPTransform
- RawUnionValue - Class in org.apache.beam.sdk.transforms.join
-
This corresponds to an integer union tag and value.
- RawUnionValue(int, Object) - Constructor for class org.apache.beam.sdk.transforms.join.RawUnionValue
-
Constructs a partial union from the given union tag and value.
- reachableNodes(Network<NodeT, EdgeT>, Set<NodeT>, Set<NodeT>) - Static method in class org.apache.beam.sdk.util.construction.graph.Networks
-
Returns the set of nodes that are reachable from
startNodesup to and includingendNodes. - read() - Static method in class org.apache.beam.sdk.io.TextIO
-
A
PTransformthat reads from one or more text files and returns a boundedPCollectioncontaining one element for each line of the input files. - read() - Static method in class org.apache.beam.sdk.io.TFRecordIO
-
A
PTransformthat reads from a TFRecord file (or multiple TFRecord files matching a pattern) and returns aPCollectioncontaining the decoding of each of the records of the TFRecord file(s) as a byte array. - read() - Method in interface org.apache.beam.sdk.state.BagState
- read() - Method in interface org.apache.beam.sdk.state.CombiningState
- read() - Method in interface org.apache.beam.sdk.state.ReadableState
-
Read the current value, blocking until it is available.
- read() - Method in interface org.apache.beam.sdk.state.ValueState
-
Read the current value, blocking until it is available.
- read(T) - Method in interface org.apache.beam.sdk.fn.stream.DataStreams.OutputChunkConsumer
- Read - Class in org.apache.beam.sdk.io
-
A
PTransformfor reading from aSource. - Read() - Constructor for class org.apache.beam.sdk.io.Read
- Read() - Constructor for class org.apache.beam.sdk.io.TextIO.Read
- Read() - Constructor for class org.apache.beam.sdk.io.TFRecordIO.Read
- READ_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
-
Deprecated.SDKs should move away from creating `Read` transforms and migrate to using Impulse + SplittableDoFns.
- Read.Bounded<T> - Class in org.apache.beam.sdk.io
-
PTransformthat reads from aBoundedSource. - Read.Builder - Class in org.apache.beam.sdk.io
-
Helper class for building
Readtransforms. - Read.Unbounded<T> - Class in org.apache.beam.sdk.io
-
PTransformthat reads from aUnboundedSource. - ReadableFileCoder - Class in org.apache.beam.sdk.io
-
A
CoderforFileIO.ReadableFile. - ReadableState<T> - Interface in org.apache.beam.sdk.state
-
A
Statethat can be read viaReadableState.read(). - ReadableStates - Class in org.apache.beam.sdk.state
-
For internal use only; no backwards-compatibility guarantees.
- ReadableStates() - Constructor for class org.apache.beam.sdk.state.ReadableStates
- readAll() - Static method in class org.apache.beam.sdk.io.TextIO
-
Deprecated.You can achieve The functionality of
TextIO.readAll()usingFileIOmatching plusTextIO.readFiles(). This is the preferred method to make composition explicit.TextIO.ReadAllwill not receive upgrades and will be removed in a future version of Beam. - readAll() - Method in class org.apache.beam.sdk.util.ExposedByteArrayInputStream
-
Read all remaining bytes.
- ReadAll() - Constructor for class org.apache.beam.sdk.io.TextIO.ReadAll
-
Deprecated.
- ReadAllViaFileBasedSource<T> - Class in org.apache.beam.sdk.io
-
Reads each file in the input
PCollectionofFileIO.ReadableFileusing given parameters for splitting files into offset ranges and for creating aFileBasedSourcefor a file. - ReadAllViaFileBasedSource(long, SerializableFunction<String, ? extends FileBasedSource<T>>, Coder<T>) - Constructor for class org.apache.beam.sdk.io.ReadAllViaFileBasedSource
- ReadAllViaFileBasedSource(long, SerializableFunction<String, ? extends FileBasedSource<T>>, Coder<T>, boolean, ReadAllViaFileBasedSource.ReadFileRangesFnExceptionHandler) - Constructor for class org.apache.beam.sdk.io.ReadAllViaFileBasedSource
- ReadAllViaFileBasedSource.ReadFileRangesFnExceptionHandler - Class in org.apache.beam.sdk.io
-
A class to handle errors which occur during file reads.
- ReadAllViaFileBasedSourceTransform<InT,T> - Class in org.apache.beam.sdk.io
- ReadAllViaFileBasedSourceTransform(long, SerializableFunction<String, ? extends FileBasedSource<InT>>, Coder<T>) - Constructor for class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform
- ReadAllViaFileBasedSourceTransform(long, SerializableFunction<String, ? extends FileBasedSource<InT>>, Coder<T>, boolean, ReadAllViaFileBasedSource.ReadFileRangesFnExceptionHandler) - Constructor for class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform
- ReadAllViaFileBasedSourceTransform.AbstractReadFileRangesFn<InT,T> - Class in org.apache.beam.sdk.io
- ReadAllViaFileBasedSourceTransform.SplitIntoRangesFn - Class in org.apache.beam.sdk.io
- ReadAllViaFileBasedSourceWithFilename<T> - Class in org.apache.beam.sdk.io
-
Reads each file of the input
PCollectionand outputs each element as the value of aKV, where the key is the filename from which that value came. - ReadAllViaFileBasedSourceWithFilename(long, SerializableFunction<String, ? extends FileBasedSource<T>>, Coder<KV<String, T>>) - Constructor for class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceWithFilename
- readDecompressed(ReadableByteChannel) - Method in enum org.apache.beam.sdk.io.Compression
- Reader() - Constructor for class org.apache.beam.sdk.io.Source.Reader
- ReadFileRangesFnExceptionHandler() - Constructor for class org.apache.beam.sdk.io.ReadAllViaFileBasedSource.ReadFileRangesFnExceptionHandler
- readFiles() - Static method in class org.apache.beam.sdk.io.TextIO
-
Like
TextIO.read(), but reads each file in aPCollectionofFileIO.ReadableFile, returned byFileIO.readMatches(). - readFiles() - Static method in class org.apache.beam.sdk.io.TFRecordIO
-
Like
TFRecordIO.read(), but reads each file in aPCollectionofFileIO.ReadableFile, returned byFileIO.readMatches(). - ReadFiles() - Constructor for class org.apache.beam.sdk.io.TextIO.ReadFiles
- ReadFiles() - Constructor for class org.apache.beam.sdk.io.TFRecordIO.ReadFiles
- readFilesWithRetries() - Method in class org.apache.beam.sdk.util.ExplicitShardedFile
-
Discovers all shards of this file.
- readFilesWithRetries() - Method in class org.apache.beam.sdk.util.FilePatternMatchingShardedFile
-
Discovers all shards of this file.
- readFilesWithRetries() - Method in class org.apache.beam.sdk.util.NumberedShardedFile
-
Discovers all shards of this file.
- readFilesWithRetries(Sleeper, BackOff) - Method in class org.apache.beam.sdk.util.ExplicitShardedFile
- readFilesWithRetries(Sleeper, BackOff) - Method in class org.apache.beam.sdk.util.FilePatternMatchingShardedFile
- readFilesWithRetries(Sleeper, BackOff) - Method in class org.apache.beam.sdk.util.NumberedShardedFile
- readFilesWithRetries(Sleeper, BackOff) - Method in interface org.apache.beam.sdk.util.ShardedFile
- readFromPort(BeamFnApi.RemoteGrpcPort, String) - Static method in class org.apache.beam.sdk.fn.data.RemoteGrpcPortRead
- readFromSource(BoundedSource<T>, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Reads all elements from the given
BoundedSource. - readFromSplitsOfSource(BoundedSource<T>, long, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
- readFromStartedReader(Source.Reader<T>) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Reads all elements from the given started
Source.Reader. - readFromUnstartedReader(Source.Reader<T>) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Reads all elements from the given unstarted
Source.Reader. - readFullyAsBytes() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
-
Returns the full contents of the file as bytes.
- readFullyAsUTF8String() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
-
Returns the full contents of the file as a
Stringdecoded as UTF-8. - readLater() - Method in interface org.apache.beam.sdk.state.BagState
- readLater() - Method in interface org.apache.beam.sdk.state.CombiningState
- readLater() - Method in interface org.apache.beam.sdk.state.GroupingState
- readLater() - Method in interface org.apache.beam.sdk.state.ReadableState
-
Indicate that the value will be read later.
- readLater() - Method in interface org.apache.beam.sdk.state.SetState
- readLater() - Method in interface org.apache.beam.sdk.state.ValueState
- readLater() - Method in interface org.apache.beam.sdk.state.WatermarkHoldState
- readMatches() - Static method in class org.apache.beam.sdk.io.FileIO
-
Converts each result of
FileIO.match()orFileIO.matchAll()to aFileIO.ReadableFilewhich can be used to read the contents of each file, optionally decompressing it. - ReadMatches() - Constructor for class org.apache.beam.sdk.io.FileIO.ReadMatches
- readNextBlock() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
-
Read the next block from the input.
- readNextRecord() - Method in class org.apache.beam.sdk.io.BlockBasedSource.Block
-
Reads the next record from the block and returns true iff one exists.
- readNextRecord() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
-
Reads the next record from the
current blockif possible. - readNextRecord() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
-
Reads the next record via the delegate reader.
- readNextRecord() - Method in class org.apache.beam.sdk.io.FileBasedSource.FileBasedReader
-
Reads the next record from the channel provided by
FileBasedSource.FileBasedReader.startReading(java.nio.channels.ReadableByteChannel). - readNItemsFromStartedReader(Source.Reader<T>, int) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Read elements from a
Source.Readerthat has already hadSource.Reader.start()called on it, until n elements are read. - readNItemsFromUnstartedReader(Source.Reader<T>, int) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Read elements from a
Source.Readeruntil n elements are read. - readRange(Instant, Instant) - Method in interface org.apache.beam.sdk.state.OrderedListState
-
Read a timestamp-limited subrange of the list.
- readRangeLater(Instant, Instant) - Method in interface org.apache.beam.sdk.state.OrderedListState
-
Call to indicate that a specific range will be read from the list, allowing runners to batch multiple range reads.
- readRangesFn() - Method in class org.apache.beam.sdk.io.ReadAllViaFileBasedSource
- readRangesFn() - Method in class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform
- readRangesFn() - Method in class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceWithFilename
- readRemainingFromReader(Source.Reader<T>, boolean) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Read all remaining elements from a
Source.Reader. - ReadTranslation - Class in org.apache.beam.sdk.util.construction
-
Methods for translating
SplittableParDo.PrimitiveBoundedReadandSplittableParDo.PrimitiveUnboundedReadPTransformTranslationintoRunnerApi.ReadPayloadprotos. - ReadTranslation() - Constructor for class org.apache.beam.sdk.util.construction.ReadTranslation
- ReadTranslation.BoundedReadPayloadTranslator - Class in org.apache.beam.sdk.util.construction
- ReadTranslation.Registrar - Class in org.apache.beam.sdk.util.construction
- ReadTranslation.UnboundedReadPayloadTranslator - Class in org.apache.beam.sdk.util.construction
- readValue - Variable in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
- readValue - Variable in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
- ReadWriteRegistrar() - Constructor for class org.apache.beam.sdk.io.TFRecordSchemaTransformTranslation.ReadWriteRegistrar
- record(double) - Method in class org.apache.beam.sdk.util.HistogramData
- record(double...) - Method in class org.apache.beam.sdk.util.HistogramData
- Record() - Constructor for class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record
- RECORDING_ROUTER - Static variable in interface org.apache.beam.sdk.transforms.errorhandling.BadRecordRouter
- RecordingBadRecordRouter() - Constructor for class org.apache.beam.sdk.transforms.errorhandling.BadRecordRouter.RecordingBadRecordRouter
- Redistribute - Class in org.apache.beam.sdk.transforms
-
A family of
PTransformsthat returns aPCollectionequivalent to its input but functions as an operational hint to a runner that redistributing the data in some way is likely useful. - Redistribute() - Constructor for class org.apache.beam.sdk.transforms.Redistribute
- REDISTRIBUTE_ARBITRARILY_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- REDISTRIBUTE_BY_KEY_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- Redistribute.RedistributeArbitrarily<T> - Class in org.apache.beam.sdk.transforms
-
Noop transform that hints to the runner to try to redistribute the work evenly, or via whatever clever strategy the runner comes up with.
- Redistribute.RedistributeByKey<K,V> - Class in org.apache.beam.sdk.transforms
- Redistribute.Registrar - Class in org.apache.beam.sdk.transforms
-
Registers translators for the Redistribute family of transforms.
- referencesSingleField() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Returns true if this descriptor references only a single, non-wildcard field.
- referent() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.StateParameter
- referent() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.TimerFamilyParameter
- referent() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.TimerParameter
- ReflectHelpers - Class in org.apache.beam.sdk.util.common
-
Utilities for working with with
ClassesandMethods. - ReflectHelpers() - Constructor for class org.apache.beam.sdk.util.common.ReflectHelpers
- ReflectHelpers.ObjectsClassComparator - Class in org.apache.beam.sdk.util.common
-
A
Comparatorthat uses the object's class' canonical name to compare them. - ReflectUtils - Class in org.apache.beam.sdk.schemas.utils
-
A set of reflection helper methods.
- ReflectUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.ReflectUtils
- ReflectUtils.ClassWithSchema - Class in org.apache.beam.sdk.schemas.utils
-
Represents a class and a schema.
- ReflectUtils.TypeDescriptorWithSchema<T> - Class in org.apache.beam.sdk.schemas.utils
-
Represents a type descriptor and a schema.
- Regex - Class in org.apache.beam.sdk.transforms
-
PTransforms to use Regular Expressions to process elements in aPCollection. - Regex.AllMatches - Class in org.apache.beam.sdk.transforms
-
Regex.MatchesName<String>takes aPCollection<String>and returns aPCollection<List<String>>representing the value extracted from all the Regex groups of the inputPCollectionto the number of times that element occurs in the input. - Regex.Find - Class in org.apache.beam.sdk.transforms
-
Regex.Find<String>takes aPCollection<String>and returns aPCollection<String>representing the value extracted from the Regex groups of the inputPCollectionto the number of times that element occurs in the input. - Regex.FindAll - Class in org.apache.beam.sdk.transforms
-
Regex.Find<String>takes aPCollection<String>and returns aPCollection<List<String>>representing the value extracted from the Regex groups of the inputPCollectionto the number of times that element occurs in the input. - Regex.FindKV - Class in org.apache.beam.sdk.transforms
-
Regex.MatchesKV<KV<String, String>>takes aPCollection<String>and returns aPCollection<KV<String, String>>representing the key and value extracted from the Regex groups of the inputPCollectionto the number of times that element occurs in the input. - Regex.FindName - Class in org.apache.beam.sdk.transforms
-
Regex.Find<String>takes aPCollection<String>and returns aPCollection<String>representing the value extracted from the Regex groups of the inputPCollectionto the number of times that element occurs in the input. - Regex.FindNameKV - Class in org.apache.beam.sdk.transforms
-
Regex.MatchesKV<KV<String, String>>takes aPCollection<String>and returns aPCollection<KV<String, String>>representing the key and value extracted from the Regex groups of the inputPCollectionto the number of times that element occurs in the input. - Regex.Matches - Class in org.apache.beam.sdk.transforms
-
Regex.Matches<String>takes aPCollection<String>and returns aPCollection<String>representing the value extracted from the Regex groups of the inputPCollectionto the number of times that element occurs in the input. - Regex.MatchesKV - Class in org.apache.beam.sdk.transforms
-
Regex.MatchesKV<KV<String, String>>takes aPCollection<String>and returns aPCollection<KV<String, String>>representing the key and value extracted from the Regex groups of the inputPCollectionto the number of times that element occurs in the input. - Regex.MatchesName - Class in org.apache.beam.sdk.transforms
-
Regex.MatchesName<String>takes aPCollection<String>and returns aPCollection<String>representing the value extracted from the Regex groups of the inputPCollectionto the number of times that element occurs in the input. - Regex.MatchesNameKV - Class in org.apache.beam.sdk.transforms
-
Regex.MatchesNameKV<KV<String, String>>takes aPCollection<String>and returns aPCollection<KV<String, String>>representing the key and value extracted from the Regex groups of the inputPCollectionto the number of times that element occurs in the input. - Regex.ReplaceAll - Class in org.apache.beam.sdk.transforms
-
Regex.ReplaceAll<String>takes aPCollection<String>and returns aPCollection<String>with all Strings that matched the Regex being replaced with the replacement string. - Regex.ReplaceFirst - Class in org.apache.beam.sdk.transforms
-
Regex.ReplaceFirst<String>takes aPCollection<String>and returns aPCollection<String>with the first Strings that matched the Regex being replaced with the replacement string. - Regex.Split - Class in org.apache.beam.sdk.transforms
-
Regex.Split<String>takes aPCollection<String>and returns aPCollection<String>with the input string split into individual items in a list. - RegexMatcher - Class in org.apache.beam.sdk.testing
-
Hamcrest matcher to assert a string matches a pattern.
- RegexMatcher(String) - Constructor for class org.apache.beam.sdk.testing.RegexMatcher
- register(Class<? extends PipelineOptions>) - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
-
This registers the interface with this factory.
- register(ArtifactResolver.ResolutionFn) - Method in interface org.apache.beam.sdk.util.construction.ArtifactResolver
-
Register
ArtifactResolver.ResolutionFn. - register(ArtifactResolver.ResolutionFn) - Method in class org.apache.beam.sdk.util.construction.DefaultArtifactResolver
- registerBadRecordErrorHandler(PTransform<PCollection<BadRecord>, OutputT>) - Method in class org.apache.beam.sdk.Pipeline
- registerByteSizeObserver(T, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.NullableCoder
-
Overridden to short-circuit the default
StructuredCoderbehavior of encoding and counting the bytes. - registerByteSizeObserver(IterableT, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
- registerByteSizeObserver(Map<K, V>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.MapCoder
- registerByteSizeObserver(Optional<T>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.OptionalCoder
-
Overridden to short-circuit the default
StructuredCoderbehavior of encoding and counting the bytes. - registerByteSizeObserver(SortedMap<K, V>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.SortedMapCoder
- registerByteSizeObserver(RawUnionValue, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
-
Notifies ElementByteSizeObserver about the byte size of the encoded value using this coder.
- registerByteSizeObserver(IntervalWindow, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
- registerByteSizeObserver(Timer<K>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.util.construction.Timer.Coder
- registerByteSizeObserver(ShardedKey<K>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
- registerByteSizeObserver(KV<K, V>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.KvCoder
-
Notifies ElementByteSizeObserver about the byte size of the encoded value using this coder.
- registerByteSizeObserver(WindowedValue<T>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.values.WindowedValues.FullWindowedValueCoder
- registerByteSizeObserver(WindowedValue<T>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
- registerByteSizeObserver(WindowedValue<T>, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.values.WindowedValues.ValueOnlyWindowedValueCoder
-
Deprecated.
- registerByteSizeObserver(ReadableDuration, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.DurationCoder
- registerByteSizeObserver(T, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.Coder
-
Notifies the
ElementByteSizeObserverabout the byte size of the encoded value using thisCoder. - registerByteSizeObserver(T, ElementByteSizeObserver) - Method in class org.apache.beam.sdk.coders.TimestampPrefixingWindowCoder
- registerCoder(Coder<?>) - Method in class org.apache.beam.sdk.util.construction.SdkComponents
- registerCoderForClass(Class<?>, Coder<?>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
-
Registers the provided
Coderfor the given class. - registerCoderForType(TypeDescriptor<?>, Coder<?>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
-
Registers the provided
Coderfor the given type. - registerCoderOrThrow(SdkComponents, Coder) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- registerCoderProvider(CoderProvider) - Method in class org.apache.beam.sdk.coders.CoderRegistry
- registerConsumer(String, CloseableFnDataReceiver<BeamFnApi.Elements>) - Method in class org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer
-
Registers a consumer for the specified instruction id.
- registerEnvironment(RunnerApi.Environment) - Method in class org.apache.beam.sdk.util.construction.SdkComponents
-
Registers the provided
RunnerApi.Environmentinto thisSdkComponents, returning a unique ID for theRunnerApi.Environment. - registerFileSystemsOnce(PipelineOptions) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Register file systems once if never done before.
- registerJavaBean(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Register a JavaBean type for automatic schema inference.
- registerJavaBean(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Register a JavaBean type for automatic schema inference.
- registerOutputDataLocation(String, Coder<T>) - Method in class org.apache.beam.sdk.fn.data.BeamFnDataOutboundAggregator
-
Register the outbound data logical endpoint, returns the FnDataReceiver for processing the endpoint's outbound data.
- registerOutputTimersLocation(String, String, Coder<T>) - Method in class org.apache.beam.sdk.fn.data.BeamFnDataOutboundAggregator
-
Register the outbound timers logical endpoint, returns the FnDataReceiver for processing the endpoint's outbound timers data.
- registerPCollection(PCollection<?>) - Method in class org.apache.beam.sdk.util.construction.SdkComponents
-
Registers the provided
PCollectioninto thisSdkComponents, returning a unique ID for thePCollection. - registerPOJO(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Register a POJO type for automatic schema inference.
- registerPOJO(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Register a POJO type for automatic schema inference.
- registerPTransform(AppliedPTransform<?, ?, ?>, List<AppliedPTransform<?, ?, ?>>) - Method in class org.apache.beam.sdk.util.construction.SdkComponents
-
Registers the provided
AppliedPTransforminto thisSdkComponents, returning a unique ID for theAppliedPTransform. - registerSchemaForClass(Class<T>, Schema, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Register a schema for a specific
Classtype. - registerSchemaForType(TypeDescriptor<T>, Schema, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Register a schema for a specific
TypeDescriptortype. - registerSchemaProvider(Class<T>, SchemaProvider) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Register a
SchemaProviderto be used for a specific type. - registerSchemaProvider(SchemaProvider) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Register a
SchemaProvider. - registerSchemaProvider(TypeDescriptor<T>, SchemaProvider) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Register a
SchemaProviderto be used for a specific type. - registerWindowingStrategy(WindowingStrategy<?, ?>) - Method in class org.apache.beam.sdk.util.construction.SdkComponents
-
Registers the provided
WindowingStrategyinto thisSdkComponents, returning a unique ID for theWindowingStrategy. - Registrar() - Constructor for class org.apache.beam.sdk.transforms.Redistribute.Registrar
- Registrar() - Constructor for class org.apache.beam.sdk.util.construction.CombineTranslation.Registrar
- Registrar() - Constructor for class org.apache.beam.sdk.util.construction.CreatePCollectionViewTranslation.Registrar
-
Deprecated.
- Registrar() - Constructor for class org.apache.beam.sdk.util.construction.FlattenTranslator.Registrar
- Registrar() - Constructor for class org.apache.beam.sdk.util.construction.GroupByKeyTranslation.Registrar
- Registrar() - Constructor for class org.apache.beam.sdk.util.construction.GroupIntoBatchesTranslation.Registrar
- Registrar() - Constructor for class org.apache.beam.sdk.util.construction.ImpulseTranslation.Registrar
- Registrar() - Constructor for class org.apache.beam.sdk.util.construction.ReadTranslation.Registrar
- Registrar() - Constructor for class org.apache.beam.sdk.util.construction.ReshuffleTranslation.Registrar
- Registrar() - Constructor for class org.apache.beam.sdk.util.construction.SplittableParDo.Registrar
- Registrar() - Constructor for class org.apache.beam.sdk.util.construction.WindowIntoTranslation.Registrar
- Registrar() - Constructor for class org.apache.beam.sdk.util.construction.WriteFilesTranslation.Registrar
- RehydratedComponents - Class in org.apache.beam.sdk.util.construction
-
Vends Java SDK objects rehydrated from a Runner API
RunnerApi.Componentscollection. - Reify - Class in org.apache.beam.sdk.transforms
-
PTransformsfor converting between explicit and implicit form of various Beam values. - Reiterable<T> - Interface in org.apache.beam.sdk.util.common
-
An
Iterablethat returnsReiteratoriterators. - Reiterator<T> - Interface in org.apache.beam.sdk.util.common
-
An
Iteratorwith the ability to copy its iteration state. - relativeFileNaming(ValueProvider<String>, FileIO.Write.FileNaming) - Static method in class org.apache.beam.sdk.io.FileIO.Write
- ReleaseInfo - Class in org.apache.beam.sdk.util
-
Properties pertaining to this release of Apache Beam.
- ReleaseInfo() - Constructor for class org.apache.beam.sdk.util.ReleaseInfo
- remerge() - Static method in class org.apache.beam.sdk.transforms.windowing.Window
-
Creates a
WindowPTransformthat does not change assigned windows, but will cause windows to be merged again as part of the nextGroupByKey. - RemoteEnvironmentOptions - Interface in org.apache.beam.sdk.options
-
Options that are used to control configuration of the remote environment.
- RemoteEnvironmentOptions.Options - Class in org.apache.beam.sdk.options
-
Register the
RemoteEnvironmentOptions. - RemoteGrpcPortRead - Class in org.apache.beam.sdk.fn.data
-
An execution-time only
RunnerApi.PTransformwhich represents an SDK harness reading from aBeamFnApi.RemoteGrpcPort. - RemoteGrpcPortRead() - Constructor for class org.apache.beam.sdk.fn.data.RemoteGrpcPortRead
- RemoteGrpcPortWrite - Class in org.apache.beam.sdk.fn.data
-
An execution-time only
RunnerApi.PTransformwhich represents a write from within an SDK harness to aBeamFnApi.RemoteGrpcPort. - RemoteGrpcPortWrite() - Constructor for class org.apache.beam.sdk.fn.data.RemoteGrpcPortWrite
- remove() - Method in class org.apache.beam.sdk.fn.stream.DataStreams.DataStreamDecoder
- remove(long) - Method in class org.apache.beam.sdk.util.BucketingFunction
-
Remove one sample (from bucket) at
timeMsSinceEpoch. - remove(Object) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- remove(K) - Method in interface org.apache.beam.sdk.state.MapState
-
Remove the mapping for a key from this map if it is present.
- remove(K) - Method in interface org.apache.beam.sdk.state.MultimapState
-
Removes all values associated with the key from this multimap.
- remove(T) - Method in interface org.apache.beam.sdk.state.SetState
-
Removes the specified element from this set if it is present.
- removeTemporaryFiles(Collection<ResourceId>) - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
- rename(String, String) - Method in class org.apache.beam.sdk.schemas.transforms.RenameFields.Inner
-
Rename a specific field.
- rename(List<ClassLoaderFileSystem.ClassLoaderResourceId>, List<ClassLoaderFileSystem.ClassLoaderResourceId>, MoveOptions...) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem
- rename(List<ResourceId>, List<ResourceId>, MoveOptions...) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Renames a
Listof file-like resources from one location to another. - rename(List<ResourceIdT>, List<ResourceIdT>, MoveOptions...) - Method in class org.apache.beam.sdk.io.FileSystem
-
Renames a
Listof file-like resources from one location to another. - rename(FieldAccessDescriptor, String) - Method in class org.apache.beam.sdk.schemas.transforms.RenameFields.Inner
-
Rename a specific field.
- RenameFields - Class in org.apache.beam.sdk.schemas.transforms
-
A transform for renaming fields inside an existing schema.
- RenameFields() - Constructor for class org.apache.beam.sdk.schemas.transforms.RenameFields
- RenameFields.Inner<T> - Class in org.apache.beam.sdk.schemas.transforms
-
The class implementing the actual PTransform.
- Repeatedly - Class in org.apache.beam.sdk.transforms.windowing
-
A
Triggerthat fires according to its subtrigger forever. - replaceAll(String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.ReplaceAllPTransformthat checks if a portion of the line matches the Regex and replaces all matches with the replacement String. - replaceAll(List<PTransformOverride>) - Method in class org.apache.beam.sdk.Pipeline
-
For internal use only; no backwards-compatibility guarantees.
- replaceAll(Pattern, String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.ReplaceAllPTransformthat checks if a portion of the line matches the Regex and replaces all matches with the replacement String. - ReplaceAll(Pattern, String) - Constructor for class org.apache.beam.sdk.transforms.Regex.ReplaceAll
- replaceChild(TransformHierarchy.Node, TransformHierarchy.Node) - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
-
Replace a sub-node of this transform node.
- replaceDirectedNetworkNodes(MutableNetwork<NodeT, EdgeT>, Function<NodeT, NodeT>) - Static method in class org.apache.beam.sdk.util.construction.graph.Networks
-
Applies the
functionto all nodes within thenetwork. - replaceFirst(String, String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.ReplaceAllPTransformthat checks if a portion of the line matches the Regex and replaces the first match with the replacement String. - replaceFirst(Pattern, String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.ReplaceAllPTransformthat checks if a portion of the line matches the Regex and replaces the first match with the replacement String. - ReplaceFirst(Pattern, String) - Constructor for class org.apache.beam.sdk.transforms.Regex.ReplaceFirst
- ReplacementOutput() - Constructor for class org.apache.beam.sdk.runners.PTransformOverrideFactory.ReplacementOutput
- ReplacementOutputs - Class in org.apache.beam.sdk.util.construction
-
Utility methods for creating
PTransformOverrideFactory.ReplacementOutputfor known styles ofPOutput. - replaceNode(TransformHierarchy.Node, PInput, PTransform<?, ?>) - Method in class org.apache.beam.sdk.runners.TransformHierarchy
- replaceOutputs(Map<PCollection<?>, PTransformOverrideFactory.ReplacementOutput>) - Method in class org.apache.beam.sdk.runners.TransformHierarchy
-
Recursively replace the outputs of the current
TransformHierarchy.Nodewith the original outputs of the node it is replacing. - reportElementSize(long) - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
- reportElementSize(long) - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObserver
-
Called to report element byte size.
- reportLineage(ResourceIdT, Lineage) - Method in class org.apache.beam.sdk.io.FileSystem
-
Report
Lineagemetrics for resource id at file level. - reportLineage(ResourceIdT, Lineage, FileSystem.LineageLevel) - Method in class org.apache.beam.sdk.io.FileSystem
-
Report
Lineagemetrics for resource id to a given level. - reportSinkLineage(ResourceId) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Report sink
Lineagemetrics for resource id. - reportSinkLineage(ResourceId, FileSystem.LineageLevel) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Report source
Lineagemetrics for resource id at given level. - reportSourceLineage(ResourceId) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Report source
Lineagemetrics for resource id. - reportSourceLineage(ResourceId, FileSystem.LineageLevel) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Report source
Lineagemetrics for resource id at given level. - requestsFinalization() - Method in interface org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoLike
- REQUIRE_MISSING - org.apache.beam.sdk.util.RowJson.RowJsonDeserializer.NullBehavior
-
Specifies that a null value must be represented with a missing field in JSON.
- REQUIRE_NULL - org.apache.beam.sdk.util.RowJson.RowJsonDeserializer.NullBehavior
-
Specifies that a null value must be represented with a null value in JSON.
- requirements() - Method in class org.apache.beam.sdk.util.construction.SdkComponents
- Requirements - Class in org.apache.beam.sdk.transforms
-
Describes the run-time requirements of a
Contextful, such as access to side inputs. - REQUIRES_BUNDLE_FINALIZATION_URN - Static variable in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
This requirement indicates the requests_finalization field of ParDo transform payloads must be inspected.
- REQUIRES_ON_WINDOW_EXPIRATION_URN - Static variable in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
This requirement indicates that the ParDo requires a callback on each window expiration.
- REQUIRES_SPLITTABLE_DOFN_URN - Static variable in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
This requirement indicates the restriction_coder_id field of ParDo transform payloads must be inspected.
- REQUIRES_STABLE_INPUT_URN - Static variable in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
This requirement indicates the requires_stable_input field of ParDo transform payloads must be inspected.
- REQUIRES_STATEFUL_PROCESSING_URN - Static variable in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
This requirement indicates the state_spec and time_spec fields of ParDo transform payloads must be inspected.
- REQUIRES_TIME_SORTED_INPUT_URN - Static variable in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
This requirement indicates the requires_time_sorted_input field of ParDo transform payloads must be inspected.
- requiresDataSchema() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIOProvider
-
Indicates whether the dataSchema value is necessary.
- requiresDeduping() - Method in class org.apache.beam.sdk.io.UnboundedSource
-
Returns whether this source requires explicit deduping.
- requiresSideInputs(Collection<PCollectionView<?>>) - Static method in class org.apache.beam.sdk.transforms.Requirements
-
Describes the need for access to the given side inputs.
- requiresSideInputs(PCollectionView<?>...) - Static method in class org.apache.beam.sdk.transforms.Requirements
- requiresStableInput() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerFamilyMethod
-
Whether this method requires stable input, expressed via
DoFn.RequiresStableInput. - requiresStableInput() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerMethod
-
Whether this method requires stable input, expressed via
DoFn.RequiresStableInput. - requiresStableInput() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnWindowExpirationMethod
-
Whether this method requires stable input, expressed via
DoFn.RequiresStableInput. - requiresStableInput() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
-
Whether this method requires stable input, expressed via
DoFn.RequiresStableInput. - requiresStableInputParDoMulti() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
A
PTransformMatcherthat matches aParDo.MultiOutputcontaining aDoFnthat requires stable input, as signified byDoFnSignature.ProcessElementMethod.requiresStableInput(). - requiresStableInputParDoSingle() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
A
PTransformMatcherthat matches aParDo.SingleOutputcontaining aDoFnthat requires stable input, as signified byDoFnSignature.ProcessElementMethod.requiresStableInput(). - requiresTimeSortedInput() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
-
Whether this method requires time sorted input, expressed via
DoFn.RequiresTimeSortedInput. - requiresTimeSortedInput(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- reset() - Method in class org.apache.beam.sdk.fn.CancellableQueue
-
Enables the queue to be re-used after it has been cancelled.
- reset() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataInboundObserver
-
Enables this receiver to be used again for another bundle.
- reset() - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
- reset() - Method in interface org.apache.beam.sdk.util.BackOff
-
Reset to initial state.
- reset() - Method in class org.apache.beam.sdk.util.ByteStringOutputStream
- reset() - Method in class org.apache.beam.sdk.util.ExposedByteArrayOutputStream
- reset() - Method in class org.apache.beam.sdk.util.UnownedInputStream
- resetCache() - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
-
Resets the set of interfaces registered with this factory to the default state.
- Reshuffle<K,V> - Class in org.apache.beam.sdk.transforms
-
For internal use only; no backwards compatibility guarantees.
- RESHUFFLE_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- Reshuffle.AssignShardFn<T> - Class in org.apache.beam.sdk.transforms
- Reshuffle.ViaRandomKey<T> - Class in org.apache.beam.sdk.transforms
-
Implementation of
Reshuffle.viaRandomKey(). - ReshuffleTranslation - Class in org.apache.beam.sdk.util.construction
-
Utility methods for translating a
Reshuffleto and fromRunnerApirepresentations. - ReshuffleTranslation() - Constructor for class org.apache.beam.sdk.util.construction.ReshuffleTranslation
- ReshuffleTranslation.Registrar - Class in org.apache.beam.sdk.util.construction
-
Registers
ReshuffleTranslation.ReshuffleTranslator. - ReshuffleTrigger<W extends BoundedWindow> - Class in org.apache.beam.sdk.transforms.windowing
-
For internal use only; no backwards compatibility guarantees.
- ReshuffleTrigger() - Constructor for class org.apache.beam.sdk.transforms.windowing.ReshuffleTrigger
- resolve(String, ResolveOptions) - Method in class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderResourceId
- resolve(String, ResolveOptions) - Method in interface org.apache.beam.sdk.io.fs.ResourceId
-
Returns a child
ResourceIdunderthis. - resolve(RunnerApi.ArtifactInformation) - Method in interface org.apache.beam.sdk.util.construction.ArtifactResolver.ResolutionFn
- resolve(Schema) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Resolve the
FieldAccessDescriptoragainst a schema. - RESOLVE_DIRECTORY - org.apache.beam.sdk.io.fs.ResolveOptions.StandardResolveOptions
-
Resolve a directory.
- RESOLVE_FILE - org.apache.beam.sdk.io.fs.ResolveOptions.StandardResolveOptions
-
Resolve a file.
- resolveAnyOfEnvironment(RunnerApi.Environment, String...) - Static method in class org.apache.beam.sdk.util.construction.Environments
- resolveArtifacts(List<RunnerApi.ArtifactInformation>) - Method in interface org.apache.beam.sdk.util.construction.ArtifactResolver
-
Resolves a list of artifacts by applying registered
ArtifactResolver.ResolutionFns. - resolveArtifacts(List<RunnerApi.ArtifactInformation>) - Method in class org.apache.beam.sdk.util.construction.DefaultArtifactResolver
- resolveArtifacts(RunnerApi.Pipeline) - Method in interface org.apache.beam.sdk.util.construction.ArtifactResolver
-
Updating pipeline proto by applying registered
ArtifactResolver.ResolutionFns. - resolveArtifacts(RunnerApi.Pipeline) - Method in class org.apache.beam.sdk.util.construction.DefaultArtifactResolver
- ResolveOptions - Interface in org.apache.beam.sdk.io.fs
-
An object that configures
ResourceId.resolve(java.lang.String, org.apache.beam.sdk.io.fs.ResolveOptions). - ResolveOptions.StandardResolveOptions - Enum in org.apache.beam.sdk.io.fs
-
Defines the standard resolve options.
- resolveType(Type) - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns a
TypeDescriptorrepresenting the given type, with type variables resolved according to the specialization in this type. - ResourceHint - Class in org.apache.beam.sdk.transforms.resourcehints
-
Provides a definition of a resource hint known to the SDK.
- ResourceHint() - Constructor for class org.apache.beam.sdk.transforms.resourcehints.ResourceHint
- resourceHints - Variable in class org.apache.beam.sdk.transforms.PTransform
- ResourceHints - Class in org.apache.beam.sdk.transforms.resourcehints
-
Pipeline authors can use resource hints to provide additional information to runners about the desired aspects of the execution environment.
- ResourceHintsOptions - Interface in org.apache.beam.sdk.transforms.resourcehints
-
Options that are used to control configuration of the remote environment.
- ResourceHintsOptions.EmptyListDefault - Class in org.apache.beam.sdk.transforms.resourcehints
- ResourceHintsOptions.Options - Class in org.apache.beam.sdk.transforms.resourcehints
-
Register the
ResourceHintsOptions. - resourceId() - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata
- ResourceId - Interface in org.apache.beam.sdk.io.fs
-
An identifier which represents a file-like resource.
- ResourceIdCoder - Class in org.apache.beam.sdk.io.fs
-
A
CoderforResourceId. - ResourceIdCoder() - Constructor for class org.apache.beam.sdk.io.fs.ResourceIdCoder
- ResourceIdTester - Class in org.apache.beam.sdk.io.fs
-
A utility to test
ResourceIdimplementations. - restriction() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
If this is a splittable
DoFn, returns the associated restriction with the current call. - restriction() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- restriction() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- restrictionParameter(TypeDescriptor<?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
-
Returns a
DoFnSignature.Parameter.RestrictionParameter. - restrictionT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialRestrictionMethod
-
Type of the returned restriction.
- restrictionT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.RestrictionParameter
- restrictionTracker() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
If this is a splittable
DoFn, returns the associatedRestrictionTrackerwith the current call. - restrictionTracker() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- restrictionTracker() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- restrictionTracker(TypeDescriptor<?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- RestrictionTracker<RestrictionT,PositionT> - Class in org.apache.beam.sdk.transforms.splittabledofn
-
Manages access to the restriction and keeps track of its claimed part for a splittable
DoFn. - RestrictionTracker() - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker
- RestrictionTracker.HasProgress - Interface in org.apache.beam.sdk.transforms.splittabledofn
-
All
RestrictionTrackers SHOULD implement this interface to improve auto-scaling and splitting performance. - RestrictionTracker.IsBounded - Enum in org.apache.beam.sdk.transforms.splittabledofn
- RestrictionTracker.Progress - Class in org.apache.beam.sdk.transforms.splittabledofn
-
A representation for the amount of known completed and remaining work.
- RestrictionTracker.TruncateResult<RestrictionT> - Class in org.apache.beam.sdk.transforms.splittabledofn
-
A representation of the truncate result.
- RestrictionTrackers - Class in org.apache.beam.sdk.fn.splittabledofn
-
Support utilities for interacting with
RestrictionTrackers. - RestrictionTrackers() - Constructor for class org.apache.beam.sdk.fn.splittabledofn.RestrictionTrackers
- RestrictionTrackers.ClaimObserver<PositionT> - Interface in org.apache.beam.sdk.fn.splittabledofn
-
Interface allowing a runner to observe the calls to
RestrictionTracker.tryClaim(PositionT). - result(T) - Static method in class org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult
- Result() - Constructor for class org.apache.beam.sdk.schemas.transforms.CoGroup.Result
- Result() - Constructor for class org.apache.beam.sdk.transforms.WithFailures.Result
- RESULT - org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult.IsException
- resultBuilder() - Static method in class org.apache.beam.sdk.transforms.JsonToRow.ParseResult
- resume() - Static method in class org.apache.beam.sdk.transforms.DoFn.ProcessContinuation
-
Indicates that there is more work to be done for the current element.
- resumeDelay() - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContinuation
-
A minimum duration that should elapse between the end of this
DoFn.ProcessElementcall and theDoFn.ProcessElementcall continuing processing of the same element. - RETRACTING_FIRED_PANES - org.apache.beam.sdk.values.WindowingStrategy.AccumulationMode
- Reversed() - Constructor for class org.apache.beam.sdk.transforms.Top.Reversed
- revision() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
A monotonically increasing revision number of this
PipelineOptionsobject that can be used to detect changes. - RHS_TAG - Static variable in class org.apache.beam.sdk.schemas.transforms.Join
- right(Integer...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual.Impl
- right(Integer...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual
- right(String...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual.Impl
- right(String...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual
- right(FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual.Impl
- right(FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual
- rightOuterJoin(PCollection<RhsT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Join
-
Perform a right outer join.
- root() - Static method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
-
Path for display data registered by a top-level component.
- route(DoFn.MultiOutputReceiver, RecordT, Coder<RecordT>, Exception, String) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecordRouter.RecordingBadRecordRouter
- route(DoFn.MultiOutputReceiver, RecordT, Coder<RecordT>, Exception, String) - Method in interface org.apache.beam.sdk.transforms.errorhandling.BadRecordRouter
- route(DoFn.MultiOutputReceiver, RecordT, Coder<RecordT>, Exception, String) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecordRouter.ThrowingBadRecordRouter
- route(DoFn.FinishBundleContext, RecordT, Coder<RecordT>, Exception, String, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecordRouter.RecordingBadRecordRouter
- route(DoFn.FinishBundleContext, RecordT, Coder<RecordT>, Exception, String, BoundedWindow) - Method in interface org.apache.beam.sdk.transforms.errorhandling.BadRecordRouter
- route(DoFn.FinishBundleContext, RecordT, Coder<RecordT>, Exception, String, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecordRouter.ThrowingBadRecordRouter
- row(Schema) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Create a map type for the given key and value types.
- Row - Class in org.apache.beam.sdk.values
-
Rowis an immutable tuple-like schema to represent one element in aPCollection. - ROW - org.apache.beam.sdk.schemas.Schema.TypeName
- ROW_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- Row.Builder - Class in org.apache.beam.sdk.values
-
Builder for
Row. - Row.Equals - Class in org.apache.beam.sdk.values
- Row.FieldValueBuilder - Class in org.apache.beam.sdk.values
-
Builder for
Rowthat bases a row on another row. - rowBag(Schema) - Static method in class org.apache.beam.sdk.state.StateSpecs
- RowCoder - Class in org.apache.beam.sdk.coders
-
A sub-class of SchemaCoder that can only encode
Rowinstances. - RowCoderGenerator - Class in org.apache.beam.sdk.coders
- RowCoderGenerator() - Constructor for class org.apache.beam.sdk.coders.RowCoderGenerator
- RowFilter - Class in org.apache.beam.sdk.util
-
A utility that filters fields from Beam
Rows. - RowFilter(Schema) - Constructor for class org.apache.beam.sdk.util.RowFilter
- rowFromProto(SchemaApi.Row, Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.SchemaTranslation
- RowJson - Class in org.apache.beam.sdk.util
-
Jackson serializer and deserializer for
Rows. - RowJson() - Constructor for class org.apache.beam.sdk.util.RowJson
- RowJson.RowJsonDeserializer - Class in org.apache.beam.sdk.util
-
Jackson deserializer for parsing JSON into
Rows. - RowJson.RowJsonDeserializer.NullBehavior - Enum in org.apache.beam.sdk.util
-
An enumeration type for specifying how
RowJson.RowJsonDeserializershould expect null values to be represented. - RowJson.RowJsonSerializer - Class in org.apache.beam.sdk.util
-
Jackson serializer for converting
Rowsto JSON. - RowJson.UnsupportedRowJsonException - Exception in org.apache.beam.sdk.util
-
Gets thrown when Row parsing or serialization fails for any reason.
- RowJsonUtils - Class in org.apache.beam.sdk.util
-
Utilities for working with
RowJson.RowJsonSerializerandRowJson.RowJsonDeserializer. - RowJsonUtils() - Constructor for class org.apache.beam.sdk.util.RowJsonUtils
- rowMap(Schema, Schema) - Static method in class org.apache.beam.sdk.state.StateSpecs
- RowMessages - Class in org.apache.beam.sdk.schemas
- rowMultimap(Schema, Schema) - Static method in class org.apache.beam.sdk.state.StateSpecs
-
Create a
StateSpecfor aMultimapState, optimized for key lookups, key puts, and clear. - rowOrderedList(Schema) - Static method in class org.apache.beam.sdk.state.StateSpecs
- rowReceiver(DoFn.WindowedContext, OutputBuilderSupplier, TupleTag<T>, SchemaCoder<T>) - Static method in class org.apache.beam.sdk.transforms.DoFnOutputReceivers
-
Returns a
DoFn.OutputReceiverthat automatically converts aRowto the user's output type and delegates toDoFnOutputReceivers.WindowedContextOutputReceiver. - rows() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorforRow. - RowSchemaInformationProvider - Class in org.apache.beam.sdk.schemas.utils
- RowSchemaInformationProvider() - Constructor for class org.apache.beam.sdk.schemas.utils.RowSchemaInformationProvider
- RowSelector - Interface in org.apache.beam.sdk.schemas.utils
-
A selector interface for extracting fields from a row.
- RowSelectorContainer(Schema, FieldAccessDescriptor, boolean) - Constructor for class org.apache.beam.sdk.schemas.utils.SelectHelpers.RowSelectorContainer
- rowSet(Schema) - Static method in class org.apache.beam.sdk.state.StateSpecs
- RowStringInterpolator - Class in org.apache.beam.sdk.util
-
A utility that interpolates values in a pre-determined
Stringusing an input BeamRow. - RowStringInterpolator(String, Schema) - Constructor for class org.apache.beam.sdk.util.RowStringInterpolator
- rowToBytesFn(SchemaProvider, TypeDescriptor<T>, Coder<? super T>) - Static method in class org.apache.beam.sdk.schemas.RowMessages
- rowToBytesFn(SchemaProvider, TypeDescriptor<T>, ProcessFunction<? super T, byte[]>) - Static method in class org.apache.beam.sdk.schemas.RowMessages
- rowToJson(ObjectMapper, Row) - Static method in class org.apache.beam.sdk.util.RowJsonUtils
- rowToProto(Row) - Static method in class org.apache.beam.sdk.schemas.SchemaTranslation
- rowValue(Schema) - Static method in class org.apache.beam.sdk.state.StateSpecs
-
Create a
StateSpecfor a row value with the specified schema. - RowWithGetters<T extends @NonNull java.lang.Object> - Class in org.apache.beam.sdk.values
-
A Concrete subclass of
Rowthat delegates to a set of providedFieldValueGetters. - RowWithStorage - Class in org.apache.beam.sdk.values
-
Concrete subclass of
Rowthat explicitly stores all fields of the row. - RULE_arrayQualifier - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- RULE_dotExpression - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- RULE_dotExpressionComponent - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- RULE_fieldSpecifier - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- RULE_mapQualifier - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- RULE_qualifiedComponent - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- RULE_qualifierList - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- ruleNames - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- ruleNames - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- run() - Method in interface org.apache.beam.sdk.function.ThrowingRunnable
- run() - Method in class org.apache.beam.sdk.Pipeline
-
Runs this
Pipelineaccording to thePipelineOptionsused to create thePipelineviaPipeline.create(PipelineOptions). - run() - Method in class org.apache.beam.sdk.testing.TestPipeline
-
Runs this
TestPipeline, unwrapping anyAssertionErrorthat is raised during testing. - run() - Method in interface org.apache.beam.sdk.util.ThrowingRunnable
- run(PipelineOptions) - Method in class org.apache.beam.sdk.Pipeline
-
Runs this
Pipelineusing the givenPipelineOptions, using the runner specified by the options. - run(PipelineOptions) - Method in class org.apache.beam.sdk.testing.TestPipeline
-
Like
TestPipeline.run()but with the given potentially modified options. - run(Pipeline) - Method in class org.apache.beam.sdk.PipelineRunner
-
Processes the given
Pipeline, potentially asynchronously, returning a runner-specific type of result. - run(Pipeline) - Method in class org.apache.beam.sdk.testing.CrashingRunner
- run(PTransform<PBegin, ?>) - Method in class org.apache.beam.sdk.PipelineRunner
-
Overloaded
PTransformrunner that runs with the default appPipelineOptions. - run(PTransform<PBegin, ?>, PipelineOptions) - Method in class org.apache.beam.sdk.PipelineRunner
-
Creates a
Pipelineout of a singlePTransformstep, and executes it. - runAsync(ThrowingRunnable) - Static method in class org.apache.beam.sdk.util.MoreFutures
-
Shorthand for
MoreFutures.runAsync(ThrowingRunnable, ExecutorService)usingForkJoinPool.commonPool(). - runAsync(ThrowingRunnable, ExecutorService) - Static method in class org.apache.beam.sdk.util.MoreFutures
-
Like
CompletableFuture.runAsync(java.lang.Runnable)but forThrowingRunnable. - runBeforeProcessing(PipelineOptions) - Static method in class org.apache.beam.sdk.fn.JvmInitializers
-
Finds all registered implementations of JvmInitializer and executes their
beforeProcessingmethods. - RUNNER_IMPLEMENTED_TRANSFORMS - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- RunnerPCollectionView<T> - Class in org.apache.beam.sdk.util.construction
-
A
PCollectionViewcreated from the components of aRunnerApi.SideInput. - RunnerPCollectionView(PCollection<?>, TupleTag<Iterable<WindowedValue<?>>>, ViewFn<Iterable<WindowedValue<?>>, T>, WindowMappingFn<?>, WindowingStrategy<?, ?>, Coder<?>) - Constructor for class org.apache.beam.sdk.util.construction.RunnerPCollectionView
-
Create a new
RunnerPCollectionViewfrom the provided components. - RUNNING - org.apache.beam.sdk.PipelineResult.State
-
The job is currently running.
- runOnStartup() - Static method in class org.apache.beam.sdk.fn.JvmInitializers
-
Finds all registered implementations of JvmInitializer and executes their
onStartupmethods. - runResourceIdBattery(ResourceId) - Static method in class org.apache.beam.sdk.io.fs.ResourceIdTester
- runWindowFn(WindowFn<T, W>, List<Long>) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
-
Runs the
WindowFnover the provided input, returning a map of windows to the timestamps in those windows. - runWindowFnWithValue(WindowFn<T, W>, List<TimestampedValue<T>>) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
-
Runs the
WindowFnover the provided input, returning a map of windows to the timestamps in those windows. - runWithAdditionalOptionArgs(List<String>) - Method in class org.apache.beam.sdk.testing.TestPipeline
-
Runs this
TestPipelinewith additional cmd pipeline option args.
S
- SAME - org.apache.beam.sdk.schemas.Schema.EquivalenceNullablePolicy
- Sample - Class in org.apache.beam.sdk.transforms
-
PTransforms for taking samples of the elements in aPCollection, or samples of the values associated with each key in aPCollectionofKVs. - Sample() - Constructor for class org.apache.beam.sdk.transforms.Sample
- Sample.FixedSizedSampleFn<T> - Class in org.apache.beam.sdk.transforms
-
CombineFnthat computes a fixed-size sample of a collection of values. - SampleAllFiles() - Constructor for class org.apache.beam.sdk.io.TextRowCountEstimator.SampleAllFiles
- satisfies(List<SerializableFunction<Iterable<T>, Void>>) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionListContentsAssert
-
Takes list of
SerializableFunctions of the same size asPAssert.PCollectionListContentsAssert.pCollectionList, and applies each matcher to thePCollectionwith the identical index in thePAssert.PCollectionListContentsAssert.pCollectionList. - satisfies(SerializableFunction<Iterable<T>, Void>) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Applies the provided checking function (presumably containing assertions) to the iterable in question.
- satisfies(SerializableFunction<Iterable<T>, Void>) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
- satisfies(SerializableFunction<Iterable<T>, Void>) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionListContentsAssert
- satisfies(SerializableFunction<T, Void>) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Applies the provided checking function (presumably containing assertions) to the value in question.
- schedule(Runnable, long, TimeUnit) - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- ScheduledExecutorServiceFactory() - Constructor for class org.apache.beam.sdk.options.ExecutorOptions.ScheduledExecutorServiceFactory
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- schema - Variable in class org.apache.beam.sdk.schemas.SchemaCoder
- schema() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIO
-
Returns the schema of the data.
- Schema - Class in org.apache.beam.sdk.schemas
- Schema(List<Schema.Field>) - Constructor for class org.apache.beam.sdk.schemas.Schema
- Schema(List<Schema.Field>, Schema.Options) - Constructor for class org.apache.beam.sdk.schemas.Schema
- SCHEMA - Static variable in class org.apache.beam.sdk.io.ClassLoaderFileSystem
- Schema.Builder - Class in org.apache.beam.sdk.schemas
-
Builder class for building
Schemaobjects. - Schema.EquivalenceNullablePolicy - Enum in org.apache.beam.sdk.schemas
-
Control whether nullable is included in equivalence check.
- Schema.Field - Class in org.apache.beam.sdk.schemas
-
Field of a row.
- Schema.Field.Builder - Class in org.apache.beam.sdk.schemas
-
Builder for
Schema.Field. - Schema.FieldType - Class in org.apache.beam.sdk.schemas
-
A descriptor of a single field type.
- Schema.LogicalType<InputT,BaseT> - Interface in org.apache.beam.sdk.schemas
-
A LogicalType allows users to define a custom schema type.
- Schema.Options - Class in org.apache.beam.sdk.schemas
- Schema.Options.Builder - Class in org.apache.beam.sdk.schemas
- Schema.TypeName - Enum in org.apache.beam.sdk.schemas
-
An enumerated list of type constructors.
- SchemaCaseFormat - Annotation Type in org.apache.beam.sdk.schemas.annotations
- SchemaCoder<T> - Class in org.apache.beam.sdk.schemas
-
SchemaCoderis used as the coder for types that have schemas registered. - SchemaCoder(Schema, TypeDescriptor<T>, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Constructor for class org.apache.beam.sdk.schemas.SchemaCoder
- SchemaCreate - Annotation Type in org.apache.beam.sdk.schemas.annotations
-
Can be put on a constructor or a static method, in which case that constructor or method will be used to created instance of the class by Beam's schema code.
- schemaElement(int) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provide a reference to the selected schema field corresponding to the input argument specified by index.
- schemaElement(int) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- schemaElement(int) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- schemaElementParameter(TypeDescriptor<?>, String, int) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- SchemaFieldDescription - Annotation Type in org.apache.beam.sdk.schemas.annotations
- SchemaFieldName - Annotation Type in org.apache.beam.sdk.schemas.annotations
- SchemaFieldNumber - Annotation Type in org.apache.beam.sdk.schemas.annotations
- schemaFor(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProvider
- schemaFor(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.AutoValueSchema
- schemaFor(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema
- schemaFor(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.JavaFieldSchema
- schemaFor(TypeDescriptor<T>) - Method in interface org.apache.beam.sdk.schemas.SchemaProvider
-
Lookup a schema for the given type.
- schemaFromClass(TypeDescriptor<?>, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.StaticSchemaInference
-
Infer a schema from a Java class.
- schemaFromJavaBeanClass(TypeDescriptor<?>, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
-
Create a
Schemafor a Java Bean class. - schemaFromPojoClass(TypeDescriptor<?>, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
- schemaFromProto(SchemaApi.Schema) - Static method in class org.apache.beam.sdk.schemas.SchemaTranslation
- SchemaIgnore - Annotation Type in org.apache.beam.sdk.schemas.annotations
-
When used on a POJO field or a JavaBean getter, that field or getter is ignored from the inferred schema.
- SchemaInformationProvider - Interface in org.apache.beam.sdk.schemas.utils
-
Provides an instance of
ConvertHelpers.ConvertedSchemaInformation. - SchemaIO - Interface in org.apache.beam.sdk.schemas.io
-
An abstraction to create schema capable and aware IOs.
- SchemaIOProvider - Interface in org.apache.beam.sdk.schemas.io
-
Provider to create
SchemaIOinstances for use in Beam SQL and other SDKs. - SchemaLogicalType - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A schema represented as a serialized proto bytes.
- SchemaLogicalType() - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.SchemaLogicalType
- SchemaProvider - Interface in org.apache.beam.sdk.schemas
-
Concrete implementations of this class allow creation of schema service objects that vend a
Schemafor a specific type. - SchemaProviderRegistrar - Interface in org.apache.beam.sdk.schemas
-
SchemaProvidercreators have the ability to automatically have theirschemaProviderregistered with this SDK by creating aServiceLoaderentry and a concrete implementation of this interface. - SchemaRegistry - Class in org.apache.beam.sdk.schemas
- schemaToProto(Schema, boolean) - Static method in class org.apache.beam.sdk.schemas.SchemaTranslation
- schemaToProto(Schema, boolean, boolean) - Static method in class org.apache.beam.sdk.schemas.SchemaTranslation
- SchemaTransform - Class in org.apache.beam.sdk.schemas.transforms
-
An abstraction representing schema capable and aware transforms.
- SchemaTransform() - Constructor for class org.apache.beam.sdk.schemas.transforms.SchemaTransform
- SchemaTransformPayloadTranslator() - Constructor for class org.apache.beam.sdk.schemas.transforms.SchemaTransformTranslation.SchemaTransformPayloadTranslator
- SchemaTransformProvider - Interface in org.apache.beam.sdk.schemas.transforms
-
Provider to create
SchemaTransforminstances for use in Beam SQL and other SDKs. - SchemaTransformTranslation - Class in org.apache.beam.sdk.schemas.transforms
-
A
PTransformTranslation.TransformPayloadTranslatorimplementation that translates between a JavaSchemaTransformand a protobuf payload for that transform. - SchemaTransformTranslation() - Constructor for class org.apache.beam.sdk.schemas.transforms.SchemaTransformTranslation
- SchemaTransformTranslation.SchemaTransformPayloadTranslator<T extends SchemaTransform> - Class in org.apache.beam.sdk.schemas.transforms
- SchemaTranslation - Class in org.apache.beam.sdk.schemas
-
Utility methods for translating schemas.
- SchemaTranslation() - Constructor for class org.apache.beam.sdk.schemas.SchemaTranslation
- schemaTypeCreator(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
-
Deprecated.new implementations should override
GetterBasedSchemaProvider.schemaTypeCreator(TypeDescriptor, Schema)and make this method throw anUnsupportedOperationException - schemaTypeCreator(Class<?>, Schema) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProviderV2
- schemaTypeCreator(TypeDescriptor<?>, Schema) - Method in class org.apache.beam.sdk.schemas.AutoValueSchema
- schemaTypeCreator(TypeDescriptor<?>, Schema) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
-
Deprecated.Delegates to the
GetterBasedSchemaProvider.schemaTypeCreator(Class, Schema)for backwards compatibility, override it if you want to use the richer type signature contained in theTypeDescriptornot subject to the type erasure. - schemaTypeCreator(TypeDescriptor<?>, Schema) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProviderV2
- schemaTypeCreator(TypeDescriptor<?>, Schema) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema
- schemaTypeCreator(TypeDescriptor<?>, Schema) - Method in class org.apache.beam.sdk.schemas.JavaFieldSchema
- SchemaUserTypeCreator - Interface in org.apache.beam.sdk.schemas
-
A creator interface for user types that have schemas.
- SchemaUtils - Class in org.apache.beam.sdk.schemas
-
A set of utility functions for schemas.
- SchemaUtils() - Constructor for class org.apache.beam.sdk.schemas.SchemaUtils
- SchemaVerification - Class in org.apache.beam.sdk.values
- SchemaVerification() - Constructor for class org.apache.beam.sdk.values.SchemaVerification
- SchemaZipFold<T> - Class in org.apache.beam.sdk.schemas.utils
-
Visitor that zips schemas, and accepts pairs of fields and their types.
- SchemaZipFold() - Constructor for class org.apache.beam.sdk.schemas.utils.SchemaZipFold
- SchemaZipFold.Context - Class in org.apache.beam.sdk.schemas.utils
-
Context referring to a current position in a schema.
- scopedMetricsContainer(MetricsContainer) - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
-
Set the
MetricsContainerfor the current thread. - SdkComponents - Class in org.apache.beam.sdk.util.construction
-
SDK objects that will be represented at some later point within a
RunnerApi.Componentsobject. - SdkHarnessLogLevelOverrides() - Constructor for class org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides
- SdkHarnessOptions - Interface in org.apache.beam.sdk.options
-
Options that are used to control configuration of the SDK harness.
- SdkHarnessOptions.BundleProcessorCacheTimeoutFactory - Class in org.apache.beam.sdk.options
- SdkHarnessOptions.DefaultMaxCacheMemoryUsageMb - Class in org.apache.beam.sdk.options
-
The default implementation which detects how much memory to use for a process wide cache.
- SdkHarnessOptions.DefaultMaxCacheMemoryUsageMbFactory - Class in org.apache.beam.sdk.options
-
A
DefaultValueFactorywhich constructs an instance of the class specified bymaxCacheMemoryUsageMbClassto compute the maximum amount of memory to allocate to the process wide cache within an SDK harness instance. - SdkHarnessOptions.LogLevel - Enum in org.apache.beam.sdk.options
-
The set of log levels that can be used in the SDK harness.
- SdkHarnessOptions.MaxCacheMemoryUsageMb - Interface in org.apache.beam.sdk.options
-
Specifies the maximum amount of memory to use within the current SDK harness instance.
- SdkHarnessOptions.SdkHarnessLogLevelOverrides - Class in org.apache.beam.sdk.options
-
Defines a log level override for a specific class, package, or name.
- Secret - Interface in org.apache.beam.sdk.util
-
A secret management interface used for handling sensitive data.
- select(Row) - Method in interface org.apache.beam.sdk.schemas.utils.RowSelector
- select(Row) - Method in class org.apache.beam.sdk.schemas.utils.SelectHelpers.RowSelectorContainer
- Select - Class in org.apache.beam.sdk.schemas.transforms
-
A
PTransformfor selecting a subset of fields from a schema type. - Select() - Constructor for class org.apache.beam.sdk.schemas.transforms.Select
- Select.Fields<T> - Class in org.apache.beam.sdk.schemas.transforms
- Select.Flattened<T> - Class in org.apache.beam.sdk.schemas.transforms
-
A
PTransformrepresenting a flattened schema. - SelectHelpers - Class in org.apache.beam.sdk.schemas.utils
-
Helper methods to select subrows out of rows.
- SelectHelpers() - Constructor for class org.apache.beam.sdk.schemas.utils.SelectHelpers
- SelectHelpers.RowSelectorContainer - Class in org.apache.beam.sdk.schemas.utils
- sendElements(BeamFnApi.Elements) - Method in class org.apache.beam.sdk.fn.data.BeamFnDataOutboundAggregator
- sendOrCollectBufferedDataAndFinishOutboundStreams() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataOutboundAggregator
-
Closes the streams for all registered outbound endpoints.
- SequenceDefinition() - Constructor for class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
- SequenceDefinition(Instant, Instant, Duration) - Constructor for class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
- SequenceDefinition(Instant, Instant, Duration, boolean) - Constructor for class org.apache.beam.sdk.transforms.PeriodicSequence.SequenceDefinition
-
catchUpToNow is experimental; no backwards-compatibility guarantees.
- SerializableBiConsumer<FirstInputT,SecondInputT> - Interface in org.apache.beam.sdk.transforms
-
A union of the
BiConsumerandSerializableinterfaces. - SerializableBiFunction<FirstInputT,SecondInputT,OutputT> - Interface in org.apache.beam.sdk.transforms
-
A union of the
BiFunctionandSerializableinterfaces. - SerializableCoder<T extends java.io.Serializable> - Class in org.apache.beam.sdk.coders
-
A
Coderfor Java classes that implementSerializable. - SerializableCoder(Class<T>, TypeDescriptor<T>) - Constructor for class org.apache.beam.sdk.coders.SerializableCoder
- SerializableCoder.SerializableCoderProviderRegistrar - Class in org.apache.beam.sdk.coders
-
A
CoderProviderRegistrarwhich registers aCoderProviderwhich can handle serializable types. - SerializableCoderProviderRegistrar() - Constructor for class org.apache.beam.sdk.coders.SerializableCoder.SerializableCoderProviderRegistrar
- SerializableComparator<T> - Interface in org.apache.beam.sdk.transforms
-
A
Comparatorthat is alsoSerializable. - SerializableFunction<InputT,OutputT> - Interface in org.apache.beam.sdk.transforms
-
A function that computes an output value of type
OutputTfrom an input value of typeInputT, isSerializable, and does not allow checked exceptions to be declared. - SerializableFunctions - Class in org.apache.beam.sdk.transforms
-
Useful
SerializableFunctionoverrides. - SerializableFunctions() - Constructor for class org.apache.beam.sdk.transforms.SerializableFunctions
- SerializableMatcher<T> - Interface in org.apache.beam.sdk.testing
-
A
Matcherthat is alsoSerializable. - SerializableMatchers - Class in org.apache.beam.sdk.testing
-
Static class for building and using
SerializableMatcherinstances. - SerializableSupplier<T> - Interface in org.apache.beam.sdk.util
-
A union of a
SupplierandSerializable, enabling configuration withSerializableSuppliertypes that are notSerializable. - SerializableThrowable - Class in org.apache.beam.sdk.util
-
A wrapper around
Throwablethat preserves the stack trace on serialization, unlike regularThrowable. - SerializableThrowable(Throwable) - Constructor for class org.apache.beam.sdk.util.SerializableThrowable
- SerializableUtils - Class in org.apache.beam.sdk.util
-
Utilities for working with Serializables.
- SerializableUtils() - Constructor for class org.apache.beam.sdk.util.SerializableUtils
- serialize(ValueProvider<?>, JsonGenerator, SerializerProvider) - Method in class org.apache.beam.sdk.options.ValueProvider.Serializer
- serialize(Row) - Method in interface org.apache.beam.sdk.schemas.io.payloads.PayloadSerializer
- serialize(Row, JsonGenerator, SerializerProvider) - Method in class org.apache.beam.sdk.util.RowJson.RowJsonSerializer
- SERIALIZED_JAVA_WINDOWFN_URN - Static variable in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- Serializer() - Constructor for class org.apache.beam.sdk.options.ValueProvider.Serializer
- serializeToByteArray(Serializable) - Static method in class org.apache.beam.sdk.util.SerializableUtils
-
Serializes the argument into an array of bytes, and returns it.
- serialVersionUID - Static variable in interface org.apache.beam.sdk.schemas.io.payloads.PayloadSerializer
- serverDirect() - Static method in class org.apache.beam.sdk.fn.stream.OutboundObserverFactory
-
Like
OutboundObserverFactory.clientDirect()but for server-side RPCs. - ServerFactory - Class in org.apache.beam.sdk.fn.server
-
A
gRPC serverfactory. - ServerFactory() - Constructor for class org.apache.beam.sdk.fn.server.ServerFactory
- ServerFactory.InetSocketAddressServerFactory - Class in org.apache.beam.sdk.fn.server
-
Creates a
gRPC Serverusing the default server factory. - ServerFactory.UrlFactory - Interface in org.apache.beam.sdk.fn.server
-
Factory that constructs client-accessible URLs from a local server address and port.
- SESSION_WINDOWS_URN - Static variable in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- Sessions - Class in org.apache.beam.sdk.transforms.windowing
-
A
WindowFnthat windows values into sessions separated by periods with no input for at least the duration specified bySessions.getGapDuration(). - set() - Static method in class org.apache.beam.sdk.state.StateSpecs
- set(long) - Method in class org.apache.beam.sdk.metrics.DelegatingGauge
-
Set the gauge.
- set(long) - Method in interface org.apache.beam.sdk.metrics.Gauge
-
Set current value for this gauge.
- set(long...) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
-
Creates a Set of elements to be used as expected output in
WindowFnTestUtils.runWindowFn(org.apache.beam.sdk.transforms.windowing.WindowFn<T, W>, java.util.List<java.lang.Long>). - set(String, Instant) - Method in interface org.apache.beam.sdk.state.TimerMap
- set(ObjectT, ValueT) - Method in interface org.apache.beam.sdk.schemas.FieldValueSetter
-
Sets the specified field on object to value.
- set(Coder<T>) - Static method in class org.apache.beam.sdk.state.StateSpecs
-
Identical to
StateSpecs.set(), but with an element coder explicitly supplied. - set(Instant) - Method in interface org.apache.beam.sdk.state.Timer
-
Sets or resets the time in the timer's
TimeDomainat which it should fire. - setAppend(Boolean) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration.Builder
- setAppName(String) - Method in interface org.apache.beam.sdk.options.ApplicationNameOptions
- setBlockOnRun(boolean) - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
- setBundleProcessorCacheTimeout(Duration) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
- setCallable(String) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration.Builder
- setChecksum(String) - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
- setCloningBehavior(DoFnTester.CloningBehavior) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - setCoder(String) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record.Builder
- setCoder(Coder<T>) - Method in class org.apache.beam.sdk.values.PCollection
-
Sets the
Coderused by thisPCollectionto encode and decode the values stored in it. - SetCoder<T> - Class in org.apache.beam.sdk.coders
- SetCoder(Coder<T>) - Constructor for class org.apache.beam.sdk.coders.SetCoder
- setCoderRegistry(CoderRegistry) - Method in class org.apache.beam.sdk.Pipeline
-
Deprecated.this should never be used - every
Pipelinehas a registry throughout its lifetime. - setCompression(String) - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformConfiguration.Builder
- setCompression(String) - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration.Builder
- setCompression(Compression) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
- setCrossProduct(Boolean) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider.Configuration.Builder
- setCurrentContainer(MetricsContainer) - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
-
Set the
MetricsContainerfor the current thread. - setDefaultEnvironmentConfig(String) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- setDefaultEnvironmentType(String) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- setDefaultPipelineOptions(PipelineOptions) - Static method in class org.apache.beam.sdk.io.FileSystems
-
Sets the default configuration in workers.
- setDefaultPipelineOptions(PipelineOptions) - Static method in class org.apache.beam.sdk.metrics.Metrics
-
Initialize metrics flags if not already done so.
- setDefaultSdkHarnessLogLevel(SdkHarnessOptions.LogLevel) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
- setDelimiters(byte[]) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
- setDescription(String) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
- setDescription(String) - Method in class org.apache.beam.sdk.schemas.Schema.Field.Builder
- setDescription(String) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Failure.Builder
- setDirectoryTreatment(FileIO.ReadMatches.DirectoryTreatment) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
- setDisplayData(List<DisplayData.ItemSpec<?>>) - Method in class org.apache.beam.sdk.transforms.PTransform
-
Set display data for your PTransform.
- setDrop(List<String>) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration.Builder
- setElementProcessingTimeoutMinutes(int) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
- setElements(Long) - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate.Builder
- setElementsPerPeriod(Long) - Method in class org.apache.beam.sdk.io.GenerateSequence.External.ExternalConfiguration
- setElementT(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter.Builder
- setElementT(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SideInputParameter.Builder
- setElementType(FieldValueTypeInformation) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
- setEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
- setEnableHeapDumps(boolean) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- setEnableLogViaFnApi(boolean) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
- setEncodedRecord(byte[]) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record.Builder
- setEncodingPositions(Map<String, Integer>) - Method in class org.apache.beam.sdk.schemas.Schema
-
Sets the encoding positions for this schema.
- setEnd(Long) - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Builder
- setEnvironmentCacheMillis(int) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- setEnvironmentExpirationMillis(int) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- setEnvironmentOptions(List<String>) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- setError(String) - Method in class org.apache.beam.sdk.schemas.io.Failure.Builder
- setErrorField(String) - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
-
Adds the error message to the returned error Row.
- setErrorHandling(ErrorHandling) - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformConfiguration.Builder
- setErrorHandling(ErrorHandling) - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration.Builder
- setErrorHandling(ErrorHandling) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider.Configuration.Builder
- setErrorHandling(ErrorHandling) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration.Builder
- setException(String) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Failure.Builder
- setExceptionStacktrace(String) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Failure.Builder
- setExpectFileToNotExist(Boolean) - Method in class org.apache.beam.sdk.io.fs.CreateOptions.Builder
- setExperiments(List<String>) - Method in interface org.apache.beam.sdk.options.ExperimentalOptions
- setExpression(String) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration.Builder
- setFailure(BadRecord.Failure) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Builder
- setField(Field) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
- setFieldAccessString(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter.Builder
- setFieldId(Integer) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Builder
- setFieldName(String) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Builder
- setFieldRename(String) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Builder
- setFields(List<String>) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider.Configuration.Builder
- setFields(Map<String, JavaRowUdf.Configuration>) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration.Builder
- setFilenameSuffix(String) - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration.Builder
- setFilePattern(String) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
- setFilePattern(String) - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformConfiguration.Builder
- setFilesToStage(List<String>) - Method in interface org.apache.beam.sdk.options.FileStagingOptions
- setGbek(String) - Method in interface org.apache.beam.sdk.options.PipelineOptions
- setGCThrashingPercentagePerPeriod(Double) - Method in interface org.apache.beam.sdk.options.MemoryMonitorOptions
- setGroupingTableMaxSizeMb(int) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
- setGzipCompressHeapDumps(boolean) - Method in interface org.apache.beam.sdk.options.MemoryMonitorOptions
- setHumanReadableJsonRecord(String) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record.Builder
- setIndex(int) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter.Builder
- setInsideGBEK() - Method in class org.apache.beam.sdk.transforms.GroupByKey
-
For Beam internal use only.
- setIsBoundedInternal(PCollection.IsBounded) - Method in class org.apache.beam.sdk.values.PCollection
-
For internal use only; no backwards-compatibility guarantees.
- setIsReadSeekEfficient(boolean) - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
- setJdkAddOpenModules(List<String>) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
- setJdkAddRootModules(List<String>) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
- setJobEndpoint(String) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- setJobName(String) - Method in interface org.apache.beam.sdk.options.PipelineOptions
- setJobServerTimeout(int) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- setJsonToRowWithErrFn(JsonToRow.JsonToRowWithErrFn) - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError.Builder
- setKeep(JavaRowUdf.Configuration) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider.Configuration.Builder
- setLanguage(String) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider.Configuration.Builder
- setLanguage(String) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration.Builder
- setLastModifiedMillis(long) - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
- setLazy() - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObserver
-
Sets byte counting for the current element as lazy.
- setLevel(String) - Method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider.Configuration.Builder
- setLineField(String) - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
-
Sets the field name for the line field in the returned Row.
- setLoadBalanceBundles(boolean) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- setLogMdc(boolean) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
- setMapKeyType(FieldValueTypeInformation) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
- setMapValueType(FieldValueTypeInformation) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
- setMaxCacheMemoryUsageMb(@org.checkerframework.checker.index.qual.NonNegative int) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
- setMaxCacheMemoryUsageMbClass(Class<? extends SdkHarnessOptions.MaxCacheMemoryUsageMb>) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
- setMaxCacheMemoryUsagePercent(@org.checkerframework.checker.index.qual.NonNegative float) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
- setMaxNumWritersPerBundle(Integer) - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration.Builder
- setMaxReadTime(Long) - Method in class org.apache.beam.sdk.io.GenerateSequence.External.ExternalConfiguration
- setMetadataSupported() - Static method in class org.apache.beam.sdk.values.WindowedValues.WindowedValueCoder
- setMethod(Method) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
- setMetricsGraphiteHost(String) - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
- setMetricsGraphitePort(Integer) - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
- setMetricsHttpSinkUrl(String) - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
- setMetricsPushPeriod(Long) - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
- setMetricsSink(Class<? extends MetricsSink>) - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
- setMetricsSupported(boolean) - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
-
Called by the run to indicate whether metrics reporting is supported.
- setMimeType(String) - Method in class org.apache.beam.sdk.io.fs.CreateOptions.Builder
- setName(String) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
- setName(String) - Method in class org.apache.beam.sdk.schemas.Schema.Field.Builder
- setName(String) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration.Builder
- setName(String) - Method in class org.apache.beam.sdk.values.PCollection
-
Sets the name of this
PCollection. - setName(String) - Method in class org.apache.beam.sdk.values.PValueBase
-
Sets the name of this
PValueBase. - setNoSpilling(Boolean) - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration.Builder
- setNullable(boolean) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
- setNumber(Integer) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
- setNumSampledBytesPerFile(long) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
- setNumShards(int) - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration.Builder
- setOnCreateMatcher(SerializableMatcher<PipelineResult>) - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
- setOneOfTypes(Map<String, FieldValueTypeInformation>) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
- setOnSuccessMatcher(SerializableMatcher<PipelineResult>) - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
- setOption(String, Schema.FieldType, Object) - Method in class org.apache.beam.sdk.schemas.Schema.Options.Builder
- setOption(String, Schema.FieldType, Object) - Static method in class org.apache.beam.sdk.schemas.Schema.Options
- setOption(String, Row) - Method in class org.apache.beam.sdk.schemas.Schema.Options.Builder
- setOption(String, Row) - Static method in class org.apache.beam.sdk.schemas.Schema.Options
- setOptions(Schema.Options) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
Returns a copy of the Field with isNullable set.
- setOptions(Schema.Options) - Method in class org.apache.beam.sdk.schemas.Schema.Field.Builder
- setOptions(Schema.Options.Builder) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
- setOptions(Schema.Options.Builder) - Method in class org.apache.beam.sdk.schemas.Schema.Field.Builder
- setOptionsId(long) - Method in interface org.apache.beam.sdk.options.PipelineOptions
- setOutput(String) - Method in class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling.Builder
- setOutput(POutput) - Method in class org.apache.beam.sdk.runners.TransformHierarchy
-
Set the output of the current
TransformHierarchy.Node. - setOutputExecutablePath(String) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- setOutputPrefix(String) - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration.Builder
- setPaneInfo(PaneInfo) - Method in interface org.apache.beam.sdk.values.OutputBuilder
- setPaneInfo(PaneInfo) - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- setPath(String) - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration.Builder
- setPayload(byte[]) - Method in class org.apache.beam.sdk.schemas.io.Failure.Builder
- setPeriod(Long) - Method in class org.apache.beam.sdk.io.GenerateSequence.External.ExternalConfiguration
- setPipelineResourcesDetector(PipelineResourcesDetector) - Method in interface org.apache.beam.sdk.util.construction.resources.PipelineResourcesOptions
- setPipelineResourcesDetectorFactoryClass(Class<? extends PipelineResourcesDetector.Factory>) - Method in interface org.apache.beam.sdk.util.construction.resources.PipelineResourcesOptions
- setPrefix(String) - Method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider.Configuration.Builder
- setProcessWideContainer(MetricsContainer) - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
-
Set the
MetricsContainerfor the current process. - setProviderRuntimeValues(ValueProvider<Map<String, Object>>) - Method in interface org.apache.beam.sdk.testing.TestPipeline.TestValueProviderOptions
- setQualifiers(List<FieldAccessDescriptor.FieldDescriptor.Qualifier>) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Builder
- setRate(GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate) - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Builder
- setRawType(Class<?>) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
- setReceiver(WindowedValueReceiver<T>) - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- setRecord(BadRecord.Record) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Builder
- setRecordId(String) - Method in interface org.apache.beam.sdk.values.OutputBuilder
- setRecordId(String) - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- setRecordOffset(Long) - Method in interface org.apache.beam.sdk.values.OutputBuilder
- setRecordOffset(Long) - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- setRelative() - Method in interface org.apache.beam.sdk.state.Timer
-
Sets the timer relative to the current time, according to any offset and alignment specified.
- setRemoteHeapDumpLocation(String) - Method in interface org.apache.beam.sdk.options.MemoryMonitorOptions
- setResourceHints(ResourceHints) - Method in class org.apache.beam.sdk.transforms.PTransform
-
Sets resource hints for the transform.
- setResourceHints(List<String>) - Method in interface org.apache.beam.sdk.transforms.resourcehints.ResourceHintsOptions
- setResourceId(ResourceId) - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
- setRetainDockerContainers(boolean) - Method in interface org.apache.beam.sdk.options.ManualDockerEnvironmentOptions
- setRowSchema(Schema) - Method in class org.apache.beam.sdk.values.PCollection
-
Sets a schema on this PCollection.
- setRunner(Class<? extends PipelineRunner<?>>) - Method in interface org.apache.beam.sdk.options.PipelineOptions
- sets(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorforSet. - Sets - Class in org.apache.beam.sdk.transforms
-
The
PTransforms that allow to compute different set functions acrossPCollections. - Sets() - Constructor for class org.apache.beam.sdk.transforms.Sets
- setSamplingStrategy(TextRowCountEstimator.SamplingStrategy) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
- setScalingFactor(double) - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObserver
-
Sets a multiplier to use on observed sizes.
- setScheduledExecutorService(ScheduledExecutorService) - Method in interface org.apache.beam.sdk.options.ExecutorOptions
- setSchema(Schema, TypeDescriptor<T>, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Method in class org.apache.beam.sdk.values.PCollection
-
Sets a
Schemaon thisPCollection. - setSdkHarnessLogLevelOverrides(SdkHarnessOptions.SdkHarnessLogLevelOverrides) - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
- setSdkWorkerParallelism(int) - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
- setSeconds(Long) - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate.Builder
- setSemiPersistDir(String) - Method in interface org.apache.beam.sdk.options.RemoteEnvironmentOptions
- setShardTemplate(String) - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration.Builder
- setSideInput(PCollectionView<T>, BoundedWindow, T) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - setSideInputId(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SideInputParameter.Builder
- setSideInputs(Map<PCollectionView<?>, Map<BoundedWindow, ?>>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - setSizeBytes(long) - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
- setSkipHeaderLines(int) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
- setStableUniqueNames(PipelineOptions.CheckEnabled) - Method in interface org.apache.beam.sdk.options.PipelineOptions
- setStart(Long) - Method in class org.apache.beam.sdk.io.GenerateSequence.External.ExternalConfiguration
- setStart(Long) - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Builder
- SetState<T> - Interface in org.apache.beam.sdk.state
-
A
ReadableStatecell containing a set of elements. - setStop(Long) - Method in class org.apache.beam.sdk.io.GenerateSequence.External.ExternalConfiguration
- setStreaming(boolean) - Method in interface org.apache.beam.sdk.options.StreamingOptions
- setTempLocation(String) - Method in interface org.apache.beam.sdk.options.PipelineOptions
- setTempRoot(String) - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
- SETTER_WITH_NULL_METHOD_ERROR - Static variable in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
- SetterTypeSupplier() - Constructor for class org.apache.beam.sdk.schemas.JavaBeanSchema.SetterTypeSupplier
- setTestTimeoutSeconds(Long) - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
- setTimer(Instant, TimeDomain) - Method in interface org.apache.beam.sdk.state.Timers
-
Sets a timer to fire when the event time watermark, the current processing time, or the synchronized processing time watermark surpasses a given timestamp.
- setTimer(Instant, Instant, TimeDomain) - Method in interface org.apache.beam.sdk.state.Timers
-
Set a timer with outputTimestamp.
- setTimestamp(Instant) - Method in interface org.apache.beam.sdk.values.OutputBuilder
- setTimestamp(Instant) - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- setTransformServiceAddress(String) - Method in interface org.apache.beam.sdk.util.construction.ExternalTranslationOptions
- setTransformServiceBeamVersion(String) - Method in interface org.apache.beam.sdk.util.construction.ExternalTranslationOptions
- setTransformsToOverride(List<String>) - Method in interface org.apache.beam.sdk.util.construction.ExternalTranslationOptions
- setType(Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Field.Builder
- setType(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
- setTypeDescriptor(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.values.PCollection
-
Sets the
TypeDescriptor<T>for thisPCollection<T>. - setup() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.Setupmethod. - setup() - Method in class org.apache.beam.sdk.transforms.Reshuffle.AssignShardFn
- setup(PipelineOptions) - Method in class org.apache.beam.sdk.util.construction.SplittableParDoNaiveBounded.NaiveProcessFn
- setUpdateCompatibilityVersion(String) - Method in interface org.apache.beam.sdk.options.StreamingOptions
- setUserAgent(String) - Method in interface org.apache.beam.sdk.options.PipelineOptions
- setUUID(UUID) - Method in class org.apache.beam.sdk.schemas.Schema
-
Set this schema's UUID.
- setValidate(boolean) - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformConfiguration.Builder
- setValue(T) - Method in interface org.apache.beam.sdk.values.OutputBuilder
- setValue(T) - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- setWatermark(Instant) - Method in interface org.apache.beam.sdk.transforms.splittabledofn.ManualWatermarkEstimator
-
Sets a timestamp before or at the timestamps of all future elements produced by the associated DoFn.
- setWatermark(Instant) - Method in class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.Manual
- setWindow(BoundedWindow) - Method in interface org.apache.beam.sdk.values.OutputBuilder
- setWindow(BoundedWindow) - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- setWindowedWrites() - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
-
Indicates that the operation will be performing windowed writes.
- setWindowingStrategyInternal(WindowingStrategy<?, ?>) - Method in class org.apache.beam.sdk.values.PCollection
-
For internal use only; no backwards-compatibility guarantees.
- setWindows(Collection<? extends BoundedWindow>) - Method in interface org.apache.beam.sdk.values.OutputBuilder
- setWindows(Collection<? extends BoundedWindow>) - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- SHARDED_KEY_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- ShardedFile - Interface in org.apache.beam.sdk.util
-
Bare-bones class for using sharded files.
- ShardedKey<K> - Class in org.apache.beam.sdk.util
-
A sharded key consisting of a user key and an opaque shard id represented by bytes.
- ShardedKey<K> - Class in org.apache.beam.sdk.values
-
Deprecated.
Use
ShardedKeyinstead. - ShardedKey(K, byte[]) - Constructor for class org.apache.beam.sdk.util.ShardedKey
- ShardedKey.Coder<K> - Class in org.apache.beam.sdk.util
- ShardedKeyCoder<KeyT> - Class in org.apache.beam.sdk.coders
- ShardedKeyCoder(Coder<KeyT>) - Constructor for class org.apache.beam.sdk.coders.ShardedKeyCoder
- ShardingFunction<UserT,DestinationT> - Interface in org.apache.beam.sdk.io
-
Function for assigning
ShardedKeys to input elements for shardedWriteFiles. - ShardingWritableByteChannel - Class in org.apache.beam.sdk.util
-
Implements a WritableByteChannel that may contain multiple output shards.
- ShardingWritableByteChannel() - Constructor for class org.apache.beam.sdk.util.ShardingWritableByteChannel
- ShardNameTemplate - Class in org.apache.beam.sdk.io
-
Standard shard naming templates.
- ShardNameTemplate() - Constructor for class org.apache.beam.sdk.io.ShardNameTemplate
- shortCircuitReturnNull(StackManipulation, StackManipulation) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
- shorts() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorfor Short. - shouldResume() - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContinuation
-
If false, the
DoFnpromises that there is no more work remaining for the current element, so the runner should not resume theDoFn.ProcessElementcall. - shouldSkipReplacement() - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
-
Returns whether a runner should skip replacing this transform.
- shutdown() - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- shutdownNow() - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- sideInput(String) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provide a reference to the input sideInput with the specified tag.
- sideInput(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- sideInput(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- sideInput(PCollectionView<SideInputT>) - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
-
Returns the value of a given side input.
- sideInput(PCollectionView<T>) - Method in interface org.apache.beam.sdk.state.StateContext
-
Returns the value of the side input for the corresponding state window.
- sideInput(PCollectionView<T>) - Method in class org.apache.beam.sdk.transforms.CombineWithContext.Context
-
Returns the value of the side input for the window corresponding to the main input's window in which values are being combined.
- sideInput(PCollectionView<T>) - Method in class org.apache.beam.sdk.transforms.Contextful.Fn.Context
-
Accesses the given side input.
- sideInput(PCollectionView<T>) - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContext
-
Returns the value of the side input.
- sideInputId() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SideInputParameter
- sideInputParameter(TypeDescriptor<?>, String) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- SideInputReference - Class in org.apache.beam.sdk.util.construction.graph
-
A reference to a side input.
- SideInputReference() - Constructor for class org.apache.beam.sdk.util.construction.graph.SideInputReference
- signatureForDoFn(FnT) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- SimpleCombineFn(SerializableFunction<Iterable<V>, V>) - Constructor for class org.apache.beam.sdk.transforms.Combine.SimpleCombineFn
-
Deprecated.
- SimpleFunction<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
A
SerializableFunctionwhich is not a functional interface. - SimpleFunction() - Constructor for class org.apache.beam.sdk.transforms.SimpleFunction
- SimpleFunction(SerializableFunction<InputT, OutputT>) - Constructor for class org.apache.beam.sdk.transforms.SimpleFunction
- SimpleIdentifierContext(FieldSpecifierNotationParser.DotExpressionComponentContext) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.SimpleIdentifierContext
- simpleTypeDescription(Type) - Static method in class org.apache.beam.sdk.util.common.ReflectHelpers
-
A
Functionthat formats types. - SINGLE_FILE_OR_SUBRANGE - org.apache.beam.sdk.io.FileBasedSource.Mode
- SingleInputOutputOverrideFactory<InputT extends PValue,OutputT extends PValue,TransformT extends PTransform<InputT,OutputT>> - Class in org.apache.beam.sdk.util.construction
- SingleInputOutputOverrideFactory() - Constructor for class org.apache.beam.sdk.util.construction.SingleInputOutputOverrideFactory
- singleton(Map<TupleTag<?>, PCollection<?>>, POutput) - Static method in class org.apache.beam.sdk.util.construction.ReplacementOutputs
- singletonView(PCollection<T>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>, boolean, T, Coder<T>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<T>capable of processing elements windowed using the providedWindowingStrategy. - singletonViewUsingVoidKey(TupleTag<Materializations.MultimapView<Void, T>>, PCollection<KV<Void, T>>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>, boolean, T, Coder<T>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
- sink - Variable in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
-
The Sink that this WriteOperation will write to.
- sink() - Static method in class org.apache.beam.sdk.io.TextIO
-
Creates a
TextIO.Sinkthat writes newline-delimited strings in UTF-8, for use withFileIO.write(). - sink() - Static method in class org.apache.beam.sdk.io.TFRecordIO
- Sink() - Constructor for class org.apache.beam.sdk.io.TextIO.Sink
- Sink() - Constructor for class org.apache.beam.sdk.io.TFRecordIO.Sink
- SINK - org.apache.beam.sdk.metrics.Lineage.Type
- SinkMetrics - Class in org.apache.beam.sdk.metrics
-
Standard Sink Metrics.
- SinkMetrics() - Constructor for class org.apache.beam.sdk.metrics.SinkMetrics
- SINKV2 - org.apache.beam.sdk.metrics.Lineage.Type
- size() - Method in class org.apache.beam.sdk.fn.data.WeightedList
- size() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- size() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
-
Returns the number of columns for this schema.
- size() - Method in class org.apache.beam.sdk.util.ByteStringOutputStream
-
Returns the current size of the output stream.
- size() - Method in class org.apache.beam.sdk.values.PCollectionList
-
Returns the number of
PCollectionsin thisPCollectionList. - size() - Method in class org.apache.beam.sdk.values.TupleTagList
-
Returns the number of TupleTags in this TupleTagList.
- sizeBytes() - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata
- SKIP - org.apache.beam.sdk.io.FileIO.ReadMatches.DirectoryTreatment
- SKIP_IF_DESTINATION_EXISTS - org.apache.beam.sdk.io.fs.MoveOptions.StandardMoveOptions
- skipIfEmpty() - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Don't write any output files if the PCollection is empty.
- sleep(long) - Method in interface org.apache.beam.sdk.util.Sleeper
-
Causes the currently executing thread to sleep (temporarily cease execution) for the specified number of milliseconds as specified in
Thread.sleep(long). - Sleeper - Interface in org.apache.beam.sdk.util
-
Sleeper interface to use for requesting the current thread to sleep as specified in
Thread.sleep(long). - SLIDING_WINDOWS_URN - Static variable in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- SlidingWindows - Class in org.apache.beam.sdk.transforms.windowing
-
A
WindowFnthat windows values into possibly overlapping fixed-size timestamp-based windows. - smallest(int) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a
PTransformthat takes an inputPCollection<T>and returns aPCollection<List<T>>with a single element containing the smallestcountelements of the inputPCollection<T>, in increasing order, sorted according to their natural order. - Smallest() - Constructor for class org.apache.beam.sdk.transforms.Top.Smallest
-
Deprecated.
- smallestDoublesFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a
Top.TopCombineFnthat aggregates the smallest count double values. - smallestFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a
Top.TopCombineFnthat aggregates the smallest count values. - smallestIntsFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a
Top.TopCombineFnthat aggregates the smallest count int values. - smallestLongsFn(int) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a
Top.TopCombineFnthat aggregates the smallest count long values. - smallestPerKey(int) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a
PTransformthat takes an inputPCollection<KV<K, V>>and returns aPCollection<KV<K, List<V>>>that contains an output element mapping each distinct key in the inputPCollectionto the smallestcountvalues associated with that key in the inputPCollection<KV<K, V>>, in increasing order, sorted according to their natural order. - SNAPPY - org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.
- SNAPPY - org.apache.beam.sdk.io.Compression
-
Google Snappy compression.
- SNAPPY - org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.
- SnappyCoder<T> - Class in org.apache.beam.sdk.coders
-
Wraps an existing coder with Snappy compression.
- SocketAddressFactory - Class in org.apache.beam.sdk.fn.channel
-
Creates a
SocketAddressbased upon a supplied string. - SocketAddressFactory() - Constructor for class org.apache.beam.sdk.fn.channel.SocketAddressFactory
- sortBySchema(List<FieldValueTypeInformation>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.StaticSchemaInference
- sorted() - Method in class org.apache.beam.sdk.schemas.Schema
-
Returns an identical Schema with lexicographically sorted fields.
- sorted() - Method in class org.apache.beam.sdk.values.Row
-
Returns an equivalent
Rowwith fields lexicographically sorted by their name. - SortedMapCoder<K extends java.lang.Comparable<? super K>,V> - Class in org.apache.beam.sdk.coders
-
A
CoderforMapsthat encodes them according to provided coders for keys and values. - Source<T> - Class in org.apache.beam.sdk.io
-
Base class for defining input formats and creating a
Sourcefor reading the input. - Source() - Constructor for class org.apache.beam.sdk.io.Source
- SOURCE - org.apache.beam.sdk.metrics.Lineage.Type
- Source.Reader<T> - Class in org.apache.beam.sdk.io
-
The interface that readers of custom input sources must implement.
- sourceIsBounded(AppliedPTransform<?, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.ReadTranslation
- SourceMetrics - Class in org.apache.beam.sdk.metrics
-
Standard
SourceMetrics. - SourceMetrics() - Constructor for class org.apache.beam.sdk.metrics.SourceMetrics
- SourceTestUtils - Class in org.apache.beam.sdk.testing
-
Helper functions and test harnesses for checking correctness of
Sourceimplementations. - SourceTestUtils() - Constructor for class org.apache.beam.sdk.testing.SourceTestUtils
- SourceTestUtils.ExpectedSplitOutcome - Enum in org.apache.beam.sdk.testing
-
Expected outcome of
BoundedSource.BoundedReader.splitAtFraction(double). - SOURCEV2 - org.apache.beam.sdk.metrics.Lineage.Type
- span(IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
-
Returns the minimal window that includes both this window and the given window.
- specification() - Method in enum org.apache.beam.sdk.util.construction.Environments.JavaVersion
- split(int) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
-
Returns a list of up to
numSplits + 1ByteKeysin ascending order, where the keys have been interpolated to form roughly equal sub-ranges of thisByteKeyRange, assuming a uniform distribution of keys within this range. - split(int, PipelineOptions) - Method in class org.apache.beam.sdk.io.UnboundedSource
-
Returns a list of
UnboundedSourceobjects representing the instances of this source that should be used when executing the workflow. - split(int, PipelineOptions) - Method in class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter
- split(long, long) - Method in class org.apache.beam.sdk.io.range.OffsetRange
- split(long, PipelineOptions) - Method in class org.apache.beam.sdk.io.BoundedSource
-
Splits the source into bundles of approximately
desiredBundleSizeBytes. - split(long, PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSource
- split(long, PipelineOptions) - Method in class org.apache.beam.sdk.io.OffsetBasedSource
- split(String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.SplitPTransformthat splits a string on the regular expression and then outputs each item. - split(String, boolean) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.SplitPTransformthat splits a string on the regular expression and then outputs each item. - split(Pattern) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.SplitPTransformthat splits a string on the regular expression and then outputs each item. - split(Pattern, boolean) - Static method in class org.apache.beam.sdk.transforms.Regex
-
Returns a
Regex.SplitPTransformthat splits a string on the regular expression and then outputs each item. - Split(Pattern, boolean) - Constructor for class org.apache.beam.sdk.transforms.Regex.Split
- SPLIT_POINTS_UNKNOWN - Static variable in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
-
A constant to use as the return value for
BoundedSource.BoundedReader.getSplitPointsConsumed()orBoundedSource.BoundedReader.getSplitPointsRemaining()when the exact value is unknown. - splitAtFraction(double) - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
-
Tells the reader to narrow the range of the input it's going to read and give up the remainder, so that the new range would contain approximately the given fraction of the amount of data in the current range.
- splitAtFraction(double) - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
- SplitIntoRangesFn(long) - Constructor for class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform.SplitIntoRangesFn
- splitRestriction() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.SplitRestrictionmethod. - SplitRestrictionMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.SplitRestrictionMethod
- SplitResult<RestrictionT> - Class in org.apache.beam.sdk.transforms.splittabledofn
-
A representation of a split result.
- SplitResult() - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.SplitResult
- SPLITTABLE_GBKIKWI_URN - Static variable in class org.apache.beam.sdk.util.construction.SplittableParDo
- SPLITTABLE_PAIR_WITH_RESTRICTION_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- SPLITTABLE_PROCESS_ELEMENTS_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
-
Deprecated.runners should move away from using `SplittableProcessElements` and prefer to internalize any necessary SplittableDoFn expansion.
- SPLITTABLE_PROCESS_KEYED_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
-
Deprecated.runners should move away from using `SplittableProcessKeyedElements` and prefer to internalize any necessary SplittableDoFn expansion.
- SPLITTABLE_PROCESS_SIZED_ELEMENTS_AND_RESTRICTIONS_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- SPLITTABLE_PROCESS_URN - Static variable in class org.apache.beam.sdk.util.construction.SplittableParDo
- SPLITTABLE_SPLIT_AND_SIZE_RESTRICTIONS_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- SPLITTABLE_TRUNCATE_SIZED_RESTRICTION_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- splittableParDo() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
- SplittableParDo<InputT,OutputT,RestrictionT,WatermarkEstimatorStateT> - Class in org.apache.beam.sdk.util.construction
-
A utility transform that executes a splittable
DoFnby expanding it into a network of simpler transforms: Pair each element with an initial restriction Split each restriction into sub-restrictions Explode windows, since splitting within each window has to happen independently Assign a unique key to each element/restriction pair Process the keyed element/restriction pairs in a runner-specific way with the splittableDoFn'sDoFn.ProcessElementmethod. - SplittableParDo.OverrideFactory<InputT,OutputT> - Class in org.apache.beam.sdk.util.construction
- SplittableParDo.PrimitiveBoundedRead<T> - Class in org.apache.beam.sdk.util.construction
-
The original primitive based
Read.Boundedexpansion. - SplittableParDo.PrimitiveUnboundedRead<T> - Class in org.apache.beam.sdk.util.construction
-
The original primitive based
Read.Unboundedexpansion. - SplittableParDo.ProcessKeyedElements<InputT,OutputT,RestrictionT,WatermarkEstimatorStateT> - Class in org.apache.beam.sdk.util.construction
-
Runner-specific primitive
PTransformthat invokes theDoFn.ProcessElementmethod for a splittableDoFnon eachKVof the inputPCollectionofKVskeyed with arbitrary but globally unique keys. - SplittableParDo.ProcessKeyedElementsTranslator - Class in org.apache.beam.sdk.util.construction
-
A translator for
SplittableParDo.ProcessKeyedElements. - SplittableParDo.Registrar - Class in org.apache.beam.sdk.util.construction
- SplittableParDoExpander - Class in org.apache.beam.sdk.util.construction.graph
-
A set of transform replacements for expanding a splittable ParDo into various sub components.
- SplittableParDoExpander() - Constructor for class org.apache.beam.sdk.util.construction.graph.SplittableParDoExpander
- splittableParDoMulti() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
A
PTransformMatcherthat matches aParDo.MultiOutputcontaining aDoFnthat is splittable, as signified byDoFnSignature.ProcessElementMethod.isSplittable(). - SplittableParDoNaiveBounded - Class in org.apache.beam.sdk.util.construction
-
Utility transforms and overrides for running bounded splittable DoFn's naively, by implementing
SplittableParDo.ProcessKeyedElementsusing a simpleReshuffleandParDo. - SplittableParDoNaiveBounded() - Constructor for class org.apache.beam.sdk.util.construction.SplittableParDoNaiveBounded
- SplittableParDoNaiveBounded.NaiveProcessFn<InputT,OutputT,RestrictionT,PositionT,WatermarkEstimatorStateT> - Class in org.apache.beam.sdk.util.construction
- SplittableParDoNaiveBounded.OverrideFactory<InputT,OutputT,RestrictionT,WatermarkEstimatorStateT> - Class in org.apache.beam.sdk.util.construction
-
Overrides a
SplittableParDo.ProcessKeyedElementsintoSplittableParDoNaiveBounded.SplittableProcessNaive. - splittableParDoSingle() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
A
PTransformMatcherthat matches aParDo.SingleOutputcontaining aDoFnthat is splittable, as signified byDoFnSignature.ProcessElementMethod.isSplittable(). - splittableProcessKeyedBounded() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
A
PTransformMatcherthat matches aParDo.SingleOutputcontaining aDoFnthat is splittable, as signified byDoFnSignature.ProcessElementMethod.isSplittable(). - splittableProcessKeyedUnbounded() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
A
PTransformMatcherthat matches aParDo.SingleOutputcontaining aDoFnthat is splittable, as signified byDoFnSignature.ProcessElementMethod.isSplittable(). - SqlTypes - Class in org.apache.beam.sdk.schemas.logicaltypes
-
Beam
Schema.LogicalTypes corresponding to SQL data types. - StandardCreateOptions() - Constructor for class org.apache.beam.sdk.io.fs.CreateOptions.StandardCreateOptions
- start() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataOutboundAggregator
-
Starts the flushing daemon thread if data_buffer_time_limit_ms is set.
- start() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
- start() - Method in class org.apache.beam.sdk.io.Source.Reader
-
Initializes the reader and advances the reader to the first record.
- start() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
-
Initializes the reader and advances the reader to the first record.
- start() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
-
Returns the start of this window, inclusive.
- startAt(Instant) - Method in class org.apache.beam.sdk.transforms.PeriodicImpulse
-
Assign a timestamp when the pipeliene starts to produce data.
- startBundle() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - startBundle() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.StartBundlemethod. - startBundle(DoFn.StartBundleContext) - Method in class org.apache.beam.sdk.util.construction.SplittableParDoNaiveBounded.NaiveProcessFn
- startBundleContext() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- startBundleContext(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provide a
DoFn.StartBundleContextto use with the givenDoFn. - startBundleContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- startBundleContext(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- StartBundleContext() - Constructor for class org.apache.beam.sdk.transforms.DoFn.StartBundleContext
- startImpl() - Method in class org.apache.beam.sdk.io.FileBasedSource.FileBasedReader
- startImpl() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
-
Initializes the
OffsetBasedSource.OffsetBasedReaderand advances to the first record, returningtrueif there is a record available to be read. - startReading(ReadableByteChannel) - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
-
Creates a decompressing channel from the input channel and passes it to its delegate reader's
FileBasedSource.FileBasedReader.startReading(ReadableByteChannel). - startReading(ReadableByteChannel) - Method in class org.apache.beam.sdk.io.FileBasedSource.FileBasedReader
-
Performs any initialization of the subclass of
FileBasedReaderthat involves IO operations. - startsWith(String) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
A
SerializableMatcherwith identical criteria toMatchers.startsWith(java.lang.String). - state(String, boolean) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Returns the state cell for the given
DoFn.StateId. - state(String, boolean) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- state(String, boolean) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- State - Interface in org.apache.beam.sdk.state
-
A state cell, supporting a
State.clear()operation. - STATE_BACKED_ITERABLE_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- STATE_CACHE_SIZE - Static variable in interface org.apache.beam.sdk.options.ExperimentalOptions
- STATE_SAMPLING_PERIOD_MILLIS - Static variable in interface org.apache.beam.sdk.options.ExperimentalOptions
- StateBinder - Interface in org.apache.beam.sdk.state
-
For internal use only; no backwards-compatibility guarantees.
- StateContext<W extends BoundedWindow> - Interface in org.apache.beam.sdk.state
-
For internal use only; no backwards-compatibility guarantees.
- StateContexts - Class in org.apache.beam.sdk.state
-
For internal use only; no backwards-compatibility guarantees.
- StateContexts() - Constructor for class org.apache.beam.sdk.state.StateContexts
- StateDeclaration() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.StateDeclaration
- stateDeclarations() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about the state cells that this
DoFndeclares. - StateKeySpec - Class in org.apache.beam.sdk.state
- stateOrTimerParDo() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
A
PTransformMatcherthat matches aParDotransform by URN and whether it contains state or timers as specified byParDoTranslation. - stateOrTimerParDoMulti() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
A
PTransformMatcherthat matches aParDo.MultiOutputcontaining aDoFnthat uses state or timers, as specified byDoFnSignature.usesState()andDoFnSignature.usesTimers(). - stateOrTimerParDoSingle() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
A
PTransformMatcherthat matches aParDo.SingleOutputcontaining aDoFnthat uses state or timers, as specified byDoFnSignature.usesState()andDoFnSignature.usesTimers(). - stateParameter(DoFnSignature.StateDeclaration, boolean) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
-
Returns a
DoFnSignature.Parameter.StateParameterreferring to the givenDoFnSignature.StateDeclaration. - StateSpec<StateT extends State> - Interface in org.apache.beam.sdk.state
-
A specification of a persistent state cell.
- StateSpec.Cases<ResultT> - Interface in org.apache.beam.sdk.state
-
Cases for doing a "switch" on the type of
StateSpec. - StateSpec.Cases.WithDefault<ResultT> - Class in org.apache.beam.sdk.state
-
A base class for a visitor with a default method for cases it is not interested in.
- StateSpecs - Class in org.apache.beam.sdk.state
-
Static methods for working with
StateSpecs. - stateType() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.StateDeclaration
- StaticSchemaInference - Class in org.apache.beam.sdk.schemas.utils
-
A set of utilities for inferring a Beam
Schemafrom static Java types. - StaticSchemaInference() - Constructor for class org.apache.beam.sdk.schemas.utils.StaticSchemaInference
- status() - Method in class org.apache.beam.sdk.io.fs.MatchResult
-
Status of the
MatchResult. - stepName() - Method in class org.apache.beam.sdk.metrics.MetricKey
-
The step name that is associated with this metric or Null if none is associated.
- steps() - Method in class org.apache.beam.sdk.metrics.MetricsFilter
- stop() - Static method in class org.apache.beam.sdk.transforms.DoFn.ProcessContinuation
-
Indicates that there is no more work to be done for the current element.
- STOP - Static variable in interface org.apache.beam.sdk.util.BackOff
-
Indicates that no more retries should be made for use in
BackOff.nextBackOffMillis(). - STOP_BACKOFF - Static variable in interface org.apache.beam.sdk.util.BackOff
-
Fixed back-off policy that always returns
#STOPforBackOff.nextBackOffMillis(), meaning that the operation should not be retried. - stopAfter(Duration) - Method in class org.apache.beam.sdk.transforms.PeriodicImpulse
-
For internal use only; no backwards-compatibility guarantees.
- stopAt(Instant) - Method in class org.apache.beam.sdk.transforms.PeriodicImpulse
-
Assign a timestamp when the pipeliene stops producing data.
- STOPPED - org.apache.beam.sdk.PipelineResult.State
-
The job has been paused, or has not yet started.
- stopSampling(int, long) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.LimitNumberOfFiles
- stopSampling(int, long) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.LimitNumberOfTotalBytes
- stopSampling(int, long) - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.SampleAllFiles
- stopSampling(int, long) - Method in interface org.apache.beam.sdk.io.TextRowCountEstimator.SamplingStrategy
- StreamingIT - Interface in org.apache.beam.sdk.testing
-
Deprecated.tests which use unbounded PCollections should be in the category
UsesUnboundedPCollections. Beyond that, it is up to the runner and test configuration to decide whether to run in streaming mode. - StreamingOptions - Interface in org.apache.beam.sdk.options
-
Options used to configure streaming.
- StreamUtils - Class in org.apache.beam.sdk.util
-
Utility functions for stream operations.
- STRING - org.apache.beam.sdk.schemas.Schema.TypeName
- STRING - org.apache.beam.sdk.transforms.display.DisplayData.Type
- STRING - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
-
The type of string fields.
- STRING_TYPES - Static variable in enum org.apache.beam.sdk.schemas.Schema.TypeName
- STRING_UTF8_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- StringCompiler - Class in org.apache.beam.sdk.schemas.transforms.providers
- StringCompiler() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.StringCompiler
- StringCompiler.CompileException - Exception in org.apache.beam.sdk.schemas.transforms.providers
- StringDelegateCoder<T> - Class in org.apache.beam.sdk.coders
-
A
Coderthat wraps aCoder<String>and encodes/decodes values via string representations. - StringDelegateCoder(Class<T>, TypeDescriptor<T>) - Constructor for class org.apache.beam.sdk.coders.StringDelegateCoder
- strings() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
The
TypeDescriptorfor String. - stringSet(Class<?>, String) - Static method in class org.apache.beam.sdk.metrics.Metrics
-
Create a metric that accumulates and reports set of unique string values.
- stringSet(String, String) - Static method in class org.apache.beam.sdk.metrics.Metrics
-
Create a metric that accumulates and reports set of unique string values.
- StringSet - Interface in org.apache.beam.sdk.metrics
-
A metric that reports set of unique string values.
- StringSetResult - Class in org.apache.beam.sdk.metrics
-
The result of a
StringSetmetric. - StringSetResult() - Constructor for class org.apache.beam.sdk.metrics.StringSetResult
- StringSetResult.EmptyStringSetResult - Class in org.apache.beam.sdk.metrics
-
Empty
StringSetResult, representing no values reported and is immutable. - StringUtf8Coder - Class in org.apache.beam.sdk.coders
-
A
Coderthat encodesStringsin UTF-8 encoding. - StringUtils - Class in org.apache.beam.sdk.util
-
Utilities for working with JSON and other human-readable string formats.
- StringUtils() - Constructor for class org.apache.beam.sdk.util.StringUtils
- stripGetterPrefix(String) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
- StripIdsDoFn() - Constructor for class org.apache.beam.sdk.values.ValueWithRecordId.StripIdsDoFn
- stripPrefix(String, String) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
- stripSetterPrefix(String) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
- StructuralByteArray - Class in org.apache.beam.sdk.coders
-
A wrapper around a byte[] that uses structural, value-based equality rather than byte[]'s normal object identity.
- StructuralByteArray(byte[]) - Constructor for class org.apache.beam.sdk.coders.StructuralByteArray
- structuralValue(byte[]) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
-
Returns an object with an
Object.equals()method that represents structural equality on the argument. - structuralValue(T) - Method in class org.apache.beam.sdk.coders.NullableCoder
- structuralValue(Iterable<T>) - Method in class org.apache.beam.sdk.coders.IterableCoder
- structuralValue(Void) - Method in class org.apache.beam.sdk.coders.VoidCoder
- structuralValue(Deque<T>) - Method in class org.apache.beam.sdk.coders.DequeCoder
- structuralValue(List<T>) - Method in class org.apache.beam.sdk.coders.ListCoder
- structuralValue(Map<K, V>) - Method in class org.apache.beam.sdk.coders.MapCoder
- structuralValue(Optional<T>) - Method in class org.apache.beam.sdk.coders.OptionalCoder
- structuralValue(SortedMap<K, V>) - Method in class org.apache.beam.sdk.coders.SortedMapCoder
- structuralValue(ShardedKey<K>) - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
- structuralValue(KV<K, V>) - Method in class org.apache.beam.sdk.coders.KvCoder
- structuralValue(TimestampedValue<T>) - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
- structuralValue(T) - Method in class org.apache.beam.sdk.coders.Coder
-
Returns an object with an
Object.equals()method that represents structural equality on the argument. - structuralValue(T) - Method in class org.apache.beam.sdk.coders.DelegateCoder
-
Returns an object with an
Object.equals()method that represents structural equality on the argument. - structuralValue(T) - Method in class org.apache.beam.sdk.coders.SerializableCoder
-
The structural value of the object is the object itself.
- structuralValue(T) - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
- structuralValue(T) - Method in class org.apache.beam.sdk.coders.ZstdCoder
-
Returns an object with an
Object.equals()method that represents structural equality on the argument. - structuralValueConsistentWithEquals(Coder<T>, T, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
-
Verifies that for the given
Coder<T>and values of typeT, the structural values are equal if and only if the encoded bytes are equal. - structuralValueConsistentWithEqualsInContext(Coder<T>, Coder.Context, T, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
-
Verifies that for the given
Coder<T>,Coder.Context, and values of typeT, the structural values are equal if and only if the encoded bytes are equal, in anyCoder.Context. - structuralValueDecodeEncodeEqual(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
-
Verifies that for the given
Coder<T>and value of typeT, the structural value is equal to the structural value yield by encoding and decoding the original value. - structuralValueDecodeEncodeEqualInContext(Coder<T>, Coder.Context, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
-
Verifies that for the given
Coder<T>,Coder.Context, and value of typeT, the structural value is equal to the structural value yield by encoding and decoding the original value, in anyCoder.Context. - structuralValueDecodeEncodeEqualIterable(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
-
Verifies that for the given
Coder<T>and value of typeT, the structural value of the content of the Iterable is equal to the structural value yield by encoding and decoding the original value. - structuralValueDecodeEncodeEqualIterableInContext(Coder<T>, Coder.Context, T) - Static method in class org.apache.beam.sdk.testing.CoderProperties
-
Verifies that for the given
Coder<T>,Coder.Context, and value of typeT, the structural content of the Iterable of the value is equal to the structural value yield by encoding and decoding the original value, in anyCoder.Context. - StructuredCoder<T> - Class in org.apache.beam.sdk.coders
-
An abstract base class to implement a
Coderthat defines equality, hashing, and printing via the class name and recursively usingStructuredCoder.getComponents(). - StructuredCoder() - Constructor for class org.apache.beam.sdk.coders.StructuredCoder
- subclassGetterInterface(ByteBuddy, Type, Type) - Static method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils
- subclassHaverInterface(ByteBuddy, Class<?>) - Static method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils
- subclassSetterInterface(ByteBuddy, Type, Type) - Static method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils
- submit(Runnable) - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- submit(Runnable, T) - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- submit(Callable<T>) - Method in class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- subPathMatches(String, String) - Static method in class org.apache.beam.sdk.metrics.MetricFiltering
-
subPathMatches(haystack, needle)returns true ifneedlerepresents a path withinhaystack. - subTriggers - Variable in class org.apache.beam.sdk.transforms.windowing.Trigger
- subTriggers() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
- success() - Static method in class org.apache.beam.sdk.testing.SuccessOrFailure
- SUCCESS_COUNTER - Static variable in class org.apache.beam.sdk.testing.PAssert
- SuccessOrFailure - Class in org.apache.beam.sdk.testing
-
Output of
PAssert. - Sum - Class in org.apache.beam.sdk.transforms
-
PTransforms for computing the sum of the elements in aPCollection, or the sum of the values associated with each key in aPCollectionofKVs. - supplierForElement(WindowedValue<?>) - Static method in class org.apache.beam.sdk.util.OutputBuilderSuppliers
- supplyAsync(ThrowingSupplier<T>) - Static method in class org.apache.beam.sdk.util.MoreFutures
-
Shorthand for
MoreFutures.supplyAsync(ThrowingSupplier, ExecutorService)usingForkJoinPool.commonPool(). - supplyAsync(ThrowingSupplier<T>, ExecutorService) - Static method in class org.apache.beam.sdk.util.MoreFutures
-
Like
CompletableFuture.supplyAsync(Supplier)but forThrowingSupplier. - supportsProjectionPushdown() - Method in interface org.apache.beam.sdk.schemas.ProjectionProducer
-
Whether
thissupports projection pushdown. - surroundsGBEK() - Method in class org.apache.beam.sdk.transforms.GroupByKey
-
For Beam internal use only.
- synchronize(RestrictionTracker<RestrictionT, PositionT>) - Static method in class org.apache.beam.sdk.fn.splittabledofn.RestrictionTrackers
- SYNCHRONIZED_PROCESSING_TIME - org.apache.beam.sdk.state.TimeDomain
-
For internal use only; no backwards compatibility guarantees.
- SynchronizedStreamObserver<V> - Class in org.apache.beam.sdk.fn.stream
-
A
StreamObserverwhich provides synchronous access access to an underlyingStreamObserver. - SyntheticComponents - Class in org.apache.beam.sdk.util.construction
-
A utility class to interact with synthetic pipeline components.
- SystemDoFnInternal - Annotation Type in org.apache.beam.sdk.util
-
Annotation to mark
DoFnsas an internal component of the Beam SDK.
T
- T__0 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- T__0 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- T__1 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- T__1 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- T__2 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- T__2 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- T__3 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- T__3 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- T__4 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- T__4 - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- tagged(Map<TupleTag<?>, PCollection<?>>, POutput) - Static method in class org.apache.beam.sdk.util.construction.ReplacementOutputs
- TaggedKeyedPCollection(TupleTag<V>, PCollection<KV<K, V>>) - Constructor for class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple.TaggedKeyedPCollection
- taggedOutputReceiver(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provide a
DoFn.MultiOutputReceiverfor outputting to the default output. - taggedOutputReceiver(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- taggedOutputReceiver(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- taggedOutputReceiverParameter() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- TaggedPValue - Class in org.apache.beam.sdk.values
-
For internal use only; no backwards-compatibility guarantees.
- TaggedPValue() - Constructor for class org.apache.beam.sdk.values.TaggedPValue
- take() - Method in class org.apache.beam.sdk.fn.CancellableQueue
-
Takes an element from this queue.
- takeOutputElements() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - takeOutputElements(TupleTag<T>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - takeOutputElementsWithTimestamp() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
Deprecated.Use
TestPipelinewith theDirectRunner. - targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.BundleMethod
-
The annotated method itself.
- targetMethod() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.DoFnMethod
-
The annotated method itself.
- targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialRestrictionMethod
-
The annotated method itself.
- targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialWatermarkEstimatorStateMethod
-
The annotated method itself.
- targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetRestrictionCoderMethod
-
The annotated method itself.
- targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetSizeMethod
-
The annotated method itself.
- targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetWatermarkEstimatorStateCoderMethod
-
The annotated method itself.
- targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.LifecycleMethod
-
The annotated method itself.
- targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewTrackerMethod
-
The annotated method itself.
- targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewWatermarkEstimatorMethod
-
The annotated method itself.
- targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerFamilyMethod
-
The annotated method itself.
- targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerMethod
-
The annotated method itself.
- targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnWindowExpirationMethod
-
The annotated method itself.
- targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
-
The annotated method itself.
- targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.SplitRestrictionMethod
-
The annotated method itself.
- targetMethod() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TruncateRestrictionMethod
-
The annotated method itself.
- teardown() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.Teardownmethod. - teardown() - Method in class org.apache.beam.sdk.util.construction.SplittableParDoNaiveBounded.NaiveProcessFn
- Tee<T> - Class in org.apache.beam.sdk.transforms
-
A PTransform that returns its input, but also applies its input to an auxiliary PTransform, akin to the shell
teecommand, which is named after the T-splitter used in plumbing. - test(RunnerApi.PTransform) - Method in interface org.apache.beam.sdk.util.construction.NativeTransforms.IsNativeTransform
- TEST_STREAM_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- testByteCount(Coder<T>, Coder.Context, T[]) - Static method in class org.apache.beam.sdk.testing.CoderProperties
-
A utility method that passes the given (unencoded) elements through coder's registerByteSizeObserver() and encode() methods, and confirms they are mutually consistent.
- testCombineFn(Combine.CombineFn<InputT, AccumT, OutputT>, List<InputT>, Matcher<? super OutputT>) - Static method in class org.apache.beam.sdk.testing.CombineFnTester
- testCombineFn(Combine.CombineFn<InputT, AccumT, OutputT>, List<InputT>, OutputT) - Static method in class org.apache.beam.sdk.testing.CombineFnTester
-
Tests that the
Combine.CombineFn, when applied to the provided input, produces the provided output. - TestElementByteSizeObserver() - Constructor for class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
- TestExecutors - Class in org.apache.beam.sdk.fn.test
-
A
TestRulethat validates that all submitted tasks finished and were completed. - TestExecutors() - Constructor for class org.apache.beam.sdk.fn.test.TestExecutors
- TestExecutors.TestExecutorService - Interface in org.apache.beam.sdk.fn.test
-
A union of the
ExecutorServiceandTestRuleinterfaces. - testingPipelineOptions() - Static method in class org.apache.beam.sdk.testing.TestPipeline
-
Creates
PipelineOptionsfor testing. - TestOutputReceiver<T> - Class in org.apache.beam.sdk.testing
-
An implementation of
DoFn.OutputReceiverthat naively collects all output values. - TestOutputReceiver() - Constructor for class org.apache.beam.sdk.testing.TestOutputReceiver
- TestPipeline - Class in org.apache.beam.sdk.testing
-
A creator of test pipelines that can be used inside of tests that can be configured to run locally or against a remote pipeline runner.
- TestPipeline.AbandonedNodeException - Exception in org.apache.beam.sdk.testing
-
An exception thrown in case an abandoned
PTransformis detected, that is, aPTransformthat has not been run. - TestPipeline.PipelineRunMissingException - Exception in org.apache.beam.sdk.testing
-
An exception thrown in case a test finishes without invoking
Pipeline.run(). - TestPipeline.TestValueProviderOptions - Interface in org.apache.beam.sdk.testing
-
Implementation detail of
TestPipeline.newProvider(T), do not use. - TestPipelineOptions - Interface in org.apache.beam.sdk.testing
-
TestPipelineOptionsis a set of options for test pipelines. - TestPipelineOptions.AlwaysPassMatcher - Class in org.apache.beam.sdk.testing
-
Matcher which will always pass.
- TestPipelineOptions.AlwaysPassMatcherFactory - Class in org.apache.beam.sdk.testing
-
Factory for
PipelineResultmatchers which always pass. - TestStream<T> - Class in org.apache.beam.sdk.testing
-
A testing input that generates an unbounded
PCollectionof elements, advancing the watermark and processing time as elements are emitted. - TestStream.Builder<T> - Class in org.apache.beam.sdk.testing
-
An incomplete
TestStream. - TestStream.ElementEvent<T> - Class in org.apache.beam.sdk.testing
-
A
TestStream.Eventthat produces elements. - TestStream.Event<T> - Interface in org.apache.beam.sdk.testing
-
An event in a
TestStream. - TestStream.EventType - Enum in org.apache.beam.sdk.testing
-
The types of
TestStream.Eventthat are supported byTestStream. - TestStream.ProcessingTimeEvent<T> - Class in org.apache.beam.sdk.testing
-
A
TestStream.Eventthat advances the processing time clock. - TestStream.TestStreamCoder<T> - Class in org.apache.beam.sdk.testing
-
Coder for
TestStream. - TestStream.WatermarkEvent<T> - Class in org.apache.beam.sdk.testing
-
A
TestStream.Eventthat advances the watermark. - testStreamFromProtoPayload(RunnerApi.TestStreamPayload, Coder<T>) - Static method in class org.apache.beam.sdk.util.construction.TestStreamTranslation
- testStreamFromProtoPayload(RunnerApi.TestStreamPayload, RehydratedComponents) - Static method in class org.apache.beam.sdk.util.construction.TestStreamTranslation
- TestStreams - Class in org.apache.beam.sdk.fn.test
-
Utility methods which enable testing of
StreamObservers. - TestStreams() - Constructor for class org.apache.beam.sdk.fn.test.TestStreams
- TestStreams.Builder<T> - Class in org.apache.beam.sdk.fn.test
-
A builder for a test
CallStreamObserverthat performs various callbacks. - TestStreamTranslation - Class in org.apache.beam.sdk.util.construction
-
Utility methods for translating a
TestStreamto and fromRunnerApirepresentations. - TestStreamTranslation() - Constructor for class org.apache.beam.sdk.util.construction.TestStreamTranslation
- TEXT - Static variable in class org.apache.beam.sdk.util.MimeTypes
- TextIO - Class in org.apache.beam.sdk.io
-
PTransforms for reading and writing text files. - TextIO.CompressionType - Enum in org.apache.beam.sdk.io
-
Deprecated.Use
Compression. - TextIO.Read - Class in org.apache.beam.sdk.io
-
Implementation of
TextIO.read(). - TextIO.ReadAll - Class in org.apache.beam.sdk.io
-
Deprecated.See
TextIO.readAll()for details. - TextIO.ReadFiles - Class in org.apache.beam.sdk.io
-
Implementation of
TextIO.readFiles(). - TextIO.Sink - Class in org.apache.beam.sdk.io
-
Implementation of
TextIO.sink(). - TextIO.TypedWrite<UserT,DestinationT> - Class in org.apache.beam.sdk.io
-
Implementation of
TextIO.write(). - TextIO.Write - Class in org.apache.beam.sdk.io
-
This class is used as the default return value of
TextIO.write(). - TextRowCountEstimator - Class in org.apache.beam.sdk.io
-
This returns a row count estimation for files associated with a file pattern.
- TextRowCountEstimator() - Constructor for class org.apache.beam.sdk.io.TextRowCountEstimator
- TextRowCountEstimator.Builder - Class in org.apache.beam.sdk.io
-
Builder for
TextRowCountEstimator. - TextRowCountEstimator.LimitNumberOfFiles - Class in org.apache.beam.sdk.io
-
This strategy stops sampling if we sample enough number of bytes.
- TextRowCountEstimator.LimitNumberOfTotalBytes - Class in org.apache.beam.sdk.io
-
This strategy stops sampling when total number of sampled bytes are more than some threshold.
- TextRowCountEstimator.NoEstimationException - Exception in org.apache.beam.sdk.io
-
An exception that will be thrown if the estimator cannot get an estimation of the number of lines.
- TextRowCountEstimator.SampleAllFiles - Class in org.apache.beam.sdk.io
-
This strategy samples all the files.
- TextRowCountEstimator.SamplingStrategy - Interface in org.apache.beam.sdk.io
-
Sampling Strategy shows us when should we stop reading further files.
- TextSource - Class in org.apache.beam.sdk.io
-
Implementation detail of
TextIO.Read. - TextSource(MatchResult.Metadata, long, long, byte[]) - Constructor for class org.apache.beam.sdk.io.TextSource
- TextSource(MatchResult.Metadata, long, long, byte[], int) - Constructor for class org.apache.beam.sdk.io.TextSource
- TextSource(ValueProvider<String>, EmptyMatchTreatment, byte[]) - Constructor for class org.apache.beam.sdk.io.TextSource
- TextSource(ValueProvider<String>, EmptyMatchTreatment, byte[], int) - Constructor for class org.apache.beam.sdk.io.TextSource
- TextualIntegerCoder - Class in org.apache.beam.sdk.coders
-
A
Coderthat encodesInteger Integersas the ASCII bytes of their textual, decimal, representation. - TextualIntegerCoder() - Constructor for class org.apache.beam.sdk.coders.TextualIntegerCoder
- TFRecordIO - Class in org.apache.beam.sdk.io
-
PTransforms for reading and writing TensorFlow TFRecord files. - TFRecordIO.CompressionType - Enum in org.apache.beam.sdk.io
-
Deprecated.Use
Compression. - TFRecordIO.Read - Class in org.apache.beam.sdk.io
-
Implementation of
TFRecordIO.read(). - TFRecordIO.ReadFiles - Class in org.apache.beam.sdk.io
-
Implementation of
TFRecordIO.readFiles(). - TFRecordIO.Sink - Class in org.apache.beam.sdk.io
- TFRecordIO.Write - Class in org.apache.beam.sdk.io
-
Implementation of
TFRecordIO.write(). - TFRecordReadSchemaTransformConfiguration - Class in org.apache.beam.sdk.io
-
Configuration for reading from TFRecord.
- TFRecordReadSchemaTransformConfiguration() - Constructor for class org.apache.beam.sdk.io.TFRecordReadSchemaTransformConfiguration
- TFRecordReadSchemaTransformConfiguration.Builder - Class in org.apache.beam.sdk.io
-
Builder for
TFRecordReadSchemaTransformConfiguration. - TFRecordReadSchemaTransformProvider - Class in org.apache.beam.sdk.io
- TFRecordReadSchemaTransformProvider() - Constructor for class org.apache.beam.sdk.io.TFRecordReadSchemaTransformProvider
- TFRecordReadSchemaTransformProvider.ErrorFn - Class in org.apache.beam.sdk.io
- TFRecordReadSchemaTransformTranslator() - Constructor for class org.apache.beam.sdk.io.TFRecordSchemaTransformTranslation.TFRecordReadSchemaTransformTranslator
- TFRecordSchemaTransformTranslation - Class in org.apache.beam.sdk.io
- TFRecordSchemaTransformTranslation() - Constructor for class org.apache.beam.sdk.io.TFRecordSchemaTransformTranslation
- TFRecordSchemaTransformTranslation.ReadWriteRegistrar - Class in org.apache.beam.sdk.io
- TFRecordSchemaTransformTranslation.TFRecordReadSchemaTransformTranslator - Class in org.apache.beam.sdk.io
- TFRecordSchemaTransformTranslation.TFRecordWriteSchemaTransformTranslator - Class in org.apache.beam.sdk.io
- TFRecordWriteSchemaTransformConfiguration - Class in org.apache.beam.sdk.io
-
Configuration for reading from TFRecord.
- TFRecordWriteSchemaTransformConfiguration() - Constructor for class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration
- TFRecordWriteSchemaTransformConfiguration.Builder - Class in org.apache.beam.sdk.io
- TFRecordWriteSchemaTransformProvider - Class in org.apache.beam.sdk.io
- TFRecordWriteSchemaTransformProvider() - Constructor for class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformProvider
- TFRecordWriteSchemaTransformProvider.ErrorFn - Class in org.apache.beam.sdk.io
- TFRecordWriteSchemaTransformTranslator() - Constructor for class org.apache.beam.sdk.io.TFRecordSchemaTransformTranslation.TFRecordWriteSchemaTransformTranslator
- that(String, PCollection<T>) - Static method in class org.apache.beam.sdk.testing.PAssert
-
Constructs an
PAssert.IterableAssertfor the elements of the providedPCollectionwith the specified reason. - that(PCollection<T>) - Static method in class org.apache.beam.sdk.testing.PAssert
-
Constructs an
PAssert.IterableAssertfor the elements of the providedPCollection. - thatFlattened(String, PCollectionList<T>) - Static method in class org.apache.beam.sdk.testing.PAssert
-
Constructs an
PAssert.IterableAssertfor the elements of the flattenedPCollectionListwith the specified reason. - thatFlattened(PCollectionList<T>) - Static method in class org.apache.beam.sdk.testing.PAssert
-
Constructs an
PAssert.IterableAssertfor the elements of the flattenedPCollectionList. - thatList(PCollectionList<T>) - Static method in class org.apache.beam.sdk.testing.PAssert
-
Constructs an
PAssert.PCollectionListContentsAssertfor the providedPCollectionList. - thatMap(String, PCollection<KV<K, V>>) - Static method in class org.apache.beam.sdk.testing.PAssert
-
Constructs a
PAssert.SingletonAssertfor the value of the providedPCollectionwith the specified reason. - thatMap(PCollection<KV<K, V>>) - Static method in class org.apache.beam.sdk.testing.PAssert
-
Constructs a
PAssert.SingletonAssertfor the value of the providedPCollection, which must have at most one value per key. - thatMultimap(String, PCollection<KV<K, V>>) - Static method in class org.apache.beam.sdk.testing.PAssert
-
Constructs a
PAssert.SingletonAssertfor the value of the providedPCollectionwith the specified reason. - thatMultimap(PCollection<KV<K, V>>) - Static method in class org.apache.beam.sdk.testing.PAssert
-
Constructs a
PAssert.SingletonAssertfor the value of the providedPCollection. - thatSingleton(String, PCollection<T>) - Static method in class org.apache.beam.sdk.testing.PAssert
-
Constructs a
PAssert.SingletonAssertfor the value of the providedPCollection PCollection<T>with the specified reason. - thatSingleton(PCollection<T>) - Static method in class org.apache.beam.sdk.testing.PAssert
-
Constructs a
PAssert.SingletonAssertfor the value of the providedPCollection PCollection<T>, which must be a singleton. - thatSingletonIterable(String, PCollection<? extends Iterable<T>>) - Static method in class org.apache.beam.sdk.testing.PAssert
-
Constructs an
PAssert.IterableAssertfor the value of the providedPCollectionwith the specified reason. - thatSingletonIterable(PCollection<? extends Iterable<T>>) - Static method in class org.apache.beam.sdk.testing.PAssert
-
Constructs an
PAssert.IterableAssertfor the value of the providedPCollectionwhich must contain a singleIterable<T>value. - threadSafe(WatermarkEstimator<WatermarkEstimatorStateT>) - Static method in class org.apache.beam.sdk.fn.splittabledofn.WatermarkEstimators
-
Returns a thread safe
WatermarkEstimatorwhich allows getting a snapshot of the current watermark and watermark estimator state. - THROTTLE_TIME_COUNTER_NAME - Static variable in class org.apache.beam.sdk.metrics.Metrics
- THROTTLE_TIME_NAMESPACE - Static variable in class org.apache.beam.sdk.metrics.Metrics
- throwable() - Method in class org.apache.beam.sdk.values.EncodableThrowable
-
Returns the underlying
Throwable. - ThrowableHandler() - Constructor for class org.apache.beam.sdk.transforms.WithFailures.ThrowableHandler
- THROWING_ROUTER - Static variable in interface org.apache.beam.sdk.transforms.errorhandling.BadRecordRouter
- ThrowingBadRecordRouter() - Constructor for class org.apache.beam.sdk.transforms.errorhandling.BadRecordRouter.ThrowingBadRecordRouter
- ThrowingBiConsumer<T1,T2> - Interface in org.apache.beam.sdk.function
-
A
BiConsumerwhich can throwExceptions. - ThrowingBiFunction<T1,T2,T3> - Interface in org.apache.beam.sdk.function
-
A
BiFunctionwhich can throwExceptions. - ThrowingConsumer<ExceptionT extends java.lang.Exception,T> - Interface in org.apache.beam.sdk.function
-
A
Consumerwhich can throwExceptions. - ThrowingFunction<T1,T2> - Interface in org.apache.beam.sdk.function
-
A
Functionwhich can throwExceptions. - ThrowingRunnable - Interface in org.apache.beam.sdk.function
-
A
Runnablewhich can throwExceptions. - ThrowingRunnable - Interface in org.apache.beam.sdk.util
-
Like
Runnablebut allowed to throw any exception. - ThrowingSupplier<T> - Interface in org.apache.beam.sdk.util
-
Like
Supplierbut allowed to throw any exception. - Time - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A time without a time-zone.
- Time() - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.Time
- TIME - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.SqlTypes
-
Beam LogicalType corresponding to CalciteSQL TIME type.
- TIME_FIELD_NAME - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
- timeDomain() - Method in class org.apache.beam.sdk.transforms.DoFn.OnTimerContext
-
Returns the time domain of the current timer.
- timeDomain(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provide a reference to the time domain for a timer firing.
- timeDomain(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- timeDomain(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- TimeDomain - Enum in org.apache.beam.sdk.state
-
TimeDomainspecifies whether an operation is based on timestamps of elements or current "real-world" time as reported while processing. - timeDomainParameter() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- timer(String) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Returns the timer for the given
DoFn.TimerId. - timer(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- timer(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- timer(String, String, String) - Static method in class org.apache.beam.sdk.fn.data.LogicalEndpoint
- timer(TimeDomain) - Static method in class org.apache.beam.sdk.state.TimerSpecs
- Timer<K> - Class in org.apache.beam.sdk.util.construction
-
A timer consists of a user key, a dynamic timer tag, a set of windows and either a bit that says that this timer should be cleared or data representing the firing timestamp, hold timestamp and pane information that should be used when producing output.
- Timer - Interface in org.apache.beam.sdk.state
-
A timer for a specified time domain that can be set to register the desire for further processing at particular time in its specified time domain.
- Timer() - Constructor for class org.apache.beam.sdk.util.construction.Timer
- TIMER_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- Timer.Coder<K> - Class in org.apache.beam.sdk.util.construction
-
A
Coderfor timers. - TimerDeclaration() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TimerDeclaration
- timerDeclarations() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Timer declarations present on the
DoFnclass. - TimerEndpoint<T> - Class in org.apache.beam.sdk.fn.data
- TimerEndpoint() - Constructor for class org.apache.beam.sdk.fn.data.TimerEndpoint
- timerFamily(String) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Returns the timerMap for the given
DoFn.TimerFamily. - timerFamily(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- timerFamily(String) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- TimerFamilyDeclaration() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TimerFamilyDeclaration
- timerFamilyDeclarations() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
TimerMap declarations present on the
DoFnclass. - timerFamilyParameter(DoFnSignature.TimerFamilyDeclaration) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- timerId(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Returns the timer id for the current timer of a
DoFn.TimerFamily. - timerId(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- timerId(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- timerIdParameter() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- timerMap(TimeDomain) - Static method in class org.apache.beam.sdk.state.TimerSpecs
- TimerMap - Interface in org.apache.beam.sdk.state
- timerParameter(DoFnSignature.TimerDeclaration) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- TimerReference - Class in org.apache.beam.sdk.util.construction.graph
-
Contains references to components relevant for runners during execution for timers.
- TimerReference() - Constructor for class org.apache.beam.sdk.util.construction.graph.TimerReference
- Timers - Interface in org.apache.beam.sdk.state
-
Interface for interacting with time.
- TimerSpec - Interface in org.apache.beam.sdk.state
-
A specification for a
Timer. - TimerSpecs - Class in org.apache.beam.sdk.state
-
Static methods for working with
TimerSpecs. - TimerSpecs() - Constructor for class org.apache.beam.sdk.state.TimerSpecs
- timestamp() - Method in class org.apache.beam.sdk.transforms.DoFn.OnTimerContext
-
Returns the output timestamp of the current timer.
- timestamp() - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContext
-
Returns the timestamp of the input element.
- timestamp() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn.AssignContext
-
Returns the timestamp of the current element.
- timestamp(DoFn<InputT, OutputT>) - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Provide a reference to the input element timestamp.
- timestamp(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- timestamp(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- TIMESTAMP - org.apache.beam.sdk.transforms.display.DisplayData.Type
- TIMESTAMP - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.SqlTypes
-
Beam LogicalType corresponding to TIMESTAMP type.
- TIMESTAMP_MAX_VALUE - Static variable in class org.apache.beam.sdk.transforms.windowing.BoundedWindow
-
The maximum value for any Beam timestamp.
- TIMESTAMP_MIN_VALUE - Static variable in class org.apache.beam.sdk.transforms.windowing.BoundedWindow
-
The minimum value for any Beam timestamp.
- TimestampCombiner - Enum in org.apache.beam.sdk.transforms.windowing
-
Policies for combining timestamps that occur within a window.
- timestampCombinerFromProto(RunnerApi.OutputTime.Enum) - Static method in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- timestamped(Iterable<TimestampedValue<T>>) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns a new
Create.TimestampedValuestransform that produces aPCollectioncontaining the elements of the providedIterablewith the specified timestamps. - timestamped(Iterable<T>, Iterable<Long>) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns a new root transform that produces a
PCollectioncontaining the specified elements with the specified timestamps. - timestamped(TimestampedValue<T>, TimestampedValue<T>...) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns a new
Create.TimestampedValuestransform that produces aPCollectioncontaining the specified elements with the specified timestamps. - TimestampedValue<V extends @Nullable java.lang.Object> - Class in org.apache.beam.sdk.values
-
An immutable pair of a value and a timestamp.
- TimestampedValue(V, Instant) - Constructor for class org.apache.beam.sdk.values.TimestampedValue
- TimestampedValue.TimestampedValueCoder<T> - Class in org.apache.beam.sdk.values
-
A
CoderforTimestampedValue. - timestampedValueInGlobalWindow(T, Instant) - Static method in class org.apache.beam.sdk.values.WindowedValues
-
Returns a
WindowedValuewith the given value and timestamp,GlobalWindowand default pane. - timestampedValueInGlobalWindow(T, Instant, PaneInfo) - Static method in class org.apache.beam.sdk.values.WindowedValues
-
Returns a
WindowedValuewith the given value, timestamp, and pane in theGlobalWindow. - TimestampObservingWatermarkEstimator<WatermarkEstimatorStateT> - Interface in org.apache.beam.sdk.transforms.splittabledofn
-
A
WatermarkEstimatorthat observes the timestamps of all records output from aDoFn. - timestampParameter() - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- TimestampPrefixingWindowCoder<T extends BoundedWindow> - Class in org.apache.beam.sdk.coders
-
A
TimestampPrefixingWindowCoderwraps arbitrary user custom window coder. - timestamps() - Static method in class org.apache.beam.sdk.transforms.Reify
-
Create a
PTransformthat will output all inputs wrapped in aTimestampedValue. - timestampsInValue() - Static method in class org.apache.beam.sdk.transforms.Reify
-
Create a
PTransformthat will output all inputKVswith the timestamp inside the value. - TimestampTransform - Class in org.apache.beam.sdk.transforms.windowing
-
For internal use only; no backwards-compatibility guarantees.
- TimestampTransform.AlignTo - Class in org.apache.beam.sdk.transforms.windowing
-
For internal use only; no backwards-compatibility guarantees.
- TimestampTransform.Delay - Class in org.apache.beam.sdk.transforms.windowing
-
For internal use only; no backwards-compatibility guarantees.
- to(long) - Method in class org.apache.beam.sdk.io.GenerateSequence
-
Specifies the maximum number to generate (exclusive).
- to(Class<OutputT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Convert
-
Convert a
PCollection<InputT> to aPCollection<OutputT>. - to(String) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Specifies a common directory for all generated files.
- to(String) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Writes to text files with the given prefix.
- to(String) - Method in class org.apache.beam.sdk.io.TextIO.Write
- to(String) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
-
Writes TFRecord file(s) with the given output prefix.
- to(FileBasedSink.DynamicDestinations<String, ?, String>) - Method in class org.apache.beam.sdk.io.TextIO.Write
-
Deprecated.
- to(FileBasedSink.DynamicDestinations<UserT, NewDestinationT, String>) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Deprecated.
- to(FileBasedSink.FilenamePolicy) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Writes to files named according to the given
FileBasedSink.FilenamePolicy. - to(FileBasedSink.FilenamePolicy) - Method in class org.apache.beam.sdk.io.TextIO.Write
- to(FileBasedSink<UserT, DestinationT, OutputT>) - Static method in class org.apache.beam.sdk.io.WriteFiles
-
Creates a
WriteFilestransform that writes to the givenFileBasedSink, letting the runner control how many different shards are produced. - to(ResourceId) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
- to(ResourceId) - Method in class org.apache.beam.sdk.io.TextIO.Write
- to(ResourceId) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
-
Writes TFRecord file(s) with a prefix given by the specified resource.
- to(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Like
FileIO.Write.to(String)but with aValueProvider. - to(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
- to(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.TextIO.Write
- to(SerializableFunction<String, DefaultFilenamePolicy.Params>, DefaultFilenamePolicy.Params) - Method in class org.apache.beam.sdk.io.TextIO.Write
-
Deprecated.
- to(SerializableFunction<UserT, DefaultFilenamePolicy.Params>, DefaultFilenamePolicy.Params) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Deprecated.
- to(TypeDescriptor<OutputT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Convert
-
Convert a
PCollection<InputT> to aPCollection<OutputT>. - TO_STRING_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- toAdditionalInputs(Iterable<PCollectionView<?>>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Expands a list of
PCollectionViewinto the form needed forPTransform.getAdditionalInputs(). - toAppliedPTransform(Pipeline) - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
-
Returns the
AppliedPTransformrepresenting thisTransformHierarchy.Node. - toBaseType(byte[]) - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
- toBaseType(InputT) - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
-
Convert the input type to the type Java type used by the base
Schema.FieldType. - toBaseType(PythonCallableSource) - Method in class org.apache.beam.sdk.schemas.logicaltypes.PythonCallable
- toBaseType(T) - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
- toBaseType(Duration) - Method in class org.apache.beam.sdk.schemas.logicaltypes.NanosDuration
- toBaseType(Instant) - Method in class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
- toBaseType(Instant) - Method in class org.apache.beam.sdk.schemas.logicaltypes.NanosInstant
- toBaseType(LocalDate) - Method in class org.apache.beam.sdk.schemas.logicaltypes.Date
- toBaseType(LocalDateTime) - Method in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
- toBaseType(LocalTime) - Method in class org.apache.beam.sdk.schemas.logicaltypes.Time
- toBaseType(UUID) - Method in class org.apache.beam.sdk.schemas.logicaltypes.UuidLogicalType
- toBaseType(EnumerationType.Value) - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
- toBaseType(OneOfType.Value) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
- toBaseType(Schema) - Method in class org.apache.beam.sdk.schemas.logicaltypes.SchemaLogicalType
- toBeamRow(String, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.YamlUtils
- toBeamRow(String, Schema, boolean) - Static method in class org.apache.beam.sdk.schemas.utils.YamlUtils
- toBeamRow(Map<String, Object>, Schema, boolean) - Static method in class org.apache.beam.sdk.schemas.utils.YamlUtils
- toBuilder() - Method in class org.apache.beam.sdk.schemas.Schema.Field
- toBuilder() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
- toBuilder() - Method in class org.apache.beam.sdk.transforms.DoFnSchemaInformation
- toBuilder() - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError
- toBuilder() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SchemaElementParameter
- toBuilder() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.SideInputParameter
- toByteArray() - Method in class org.apache.beam.sdk.util.ExposedByteArrayOutputStream
- toByteArray(Object) - Static method in class org.apache.beam.sdk.util.construction.TransformUpgrader
-
A utility method that converts an arbitrary serializable object into a byte array.
- toBytes() - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHint
-
Defines how to represent the as bytestring.
- toByteString() - Method in class org.apache.beam.sdk.util.ByteStringOutputStream
-
Creates a byte string with the size and contents of this output stream.
- toByteStringAndReset() - Method in class org.apache.beam.sdk.util.ByteStringOutputStream
-
Creates a byte string with the size and contents of this output stream and resets the output stream to be re-used possibly re-using any existing buffers.
- toCamelCase() - Method in class org.apache.beam.sdk.schemas.Schema
-
Recursively converts all field names to `lowerCamelCase`.
- toCamelCase() - Method in class org.apache.beam.sdk.values.Row
-
Returns an equivalent
Rowwith `lowerCamelCase` field names. - toComponents() - Method in class org.apache.beam.sdk.util.construction.SdkComponents
-
Convert this
SdkComponentsinto aRunnerApi.Components, including all of the containedcoders,windowing strategies,PCollections, andPTransforms. - toConfigRow(TFRecordReadSchemaTransformProvider.TFRecordReadSchemaTransform) - Method in class org.apache.beam.sdk.io.TFRecordSchemaTransformTranslation.TFRecordReadSchemaTransformTranslator
- toConfigRow(TFRecordWriteSchemaTransformProvider.TFRecordWriteSchemaTransform) - Method in class org.apache.beam.sdk.io.TFRecordSchemaTransformTranslation.TFRecordWriteSchemaTransformTranslator
- toConfigRow(T) - Method in interface org.apache.beam.sdk.util.construction.PTransformTranslation.TransformPayloadTranslator
-
Generates a Row-based construction configuration for the provided transform.
- toDefaultPolicies(SerializableFunction<UserT, DefaultFilenamePolicy.Params>, DefaultFilenamePolicy.Params, SerializableFunction<UserT, OutputT>) - Static method in class org.apache.beam.sdk.io.DynamicFileDestinations
-
Returns a
FileBasedSink.DynamicDestinationsthat returns instances ofDefaultFilenamePolicyconfigured with the givenDefaultFilenamePolicy.Params. - toDot(Network<NodeT, EdgeT>) - Static method in class org.apache.beam.sdk.util.construction.graph.Networks
- toDotString(RunnerApi.Pipeline) - Static method in class org.apache.beam.sdk.util.construction.renderer.PipelineDotRenderer
- toDotString(Pipeline) - Static method in class org.apache.beam.sdk.util.construction.renderer.PipelineDotRenderer
- toFnWithContext(CombineFnBase.GlobalCombineFn<InputT, AccumT, OutputT>) - Static method in class org.apache.beam.sdk.util.CombineFnUtil
-
Return a
CombineWithContext.CombineFnWithContextfrom the givenCombineFnBase.GlobalCombineFn. - toInputType(byte[]) - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
- toInputType(byte[]) - Method in class org.apache.beam.sdk.schemas.logicaltypes.VariableBytes
- toInputType(byte[]) - Method in class org.apache.beam.sdk.schemas.logicaltypes.SchemaLogicalType
- toInputType(BaseT) - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
-
Convert the Java type used by the base
Schema.FieldTypeto the input type. - toInputType(String) - Method in class org.apache.beam.sdk.schemas.logicaltypes.PythonCallable
- toInputType(T) - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
- toInputType(Integer) - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
- toInputType(Long) - Method in class org.apache.beam.sdk.schemas.logicaltypes.Date
- toInputType(Long) - Method in class org.apache.beam.sdk.schemas.logicaltypes.Time
- toInputType(String) - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedString
- toInputType(String) - Method in class org.apache.beam.sdk.schemas.logicaltypes.VariableString
- toInputType(BigDecimal) - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedPrecisionNumeric
- toInputType(Row) - Method in class org.apache.beam.sdk.schemas.logicaltypes.DateTime
- toInputType(Row) - Method in class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
- toInputType(Row) - Method in class org.apache.beam.sdk.schemas.logicaltypes.NanosDuration
- toInputType(Row) - Method in class org.apache.beam.sdk.schemas.logicaltypes.NanosInstant
- toInputType(Row) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
- toInputType(Row) - Method in class org.apache.beam.sdk.schemas.logicaltypes.UuidLogicalType
- toJson(PipelineOptions) - Static method in class org.apache.beam.sdk.util.construction.PipelineOptionsTranslation
-
Converts the provided
PipelineOptionsinto JsonString. - ToJson<T> - Class in org.apache.beam.sdk.transforms
-
Creates a
PTransformthat serializes UTF-8 JSON objects from aSchema-aware PCollection (i.e. - tokenNames - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
-
Deprecated.Use
FieldSpecifierNotationLexer.VOCABULARYinstead. - tokenNames - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
-
Deprecated.Use
FieldSpecifierNotationParser.VOCABULARYinstead. - ToListViewDoFn() - Constructor for class org.apache.beam.sdk.transforms.View.ToListViewDoFn
- toLogicalBaseType(Schema.LogicalType<InputT, BaseT>, InputT) - Static method in class org.apache.beam.sdk.schemas.SchemaUtils
-
Returns the base type given a logical type and the input type.
- toLogicalInputType(Schema.LogicalType<InputT, BaseT>, BaseT) - Static method in class org.apache.beam.sdk.schemas.SchemaUtils
-
Returns the input type given a logical type and the base type.
- toMessageProto(WindowingStrategy<?, ?>, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
-
Converts a
WindowingStrategyinto aRunnerApi.MessageWithComponentswhereRunnerApi.MessageWithComponents.getWindowingStrategy()()} is aRunnerApi.WindowingStrategy (proto)for the inputWindowingStrategy. - Top - Class in org.apache.beam.sdk.transforms
-
PTransforms for finding the largest (or smallest) set of elements in aPCollection, or the largest (or smallest) set of values associated with each key in aPCollectionofKVs. - TOP_LEVEL - org.apache.beam.sdk.io.FileSystem.LineageLevel
- Top.Largest<T extends java.lang.Comparable<? super T>> - Class in org.apache.beam.sdk.transforms
-
Deprecated.use
Top.Naturalinstead - Top.Natural<T extends java.lang.Comparable<? super T>> - Class in org.apache.beam.sdk.transforms
-
A
SerializableComparatorthat that uses the compared elements' natural ordering. - Top.Reversed<T extends java.lang.Comparable<? super T>> - Class in org.apache.beam.sdk.transforms
-
SerializableComparatorthat that uses the reverse of the compared elements' natural ordering. - Top.Smallest<T extends java.lang.Comparable<? super T>> - Class in org.apache.beam.sdk.transforms
-
Deprecated.use
Top.Reversedinstead - Top.TopCombineFn<T,ComparatorT extends java.util.Comparator<T> & java.io.Serializable> - Class in org.apache.beam.sdk.transforms
-
CombineFnforToptransforms that combines a bunch ofTs into a singlecount-longList<T>, usingcompareFnto choose the largestTs. - TopCombineFn(int, ComparatorT) - Constructor for class org.apache.beam.sdk.transforms.Top.TopCombineFn
- toPipeline() - Method in class org.apache.beam.sdk.util.construction.graph.FusedPipeline
-
Returns the
RunnerApi.Pipelinerepresentation of thisFusedPipeline. - topologicalOrder(Network<NodeT, ?>) - Static method in class org.apache.beam.sdk.util.construction.graph.Networks
-
Return a set of nodes in sorted topological order.
- topologicalOrder(Network<NodeT, EdgeT>, Comparator<NodeT>) - Static method in class org.apache.beam.sdk.util.construction.graph.Networks
-
Return a set of nodes in sorted topological order.
- toPrettyString(Schema) - Static method in class org.apache.beam.sdk.schemas.SchemaUtils
- toPrettyString(Row) - Static method in class org.apache.beam.sdk.schemas.SchemaUtils
- toProto() - Method in class org.apache.beam.sdk.util.HistogramData
-
Converts this
HistogramDatato its protoMetricsApi.HistogramValue. - toProto(Coder<?>) - Static method in class org.apache.beam.sdk.util.construction.CoderTranslation
- toProto(Coder<?>, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.CoderTranslation
- toProto(Source<?>) - Static method in class org.apache.beam.sdk.util.construction.ReadTranslation
- toProto(PipelineOptions) - Static method in class org.apache.beam.sdk.util.construction.PipelineOptionsTranslation
-
Converts the provided
PipelineOptionsto aStruct. - toProto(Pipeline) - Static method in class org.apache.beam.sdk.util.construction.PipelineTranslation
- toProto(Pipeline, boolean) - Static method in class org.apache.beam.sdk.util.construction.PipelineTranslation
- toProto(Pipeline, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.PipelineTranslation
- toProto(Pipeline, SdkComponents, boolean) - Static method in class org.apache.beam.sdk.util.construction.PipelineTranslation
- toProto(Pipeline, SdkComponents, boolean, boolean) - Static method in class org.apache.beam.sdk.util.construction.PipelineTranslation
- toProto(CombineFnBase.GlobalCombineFn<?, ?, ?>, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.CombineTranslation
- toProto(DisplayData) - Static method in class org.apache.beam.sdk.util.construction.DisplayDataTranslation
- toProto(TimestampCombiner) - Static method in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- toProto(Trigger) - Static method in class org.apache.beam.sdk.util.construction.TriggerTranslation
- toProto(Window.Assign<?>, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.WindowIntoTranslation
- toProto(Window.ClosingBehavior) - Static method in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- toProto(Window.OnTimeBehavior) - Static method in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- toProto(WindowFn<?, ?>, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- toProto(SplittableParDo.PrimitiveBoundedRead<?>) - Static method in class org.apache.beam.sdk.util.construction.ReadTranslation
- toProto(SplittableParDo.PrimitiveUnboundedRead<?>) - Static method in class org.apache.beam.sdk.util.construction.ReadTranslation
- toProto(PCollection<?>, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.PCollectionTranslation
- toProto(WindowingStrategy.AccumulationMode) - Static method in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- toProto(WindowingStrategy<?, ?>, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
-
Converts a
WindowingStrategyinto aRunnerApi.WindowingStrategy, registering any components in the providedSdkComponents. - toPTransform() - Method in class org.apache.beam.sdk.fn.data.RemoteGrpcPortRead
- toPTransform() - Method in class org.apache.beam.sdk.fn.data.RemoteGrpcPortWrite
- toPTransform(String) - Method in interface org.apache.beam.sdk.util.construction.graph.ExecutableStage
-
Returns a composite
RunnerApi.PTransformwhich is equivalent to thisExecutableStageas follows: TheRunnerApi.PTransform.getSubtransformsList()is empty. - toResource(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
- toResource(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.TextIO.Write
- toResource(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
- toRow(Schema) - Static method in class org.apache.beam.sdk.values.Row
-
Creates a
Rowfrom the list of values andRow.getSchema(). - toRowFunction(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProvider
-
Given a type, return a function that converts that type to a
Rowobject If no schema exists, returns null. - toRowFunction(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
-
Deprecated.
- toRowFunction(TypeDescriptor<T>) - Method in interface org.apache.beam.sdk.schemas.SchemaProvider
-
Given a type, return a function that converts that type to a
Rowobject If no schema exists, returns null. - toRows() - Static method in class org.apache.beam.sdk.schemas.transforms.Convert
-
Convert a
PCollection<InputT> into aPCollection<Row>. - toSchema() - Static method in class org.apache.beam.sdk.schemas.Schema
-
Collects a stream of
Schema.Fields into aSchema. - toSnakeCase() - Method in class org.apache.beam.sdk.schemas.Schema
-
Recursively converts all field names to `snake_case`.
- toSnakeCase() - Method in class org.apache.beam.sdk.values.Row
-
Returns an equivalent
Rowwith `snake_case` field names. - toString() - Method in class org.apache.beam.sdk.coders.Coder.Context
-
Deprecated.
- toString() - Method in class org.apache.beam.sdk.coders.DelegateCoder
- toString() - Method in class org.apache.beam.sdk.coders.SerializableCoder
- toString() - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
- toString() - Method in class org.apache.beam.sdk.coders.StructuralByteArray
- toString() - Method in class org.apache.beam.sdk.coders.StructuredCoder
- toString() - Method in class org.apache.beam.sdk.coders.ZstdCoder
- toString() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer
- toString() - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
- toString() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
- toString() - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
- toString() - Method in class org.apache.beam.sdk.io.FileBasedSource
- toString() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
- toString() - Method in interface org.apache.beam.sdk.io.fs.ResourceId
-
Returns the string representation of this
ResourceId. - toString() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
- toString() - Method in class org.apache.beam.sdk.io.range.ByteKey
- toString() - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
- toString() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
- toString() - Method in class org.apache.beam.sdk.io.range.OffsetRange
- toString() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
- toString() - Method in enum org.apache.beam.sdk.metrics.Lineage.Type
- toString() - Method in class org.apache.beam.sdk.metrics.MetricKey
- toString() - Method in class org.apache.beam.sdk.metrics.MetricName
- toString() - Method in class org.apache.beam.sdk.metrics.MetricQueryResults
- toString() - Method in class org.apache.beam.sdk.metrics.MetricResults
- toString() - Method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
- toString() - Method in class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
- toString() - Method in class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
- toString() - Method in class org.apache.beam.sdk.Pipeline
- toString() - Method in class org.apache.beam.sdk.runners.TransformHierarchy.Node
- toString() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
- toString() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
- toString() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType.Value
- toString() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
- toString() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedString
- toString() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
- toString() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
- toString() - Method in class org.apache.beam.sdk.schemas.logicaltypes.VariableBytes
- toString() - Method in class org.apache.beam.sdk.schemas.logicaltypes.VariableString
- toString() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
- toString() - Method in class org.apache.beam.sdk.schemas.Schema.Options
- toString() - Method in class org.apache.beam.sdk.schemas.Schema
- toString() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
- toString() - Method in class org.apache.beam.sdk.schemas.transforms.Cast.Narrowing
- toString() - Method in class org.apache.beam.sdk.schemas.transforms.Cast.Widening
- toString() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- toString() - Method in class org.apache.beam.sdk.testing.SuccessOrFailure
- toString() - Method in class org.apache.beam.sdk.testing.TestPipeline
- toString() - Method in class org.apache.beam.sdk.transforms.Combine.Holder
- toString() - Method in class org.apache.beam.sdk.transforms.Contextful
- toString() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
- toString() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
- toString() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
- toString() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
- toString() - Method in class org.apache.beam.sdk.transforms.display.DisplayData
- toString() - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches
- toString() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
- toString() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
- toString() - Method in class org.apache.beam.sdk.transforms.join.RawUnionValue
- toString() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
- toString() - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
- toString() - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.OutputRangeTracker
- toString() - Method in class org.apache.beam.sdk.transforms.PTransform
- toString() - Method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
- toString() - Method in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
- toString() - Method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterAll
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterEach
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterFirst
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindow
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.ReshuffleTrigger
- toString() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
- toString() - Method in class org.apache.beam.sdk.util.ByteStringOutputStream
- toString() - Method in class org.apache.beam.sdk.util.construction.graph.SideInputReference
- toString() - Method in class org.apache.beam.sdk.util.ExplicitShardedFile
- toString() - Method in class org.apache.beam.sdk.util.FilePatternMatchingShardedFile
- toString() - Method in class org.apache.beam.sdk.util.FluentBackoff
- toString() - Method in class org.apache.beam.sdk.util.NumberedShardedFile
- toString() - Method in class org.apache.beam.sdk.util.ShardedKey
- toString() - Method in class org.apache.beam.sdk.util.UnownedInputStream
- toString() - Method in class org.apache.beam.sdk.util.UnownedOutputStream
- toString() - Method in class org.apache.beam.sdk.util.WeightedValue
- toString() - Method in class org.apache.beam.sdk.values.KV
- toString() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
- toString() - Method in class org.apache.beam.sdk.values.PValueBase
- toString() - Method in class org.apache.beam.sdk.values.Row
- toString() - Method in class org.apache.beam.sdk.values.ShardedKey
-
Deprecated.
- toString() - Method in class org.apache.beam.sdk.values.TimestampedValue
- toString() - Method in class org.apache.beam.sdk.values.TupleTag
- toString() - Method in class org.apache.beam.sdk.values.TupleTagList
- toString() - Method in class org.apache.beam.sdk.values.TypeDescriptor
- toString() - Method in class org.apache.beam.sdk.values.TypeParameter
- toString() - Method in class org.apache.beam.sdk.values.ValueWithRecordId
- toString() - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- toString() - Method in class org.apache.beam.sdk.values.WindowingStrategy
- toString(boolean) - Method in class org.apache.beam.sdk.values.Row
-
Convert Row to String.
- toString(EnumerationType.Value) - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
- toString(StateT) - Method in interface org.apache.beam.sdk.transforms.Watch.Growth.TerminationCondition
-
Creates a human-readable representation of the given state of this condition.
- ToString - Class in org.apache.beam.sdk.transforms
-
PTransformsfor converting aPCollection<?>,PCollection<KV<?,?>>, orPCollection<Iterable<?>>to aPCollection<String>. - toUnsplittableSource(BoundedSource<T>) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Returns an equivalent unsplittable
BoundedSource<T>. - trace(String, Object...) - Static method in class org.apache.beam.sdk.util.WindowTracing
- TRACE - org.apache.beam.sdk.options.SdkHarnessOptions.LogLevel
-
LogLevel for logging tracing messages.
- trackerT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewTrackerMethod
-
Type of the returned
RestrictionTracker. - trackerT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.RestrictionTrackerParameter
- trackerT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
-
Concrete type of the
RestrictionTrackerparameter, if present. - transform() - Method in class org.apache.beam.sdk.util.construction.graph.SideInputReference
-
The PTransform that uses this side input.
- transform() - Method in class org.apache.beam.sdk.util.construction.graph.TimerReference
-
The PTransform that uses this timer.
- transform() - Method in class org.apache.beam.sdk.util.construction.graph.UserStateReference
-
The id of the PTransform that uses this user state.
- transform(Function<T, V>) - Method in class org.apache.beam.sdk.metrics.MetricResult
- transformContainer(Iterable<FromT>, Function<FromT, DestT>) - Static method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils
- TransformHierarchy - Class in org.apache.beam.sdk.runners
-
For internal use only; no backwards-compatibility guarantees.
- TransformHierarchy(ResourceHints) - Constructor for class org.apache.beam.sdk.runners.TransformHierarchy
- TransformHierarchy.Node - Class in org.apache.beam.sdk.runners
-
Provides internal tracking of transform relationships with helper methods for initialization and ordered visitation.
- TransformingMap(Map<K1, V1>, Function<K1, K2>, Function<V1, V2>) - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- TransformInputs - Class in org.apache.beam.sdk.util.construction
-
Utilities for extracting subsets of inputs from an
AppliedPTransform. - TransformInputs() - Constructor for class org.apache.beam.sdk.util.construction.TransformInputs
- TransformPayloadTranslatorRegistrar - Interface in org.apache.beam.sdk.util.construction
-
A registrar of TransformPayloadTranslator.
- TransformUpgrader - Class in org.apache.beam.sdk.util.construction
-
A utility class that allows upgrading transforms of a given pipeline using the Beam Transform Service.
- translate(AppliedPTransform<?, ?, ?>, List<AppliedPTransform<?, ?, ?>>, SdkComponents) - Method in class org.apache.beam.sdk.util.construction.ExternalTranslation.ExternalTranslator
- translate(AppliedPTransform<?, ?, ?>, List<AppliedPTransform<?, ?, ?>>, SdkComponents) - Method in class org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoTranslator
- translate(AppliedPTransform<?, ?, ?>, List<AppliedPTransform<?, ?, ?>>, SdkComponents) - Method in interface org.apache.beam.sdk.util.construction.PTransformTranslation.TransformTranslator
- translate(AppliedPTransform<?, ?, Combine.Globally<?, ?>>, SdkComponents) - Method in class org.apache.beam.sdk.util.construction.CombineTranslation.CombineGloballyPayloadTranslator
- translate(AppliedPTransform<?, ?, Combine.GroupedValues<?, ?, ?>>, SdkComponents) - Method in class org.apache.beam.sdk.util.construction.CombineTranslation.CombineGroupedValuesPayloadTranslator
- translate(AppliedPTransform<?, ?, Combine.PerKey<?, ?, ?>>, SdkComponents) - Method in class org.apache.beam.sdk.util.construction.CombineTranslation.CombinePerKeyPayloadTranslator
- translate(AppliedPTransform<?, ?, Flatten.PCollections<?>>, SdkComponents) - Method in class org.apache.beam.sdk.util.construction.FlattenTranslator
- translate(AppliedPTransform<?, ?, Window.Assign<?>>, SdkComponents) - Method in class org.apache.beam.sdk.util.construction.WindowIntoTranslation.WindowIntoPayloadTranslator
- translate(AppliedPTransform<?, ?, SplittableParDo.PrimitiveBoundedRead<?>>, SdkComponents) - Method in class org.apache.beam.sdk.util.construction.ReadTranslation.BoundedReadPayloadTranslator
- translate(AppliedPTransform<?, ?, SplittableParDo.PrimitiveUnboundedRead<?>>, SdkComponents) - Method in class org.apache.beam.sdk.util.construction.ReadTranslation.UnboundedReadPayloadTranslator
- translate(AppliedPTransform<?, ?, SplittableParDo.ProcessKeyedElements<?, ?, ?, ?>>, SdkComponents) - Method in class org.apache.beam.sdk.util.construction.SplittableParDo.ProcessKeyedElementsTranslator
- translate(AppliedPTransform<?, ?, T>, SdkComponents) - Method in class org.apache.beam.sdk.schemas.transforms.SchemaTransformTranslation.SchemaTransformPayloadTranslator
- translate(AppliedPTransform<?, ?, T>, SdkComponents) - Method in class org.apache.beam.sdk.util.construction.PTransformTranslation.TransformPayloadTranslator.NotSerializable
- translate(AppliedPTransform<?, ?, T>, SdkComponents) - Method in interface org.apache.beam.sdk.util.construction.PTransformTranslation.TransformPayloadTranslator
-
Translates the given transform represented by the provided
AppliedPTransformto aFunctionSpecwith a URN and a payload. - translateDoFn(DoFn<?, ?>, TupleTag<?>, Map<String, PCollectionView<?>>, DoFnSchemaInformation, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- translateDoFn(SdkComponents) - Method in interface org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoLike
- translateParDo(AppliedPTransform<?, ?, ParDo.MultiOutput<?, ?>>, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- translateParDo(ParDo.MultiOutput<InputT, ?>, PCollection<InputT>, DoFnSchemaInformation, Pipeline, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
Translate a ParDo.
- translateRestrictionCoderId(SdkComponents) - Method in interface org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoLike
- translateSideInputs(List<PCollectionView<?>>, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- translateSideInputs(SdkComponents) - Method in interface org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoLike
- translateStateSpec(StateSpec<?>, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
-
Translate state specs.
- translateStateSpecs(SdkComponents) - Method in interface org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoLike
- translateTimeDomain(TimeDomain) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- translateTimerFamilySpec(TimerSpec, SdkComponents, Coder<?>, Coder<BoundedWindow>) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- translateTimerFamilySpecs(SdkComponents) - Method in interface org.apache.beam.sdk.util.construction.ParDoTranslation.ParDoLike
- translateView(PCollectionView<?>, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- translateViewFn(ViewFn<?, ?>, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- translateWindowMappingFn(WindowMappingFn<?>, SdkComponents) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- traverseTopologically(Pipeline.PipelineVisitor) - Method in class org.apache.beam.sdk.Pipeline
-
For internal use only; no backwards-compatibility guarantees.
- Trigger - Class in org.apache.beam.sdk.transforms.windowing
-
Triggers control when the elements for a specific key and window are output.
- Trigger() - Constructor for class org.apache.beam.sdk.transforms.windowing.Trigger
- Trigger(List<Trigger>) - Constructor for class org.apache.beam.sdk.transforms.windowing.Trigger
- Trigger.OnceTrigger - Class in org.apache.beam.sdk.transforms.windowing
-
For internal use only; no backwards-compatibility guarantees.
- triggering(Trigger) - Method in class org.apache.beam.sdk.transforms.windowing.Window
-
Sets a non-default trigger for this
WindowPTransform. - TriggerTranslation - Class in org.apache.beam.sdk.util.construction
-
Utilities for working with
Triggers. - trivial() - Static method in class org.apache.beam.sdk.fn.stream.OutboundObserverFactory
-
Creates an
OutboundObserverFactorythat simply delegates to the base factory, with no flow control or synchronization. - TrivialNativeTransformExpander - Class in org.apache.beam.sdk.util.construction.graph
-
TrivialNativeTransformExpander is used to replace transforms with known URNs with their native equivalent.
- TrivialNativeTransformExpander() - Constructor for class org.apache.beam.sdk.util.construction.graph.TrivialNativeTransformExpander
- truncateRestriction() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Details about this
DoFn'sDoFn.TruncateRestrictionmethod. - TruncateRestrictionMethod() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TruncateRestrictionMethod
- TruncateResult() - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.TruncateResult
- tryClaim(Long) - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.OutputRangeTracker
- tryClaim(Long) - Method in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
-
Attempts to claim the given offset.
- tryClaim(ByteKey) - Method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
-
Attempts to claim the given key.
- tryClaim(PositionT) - Method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker
-
Attempts to claim the block of work in the current restriction identified by the given position.
- tryInvokeSetupFor(DoFn<InputT, OutputT>, PipelineOptions) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnInvokers
-
Tries to invoke setup on the given
DoFn. - tryLock() - Method in class org.apache.beam.sdk.util.NoopLock
- tryLock(long, TimeUnit) - Method in class org.apache.beam.sdk.util.NoopLock
- tryReturnRecordAt(boolean, long) - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
- tryReturnRecordAt(boolean, Long) - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
- tryReturnRecordAt(boolean, ByteKey) - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
- tryReturnRecordAt(boolean, PositionT) - Method in interface org.apache.beam.sdk.io.range.RangeTracker
-
Atomically determines whether a record at the given position can be returned and updates internal state.
- trySplit(double) - Method in class org.apache.beam.sdk.transforms.PeriodicSequence.OutputRangeTracker
- trySplit(double) - Method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
- trySplit(double) - Method in class org.apache.beam.sdk.transforms.splittabledofn.GrowableOffsetRangeTracker
- trySplit(double) - Method in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
- trySplit(double) - Method in class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker
-
Splits current restriction based on
fractionOfRemainder. - trySplitAtPosition(long) - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
- trySplitAtPosition(Long) - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
- trySplitAtPosition(ByteKey) - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
- trySplitAtPosition(PositionT) - Method in interface org.apache.beam.sdk.io.range.RangeTracker
-
Atomically splits the current range [
RangeTracker.getStartPosition(),RangeTracker.getStopPosition()) into a "primary" part [RangeTracker.getStartPosition(),splitPosition) and a "residual" part [splitPosition,RangeTracker.getStopPosition()), assuming the current last-consumed position is within [RangeTracker.getStartPosition(), splitPosition) (i.e.,splitPositionhas not been consumed yet). - TupleTag<V> - Class in org.apache.beam.sdk.values
-
A
TupleTagis a typed tag to use as the key of a heterogeneously typed tuple, likePCollectionTuple. - TupleTag() - Constructor for class org.apache.beam.sdk.values.TupleTag
-
Constructs a new
TupleTag, with a fresh unique id. - TupleTag(String) - Constructor for class org.apache.beam.sdk.values.TupleTag
-
Constructs a new
TupleTagwith the given id. - TupleTagList - Class in org.apache.beam.sdk.values
-
A
TupleTagListis an immutable list of heterogeneously typedTupleTags. - TYPE_ERASURE - org.apache.beam.sdk.coders.CannotProvideCoderException.ReasonCode
-
The reason a coder could not be provided is type erasure, for example when requesting coder inference for a
List<T>whereTis unknown. - TypeConversion() - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TypeConversion
- typedApply(T) - Method in class org.apache.beam.sdk.util.construction.graph.Networks.TypeSafeNodeFunction
- TypeDescriptor<T> - Class in org.apache.beam.sdk.values
-
A description of a Java type, including actual generic parameters where possible.
- TypeDescriptor() - Constructor for class org.apache.beam.sdk.values.TypeDescriptor
-
Creates a
TypeDescriptorrepresenting the type parameterT. - TypeDescriptor(Class<?>) - Constructor for class org.apache.beam.sdk.values.TypeDescriptor
-
Creates a
TypeDescriptorrepresenting the type parameterT, which should resolve to a concrete type in the context of the classclazz. - TypeDescriptor(Object) - Constructor for class org.apache.beam.sdk.values.TypeDescriptor
-
Creates a
TypeDescriptorrepresenting the type parameterT, which should resolve to a concrete type in the context of the classclazz. - TypeDescriptors - Class in org.apache.beam.sdk.values
-
A utility class for creating
TypeDescriptorobjects for different types, such as Java primitive types, containers andKVsof otherTypeDescriptorobjects, and extracting type variables of parameterized types (e.g. - TypeDescriptors() - Constructor for class org.apache.beam.sdk.values.TypeDescriptors
- TypeDescriptors.TypeVariableExtractor<InputT,OutputT> - Interface in org.apache.beam.sdk.values
-
A helper interface for use with
TypeDescriptors.extractFromTypeParameters(Object, Class, TypeVariableExtractor). - TypeDescriptorWithSchema() - Constructor for class org.apache.beam.sdk.schemas.utils.ReflectUtils.TypeDescriptorWithSchema
- TypedSchemaTransformProvider<ConfigT> - Class in org.apache.beam.sdk.schemas.transforms
-
Like
SchemaTransformProviderexcept uses a configuration object instead of Schema and Row. - TypedSchemaTransformProvider() - Constructor for class org.apache.beam.sdk.schemas.transforms.TypedSchemaTransformProvider
- TypedWrite() - Constructor for class org.apache.beam.sdk.io.TextIO.TypedWrite
- TypeParameter<T> - Class in org.apache.beam.sdk.values
-
Captures a free type variable that can be used in
TypeDescriptor.where(org.apache.beam.sdk.values.TypeParameter<X>, org.apache.beam.sdk.values.TypeDescriptor<X>). - TypeParameter() - Constructor for class org.apache.beam.sdk.values.TypeParameter
- TypeSafeNodeFunction(Class<T>) - Constructor for class org.apache.beam.sdk.util.construction.graph.Networks.TypeSafeNodeFunction
- typesEqual(Schema) - Method in class org.apache.beam.sdk.schemas.Schema
-
Returns true if two schemas are equal ignoring field names and descriptions.
- typesEqual(Schema.Field) - Method in class org.apache.beam.sdk.schemas.Schema.Field
-
Returns true if two fields are equal, ignoring name and description.
- typesEqual(Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Returns true if two FieldTypes are equal.
U
- unbounded() - Static method in class org.apache.beam.sdk.io.CountingSource
-
Deprecated.use
GenerateSequenceinstead - UNBOUNDED - org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.IsBounded
-
Indicates that a
Restrictionrepresents an unbounded amount of work. - UNBOUNDED - org.apache.beam.sdk.values.PCollection.IsBounded
-
Indicates that a
PCollectioncontains an unbounded number of elements. - UnboundedReader() - Constructor for class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
- UnboundedReadFromBoundedSource<T> - Class in org.apache.beam.sdk.util.construction
- UnboundedReadFromBoundedSource(BoundedSource<T>) - Constructor for class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource
-
Constructs a
PTransformthat performs an unbounded read from aBoundedSource. - UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter<T> - Class in org.apache.beam.sdk.util.construction
-
A
BoundedSourcetoUnboundedSourceadapter. - UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter.Checkpoint<T> - Class in org.apache.beam.sdk.util.construction
-
A marker representing the progress and state of an
UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter. - UnboundedScheduledExecutorService - Class in org.apache.beam.sdk.util
-
An unbounded
ScheduledExecutorServicebased upon theScheduledThreadPoolExecutorAPI contract. - UnboundedScheduledExecutorService() - Constructor for class org.apache.beam.sdk.util.UnboundedScheduledExecutorService
- UnboundedSource<OutputT,CheckpointMarkT extends UnboundedSource.CheckpointMark> - Class in org.apache.beam.sdk.io
-
A
Sourcethat reads an unbounded amount of input and, because of that, supports some additional operations such as checkpointing, watermarks, and record ids. - UnboundedSource() - Constructor for class org.apache.beam.sdk.io.UnboundedSource
- UnboundedSource.CheckpointMark - Interface in org.apache.beam.sdk.io
-
A marker representing the progress and state of an
UnboundedSource.UnboundedReader. - UnboundedSource.CheckpointMark.NoopCheckpointMark - Class in org.apache.beam.sdk.io
-
A checkpoint mark that does nothing when finalized.
- UnboundedSource.UnboundedReader<OutputT> - Class in org.apache.beam.sdk.io
-
A
Readerthat reads an unbounded amount of input. - unboundedSourceFromProto(RunnerApi.ReadPayload) - Static method in class org.apache.beam.sdk.util.construction.ReadTranslation
- unboundedSourceFromTransform(AppliedPTransform<PBegin, PCollection<T>, PTransform<PBegin, PCollection<T>>>) - Static method in class org.apache.beam.sdk.util.construction.ReadTranslation
- unboundedWithTimestampFn(SerializableFunction<Long, Instant>) - Static method in class org.apache.beam.sdk.io.CountingSource
-
Deprecated.use
GenerateSequenceand callGenerateSequence.withTimestampFn(SerializableFunction)instead - unboxedType - Variable in class org.apache.beam.sdk.schemas.utils.ConvertHelpers.ConvertedSchemaInformation
- UNCOMPRESSED - org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.
- UNCOMPRESSED - org.apache.beam.sdk.io.Compression
-
No compression.
- UNCOMPRESSED - org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.
- UNCOMPRESSED - org.apache.beam.sdk.io.TextIO.CompressionType
-
Deprecated.
- UnconsumedReads - Class in org.apache.beam.sdk.util.construction
- UnconsumedReads() - Constructor for class org.apache.beam.sdk.util.construction.UnconsumedReads
- union(Iterable<FieldAccessDescriptor>) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
- union(Contextful...) - Static method in class org.apache.beam.sdk.transforms.Requirements
- unionAll() - Static method in class org.apache.beam.sdk.transforms.Sets
-
Returns a new
PTransformtransform that follows SET ALL semantics which takes aPCollectionList<PCollection<T>>and returns aPCollection<T>containing the unionAll of collections done in order for all collections inPCollectionList<T>. - unionAll(PCollection<T>) - Static method in class org.apache.beam.sdk.transforms.Sets
-
Returns a new
PTransformtransform that follows SET ALL semantics to compute the unionAll with providedPCollection<T>. - UnionCoder - Class in org.apache.beam.sdk.transforms.join
-
A UnionCoder encodes RawUnionValues.
- unionDistinct() - Static method in class org.apache.beam.sdk.transforms.Sets
-
Returns a new
PTransformtransform that follows SET DISTINCT semantics which takes aPCollectionList<PCollection<T>>and returns aPCollection<T>containing the union of collections done in order for all collections inPCollectionList<T>. - unionDistinct(PCollection<T>) - Static method in class org.apache.beam.sdk.transforms.Sets
-
Returns a new
PTransformtransform that follows SET DISTINCT semantics to compute the union with providedPCollection<T>. - uniqueId(String, Predicate<String>) - Static method in class org.apache.beam.sdk.util.construction.SyntheticComponents
-
Generate an ID which does not collide with any existing ID, as determined by the input predicate.
- unknown() - Static method in class org.apache.beam.sdk.io.fs.MatchResult
-
Returns a
MatchResultwithMatchResult.Status.UNKNOWN. - UNKNOWN - org.apache.beam.sdk.coders.CannotProvideCoderException.ReasonCode
-
The reason a coder could not be provided is unknown or does not have an established
CannotProvideCoderException.ReasonCode. - UNKNOWN - org.apache.beam.sdk.io.fs.MatchResult.Status
- UNKNOWN - org.apache.beam.sdk.PipelineResult.State
-
The job state was not specified or unknown to a runner.
- UNKNOWN - org.apache.beam.sdk.transforms.windowing.PaneInfo.Timing
-
This element was not produced in a triggered pane and its relation to input and output watermarks is unknown.
- UnknownCoderWrapper - Class in org.apache.beam.sdk.util.construction
-
Represents a that is not defined in Java SDK, for example, a coder that is available in an external SDK that cannot be fully interpretted in the Java SDK.
- UnknownLogicalType<T> - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A base class for logical types that are not understood by the Java SDK.
- UnknownLogicalType(String, byte[], Schema.FieldType, Object, Schema.FieldType) - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.UnknownLogicalType
- unlock() - Method in class org.apache.beam.sdk.util.NoopLock
- UnownedInputStream - Class in org.apache.beam.sdk.util
-
A
OutputStreamwrapper which protects against the user attempting to modify the underlying stream by closing it or using mark. - UnownedInputStream(InputStream) - Constructor for class org.apache.beam.sdk.util.UnownedInputStream
- UnownedOutputStream - Class in org.apache.beam.sdk.util
-
A
OutputStreamwrapper which protects against the user attempting to modify the underlying stream by closing it. - UnownedOutputStream(OutputStream) - Constructor for class org.apache.beam.sdk.util.UnownedOutputStream
- UNRECOGNIZED - org.apache.beam.sdk.PipelineResult.State
-
The job state reported by a runner cannot be interpreted by the SDK.
- unregisterConsumer(String) - Method in class org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer
-
Unregisters a previously registered consumer.
- UnsupportedBuckets() - Constructor for class org.apache.beam.sdk.util.HistogramData.UnsupportedBuckets
- UnsupportedOverrideFactory<InputT extends PInput,OutputT extends POutput,TransformT extends PTransform<InputT,OutputT>> - Class in org.apache.beam.sdk.util.construction
-
A
PTransformOverrideFactorythat throws an exception when a call toUnsupportedOverrideFactory.getReplacementTransform(AppliedPTransform)is made. - unwindowedFilename(int, int, FileBasedSink.OutputFileHints) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy
- unwindowedFilename(int, int, FileBasedSink.OutputFileHints) - Method in class org.apache.beam.sdk.io.FileBasedSink.FilenamePolicy
-
When a sink has not requested windowed or triggered output, this method will be invoked to return the file
resourceto be created given the base output directory and aFileBasedSink.OutputFileHintscontaining information about the file, including a suggested (e.g. - update(double) - Method in class org.apache.beam.sdk.metrics.DelegatingHistogram
- update(double) - Method in interface org.apache.beam.sdk.metrics.Histogram
-
Add an observation to this histogram.
- update(double) - Method in class org.apache.beam.sdk.metrics.NoOpHistogram
- update(double...) - Method in class org.apache.beam.sdk.metrics.DelegatingHistogram
- update(double...) - Method in interface org.apache.beam.sdk.metrics.Histogram
-
Add observations to this histogram.
- update(double...) - Method in class org.apache.beam.sdk.metrics.NoOpHistogram
- update(long) - Method in class org.apache.beam.sdk.metrics.DelegatingDistribution
- update(long) - Method in interface org.apache.beam.sdk.metrics.Distribution
-
Add an observation to this distribution.
- update(long, long, long, long) - Method in class org.apache.beam.sdk.metrics.DelegatingDistribution
- update(long, long, long, long) - Method in interface org.apache.beam.sdk.metrics.Distribution
- update(Object) - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObserver
-
Updates the observer with a context specified, but without an instance of the Observable.
- update(Observable, Object) - Method in class org.apache.beam.sdk.util.common.ElementByteSizeObserver
- update(HistogramData) - Method in interface org.apache.beam.sdk.metrics.Histogram
-
Add a histogram to this histogram.
- update(HistogramData) - Method in class org.apache.beam.sdk.util.HistogramData
- updateCompatibilityVersionLessThan(PipelineOptions, String) - Static method in interface org.apache.beam.sdk.options.StreamingOptions
- UPDATED - org.apache.beam.sdk.PipelineResult.State
-
The job has been updated.
- updateSerializedOptions(String, Map<String, String>) - Static method in class org.apache.beam.sdk.options.ValueProviders
-
Deprecated.Use
TestPipeline.newProvider(T)for testingValueProvidercode. - updateTransform(String, RunnerApi.Pipeline, ProtoOverrides.TransformReplacement) - Static method in class org.apache.beam.sdk.util.construction.graph.ProtoOverrides
-
Update all composites present in the
originalPipelinewith an URN equal to the providedurnusing the providedProtoOverrides.TransformReplacement. - updateWindowingStrategy(WindowingStrategy<?, ?>) - Method in class org.apache.beam.sdk.transforms.GroupByKey
- upgradeTransformsViaTransformService(RunnerApi.Pipeline, List<String>, PipelineOptions) - Method in class org.apache.beam.sdk.util.construction.TransformUpgrader
-
Upgrade identified transforms in a given pipeline using the Transform Service.
- upTo(long) - Static method in class org.apache.beam.sdk.io.CountingSource
-
Deprecated.use
GenerateSequenceinstead - URN - Static variable in class org.apache.beam.sdk.fn.data.RemoteGrpcPortRead
- URN - Static variable in class org.apache.beam.sdk.fn.data.RemoteGrpcPortWrite
- URN - Static variable in class org.apache.beam.sdk.io.GenerateSequence.External
- URN - Static variable in interface org.apache.beam.sdk.util.construction.graph.ExecutableStage
-
The URN identifying an
ExecutableStagethat has been converted to aRunnerApi.PTransform. - urnEqualTo(String) - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
-
Returns a
PTransformMatcherthat matches aPTransformif the URN of thePTransformis equal to the URN provided ot this matcher. - urnForTransform(PTransform<?, ?>) - Static method in class org.apache.beam.sdk.util.construction.PTransformTranslation
-
Returns the URN for the transform if it is known, otherwise throws.
- urnForTransformOrNull(RunnerApi.PTransform) - Static method in class org.apache.beam.sdk.util.construction.PTransformTranslation
-
Returns the URN for the transform if it is known, otherwise
null. - urnForTransformOrNull(PTransform<?, ?>) - Static method in class org.apache.beam.sdk.util.construction.PTransformTranslation
-
Returns the URN for the transform if it is known, otherwise
null. - urns() - Static method in class org.apache.beam.sdk.util.construction.ModelCoders
- UserAgentFactory() - Constructor for class org.apache.beam.sdk.options.PipelineOptions.UserAgentFactory
- UserCodeException - Exception in org.apache.beam.sdk.util
-
An exception that was thrown in user-code.
- UserStateReference - Class in org.apache.beam.sdk.util.construction.graph
-
A reference to user state.
- UserStateReference() - Constructor for class org.apache.beam.sdk.util.construction.graph.UserStateReference
- UsesAttemptedMetrics - Class in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize
Metrics. - UsesAttemptedMetrics() - Constructor for class org.apache.beam.sdk.testing.UsesAttemptedMetrics
- usesBagState(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- UsesBoundedSplittableParDo - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize splittable
ParDowith aDoFn.BoundedPerElementDoFn. - UsesBoundedTrieMetrics - Class in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize
BoundedTrie. - UsesBoundedTrieMetrics() - Constructor for class org.apache.beam.sdk.testing.UsesBoundedTrieMetrics
- usesBundleFinalizer(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- UsesBundleFinalizer - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which use
DoFn.BundleFinalizer. - UsesCommittedMetrics - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize
Metrics. - UsesCounterMetrics - Class in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize
Counter. - UsesCounterMetrics() - Constructor for class org.apache.beam.sdk.testing.UsesCounterMetrics
- UsesCustomWindowMerging - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize custom window merging.
- UsesDistributionMetrics - Class in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize
Distribution. - UsesDistributionMetrics() - Constructor for class org.apache.beam.sdk.testing.UsesDistributionMetrics
- UsesExternalService - Interface in org.apache.beam.sdk.testing
-
Category tag for tests which relies on a pre-defined port, such as expansion service or transform service.
- UsesFailureMessage - Interface in org.apache.beam.sdk.testing
-
Category tag for tests which validate that currect failure message is provided by failed pipeline.
- UsesGaugeMetrics - Class in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize
Gauge. - UsesGaugeMetrics() - Constructor for class org.apache.beam.sdk.testing.UsesGaugeMetrics
- UsesImpulse - Class in org.apache.beam.sdk.testing
-
Category for tests that use
Impulsetransformations. - UsesImpulse() - Constructor for class org.apache.beam.sdk.testing.UsesImpulse
- UsesJavaExpansionService - Interface in org.apache.beam.sdk.testing
-
Category tag for tests which use the expansion service in Java.
- UsesKeyInParDo - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which use key.
- UsesKms - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize --tempRoot from
TestPipelineOptionsand and expect a default KMS key enable for the bucket specified. - UsesLoopingTimer - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize looping timers in
ParDo. - usesMapState(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- UsesMapState - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize
MapState. - UsesMetricsPusher - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize the metrics pusher feature.
- usesMultimapState(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- UsesMultimapState - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize
MultimapState. - UsesOnWindowExpiration - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize
DoFn.OnWindowExpiration. - usesOrderedListState(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- UsesOrderedListState - Class in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize
OrderedListState. - UsesOrderedListState() - Constructor for class org.apache.beam.sdk.testing.UsesOrderedListState
- UsesParDoLifecycle - Interface in org.apache.beam.sdk.testing
-
Category tag for the ParDoLifecycleTest for exclusion (BEAM-3241).
- UsesPerKeyOrderedDelivery - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which rely on a runner providing per-key ordering.
- UsesPerKeyOrderInBundle - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which rely on a runner providing per-key ordering in between transforms in the same ProcessBundleRequest.
- UsesProcessingTimeTimers - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize timers in
ParDo. - UsesPythonExpansionService - Interface in org.apache.beam.sdk.testing
-
Category tag for tests which use the expansion service in Python.
- UsesRequiresTimeSortedInput - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize
DoFn.RequiresTimeSortedInputin statefulParDo. - usesReshuffle - Variable in class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform
- UsesSchema - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize schemas.
- UsesSdkHarnessEnvironment - Interface in org.apache.beam.sdk.testing
-
Category tag for tests which validate that the SDK harness executes in a well formed environment.
- usesSetState(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- UsesSetState - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize
SetState. - UsesSideInputs - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which use sideinputs.
- UsesSideInputsWithDifferentCoders - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which use multiple side inputs with different coders.
- usesState() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Whether the
DoFndescribed by this signature uses state. - usesState(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- UsesStatefulParDo - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize stateful
ParDo. - usesStateOrTimers(AppliedPTransform<?, ?, ?>) - Static method in class org.apache.beam.sdk.util.construction.ParDoTranslation
- UsesStrictTimerOrdering - Interface in org.apache.beam.sdk.testing
-
Category for tests that enforce strict event-time ordering of fired timers, even in situations where multiple tests mutually set one another and watermark hops arbitrarily far to the future.
- UsesStringSetMetrics - Class in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize
StringSet. - UsesStringSetMetrics() - Constructor for class org.apache.beam.sdk.testing.UsesStringSetMetrics
- UsesSystemMetrics - Interface in org.apache.beam.sdk.testing
-
Category tag for tests that use System metrics.
- UsesTestStream - Interface in org.apache.beam.sdk.testing
-
Category tag for tests that use
TestStream, which is not a part of the Beam model but a special feature currently only implemented by the direct runner and the Flink Runner (streaming). - UsesTestStreamWithMultipleStages - Interface in org.apache.beam.sdk.testing
-
Subcategory for
UsesTestStreamtests which useTestStream# across multiple stages. - UsesTestStreamWithOutputTimestamp - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which use outputTimestamp.
- UsesTestStreamWithProcessingTime - Interface in org.apache.beam.sdk.testing
-
Subcategory for
UsesTestStreamtests which use the processing time feature ofTestStream. - UsesTimerMap - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which use timerMap.
- usesTimers() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature
-
Whether the
DoFndescribed by this signature uses timers. - usesTimers(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- UsesTimersInParDo - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize timers in
ParDo. - UsesTriggeredSideInputs - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which use triggered sideinputs.
- UsesUnboundedPCollections - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize at least one unbounded
PCollection. - UsesUnboundedSplittableParDo - Interface in org.apache.beam.sdk.testing
-
Category tag for validation tests which utilize splittable
ParDowith aDoFn.UnboundedPerElementDoFn. - usesValueState(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- usesWatermarkHold(DoFn<?, ?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignatures
- using(Integer...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.Impl
-
Perform a natural join between the PCollections.
- using(String...) - Method in class org.apache.beam.sdk.schemas.transforms.Join.Impl
-
Perform a natural join between the PCollections.
- using(FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.transforms.Join.Impl
-
Perform a natural join between the PCollections.
- UUID_SCHEMA - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.UuidLogicalType
- UuidLogicalType - Class in org.apache.beam.sdk.schemas.logicaltypes
-
Base class for types representing UUID as two long values.
- UuidLogicalType() - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.UuidLogicalType
V
- validate() - Method in class org.apache.beam.sdk.io.CompressedSource
-
Validates that the delegate source is a valid source and that the channel factory is not null.
- validate() - Method in class org.apache.beam.sdk.io.FileBasedSource
- validate() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
- validate() - Method in class org.apache.beam.sdk.io.Source
-
Checks that this source is valid, before it can be used in a pipeline.
- validate() - Method in class org.apache.beam.sdk.io.TFRecordReadSchemaTransformConfiguration
- validate() - Method in class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformConfiguration
- validate() - Method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration
- validate() - Method in class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration
- validate() - Method in class org.apache.beam.sdk.util.construction.UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter
- validate(PipelineOptions) - Method in class org.apache.beam.sdk.transforms.PTransform
-
Called before running the Pipeline to verify this transform is fully and correctly specified.
- validate(PipelineOptions, Map<TupleTag<?>, PCollection<?>>, Map<TupleTag<?>, PCollection<?>>) - Method in class org.apache.beam.sdk.transforms.GroupByKey
- validate(PipelineOptions, Map<TupleTag<?>, PCollection<?>>, Map<TupleTag<?>, PCollection<?>>) - Method in class org.apache.beam.sdk.transforms.PTransform
-
Called before running the Pipeline to verify this transform, its inputs, and outputs are fully and correctly specified.
- validate(Class<T>, PipelineOptions) - Static method in class org.apache.beam.sdk.options.PipelineOptionsValidator
-
Validates that the passed
PipelineOptionsconforms to all the validation criteria from the passed in interface. - validate(RunnerApi.Pipeline) - Static method in class org.apache.beam.sdk.util.construction.graph.PipelineValidator
- validate(PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSink
- validate(PipelineOptions) - Method in class org.apache.beam.sdk.io.WriteFiles
- validate(PipelineOptions) - Method in class org.apache.beam.sdk.util.construction.ForwardingPTransform
- validateCli(Class<T>, PipelineOptions) - Static method in class org.apache.beam.sdk.options.PipelineOptionsValidator
-
Validates that the passed
PipelineOptionsfrom command line interface (CLI) conforms to all the validation criteria from the passed in interface. - validateGetOutputTimestamps(WindowFn<T, W>, TimestampCombiner, List<List<Long>>) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
-
Verifies that later-ending merged windows from any of the timestamps hold up output of earlier-ending windows, using the provided
WindowFnandTimestampCombiner. - validateGetOutputTimestampsWithValue(WindowFn<T, W>, TimestampCombiner, List<List<TimestampedValue<T>>>) - Static method in class org.apache.beam.sdk.testing.WindowFnTestUtils
-
Verifies that later-ending merged windows from any of the timestampValues hold up output of earlier-ending windows, using the provided
WindowFnandTimestampCombiner. - validateJavaBean(List<FieldValueTypeInformation>, List<FieldValueTypeInformation>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
- ValidatesRunner - Interface in org.apache.beam.sdk.testing
-
Category tag for tests which validate that a Beam runner is correctly implemented.
- validateTimestampBounds(Instant) - Static method in class org.apache.beam.sdk.transforms.windowing.BoundedWindow
-
Validates that a given timestamp is within min and max bounds.
- Validation - Annotation Type in org.apache.beam.sdk.options
-
Validationrepresents a set of annotations that can be used to annotate getter properties onPipelineOptionswith information representing the validation criteria to be used when validating with thePipelineOptionsValidator. - Validation.Required - Annotation Type in org.apache.beam.sdk.options
-
This criteria specifies that the value must be not null.
- validator() - Method in class org.apache.beam.sdk.schemas.transforms.Cast
- value() - Method in annotation type org.apache.beam.sdk.coders.DefaultCoder
- value() - Method in annotation type org.apache.beam.sdk.options.Default.Boolean
- value() - Method in annotation type org.apache.beam.sdk.options.Default.Byte
- value() - Method in annotation type org.apache.beam.sdk.options.Default.Character
- value() - Method in annotation type org.apache.beam.sdk.options.Default.Class
- value() - Method in annotation type org.apache.beam.sdk.options.Default.Double
- value() - Method in annotation type org.apache.beam.sdk.options.Default.Enum
- value() - Method in annotation type org.apache.beam.sdk.options.Default.Float
- value() - Method in annotation type org.apache.beam.sdk.options.Default.InstanceFactory
- value() - Method in annotation type org.apache.beam.sdk.options.Default.Integer
- value() - Method in annotation type org.apache.beam.sdk.options.Default.Long
- value() - Method in annotation type org.apache.beam.sdk.options.Default.Short
- value() - Method in annotation type org.apache.beam.sdk.options.Default.String
- value() - Method in annotation type org.apache.beam.sdk.options.Description
- value() - Method in annotation type org.apache.beam.sdk.schemas.annotations.DefaultSchema
-
The schema provider implementation that knows how to vend schemas for the annotated class.
- value() - Method in annotation type org.apache.beam.sdk.schemas.annotations.SchemaCaseFormat
-
The name to use for the generated schema field.
- value() - Method in annotation type org.apache.beam.sdk.schemas.annotations.SchemaFieldDescription
-
The description to use for the generated schema field.
- value() - Method in annotation type org.apache.beam.sdk.schemas.annotations.SchemaFieldName
-
The name to use for the generated schema field.
- value() - Method in annotation type org.apache.beam.sdk.schemas.annotations.SchemaFieldNumber
-
The name to use for the generated schema field.
- value() - Static method in class org.apache.beam.sdk.state.StateSpecs
-
Create a
StateSpecfor a single value of typeT. - value() - Method in annotation type org.apache.beam.sdk.transforms.DoFn.FieldAccess
- value() - Method in annotation type org.apache.beam.sdk.transforms.DoFn.OnTimer
-
The timer ID.
- value() - Method in annotation type org.apache.beam.sdk.transforms.DoFn.OnTimerFamily
-
The timer ID.
- value() - Method in annotation type org.apache.beam.sdk.transforms.DoFn.SideInput
-
The SideInput tag ID.
- value() - Method in annotation type org.apache.beam.sdk.transforms.DoFn.StateId
-
The state ID.
- value() - Method in annotation type org.apache.beam.sdk.transforms.DoFn.TimerFamily
-
The TimerMap tag ID.
- value() - Method in annotation type org.apache.beam.sdk.transforms.DoFn.TimerId
-
The timer ID.
- value(Coder<T>) - Static method in class org.apache.beam.sdk.state.StateSpecs
-
Identical to
StateSpecs.value(), but with a coder explicitly supplied. - Value(int) - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType.Value
- Value(EnumerationType.Value, Object) - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
- valueCoderId() - Method in class org.apache.beam.sdk.util.construction.ModelCoders.KvCoderComponents
- valueInGlobalWindow(T) - Static method in class org.apache.beam.sdk.values.WindowedValues
-
Returns a
WindowedValuewith the given value in theGlobalWindowusing the default timestamp and pane. - valueInGlobalWindow(T, PaneInfo) - Static method in class org.apache.beam.sdk.values.WindowedValues
-
Returns a
WindowedValuewith the given value in theGlobalWindowusing the default timestamp and the specified pane. - ValueInSingleWindow<T> - Class in org.apache.beam.sdk.values
-
An immutable tuple of value, timestamp, window, and pane.
- ValueInSingleWindow() - Constructor for class org.apache.beam.sdk.values.ValueInSingleWindow
- ValueInSingleWindow.Coder<T> - Class in org.apache.beam.sdk.values
-
A coder for
ValueInSingleWindow. - valueOf(int) - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
-
Return an
EnumerationType.Valuecorresponding to one of the enumeration integer values. - valueOf(String) - Static method in enum org.apache.beam.sdk.coders.CannotProvideCoderException.ReasonCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.io.Compression
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.io.FileBasedSource.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.io.FileIO.ReadMatches.DirectoryTreatment
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.io.FileSystem.LineageLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.io.fs.EmptyMatchTreatment
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.io.fs.MatchResult.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.io.fs.MoveOptions.StandardMoveOptions
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.io.fs.ResolveOptions.StandardResolveOptions
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.io.TextIO.CompressionType
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.io.TFRecordIO.CompressionType
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.metrics.Lineage.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.options.PipelineOptions.CheckEnabled
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.options.SdkHarnessOptions.LogLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.Pipeline.PipelineVisitor.CompositeBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.PipelineResult.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.ListQualifier
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.MapQualifier
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
-
Return an
EnumerationType.Valuecorresponding to one of the enumeration strings. - valueOf(String) - Static method in enum org.apache.beam.sdk.schemas.Schema.EquivalenceNullablePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.schemas.Schema.TypeName
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields.Fanout.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.state.TimeDomain
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.testing.SourceTestUtils.ExpectedSplitOutcome
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.testing.TestStream.EventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.transforms.display.DisplayData.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.transforms.DoFnTester.CloningBehavior
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.IsBounded
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.transforms.windowing.PaneInfo.Timing
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.transforms.windowing.Window.ClosingBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.transforms.windowing.Window.OnTimeBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.util.construction.Environments.JavaVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult.IsException
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.util.RowJson.RowJsonDeserializer.NullBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.values.PCollection.IsBounded
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.beam.sdk.values.WindowingStrategy.AccumulationMode
-
Returns the enum constant of this type with the specified name.
- ValueOrMetadata(boolean, T, MetaT) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadata
- ValueProvider<T> - Interface in org.apache.beam.sdk.options
-
A
ValueProviderabstracts the notion of fetching a value that may or may not be currently available. - ValueProvider.Deserializer - Class in org.apache.beam.sdk.options
-
For internal use only; no backwards compatibility guarantees.
- ValueProvider.NestedValueProvider<T,X> - Class in org.apache.beam.sdk.options
-
ValueProvider.NestedValueProvideris an implementation ofValueProviderthat allows for wrapping anotherValueProviderobject. - ValueProvider.RuntimeValueProvider<T> - Class in org.apache.beam.sdk.options
-
ValueProvider.RuntimeValueProvideris an implementation ofValueProviderthat allows for a value to be provided at execution time rather than at graph construction time. - ValueProvider.Serializer - Class in org.apache.beam.sdk.options
-
For internal use only; no backwards compatibility guarantees.
- ValueProvider.StaticValueProvider<T> - Class in org.apache.beam.sdk.options
-
ValueProvider.StaticValueProvideris an implementation ofValueProviderthat allows for a static value to be provided. - ValueProviders - Class in org.apache.beam.sdk.options
-
Utilities for working with the
ValueProviderinterface. - values() - Static method in enum org.apache.beam.sdk.coders.CannotProvideCoderException.ReasonCode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.io.Compression
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.io.FileBasedSource.Mode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.io.FileIO.ReadMatches.DirectoryTreatment
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.io.FileSystem.LineageLevel
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.io.fs.EmptyMatchTreatment
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.io.fs.MatchResult.Status
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.io.fs.MoveOptions.StandardMoveOptions
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.io.fs.ResolveOptions.StandardResolveOptions
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.io.TextIO.CompressionType
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.io.TFRecordIO.CompressionType
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.metrics.Lineage.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.options.PipelineOptions.CheckEnabled
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.options.SdkHarnessOptions.LogLevel
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.Pipeline.PipelineVisitor.CompositeBehavior
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.PipelineResult.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.ListQualifier
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.MapQualifier
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier.Kind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.schemas.Schema.EquivalenceNullablePolicy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.schemas.Schema.TypeName
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields.Fanout.Kind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
- values() - Method in interface org.apache.beam.sdk.state.MapState
-
Returns an
Iterableover the values contained in this map. - values() - Static method in enum org.apache.beam.sdk.state.TimeDomain
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.testing.SourceTestUtils.ExpectedSplitOutcome
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.testing.TestStream.EventType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in class org.apache.beam.sdk.transforms.Deduplicate
-
Returns a deduplication transform that deduplicates values for up to 10 mins within the
processing time domain. - values() - Static method in enum org.apache.beam.sdk.transforms.display.DisplayData.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.transforms.DoFnTester.CloningBehavior
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.IsBounded
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.transforms.windowing.PaneInfo.Timing
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.transforms.windowing.Window.ClosingBehavior
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.transforms.windowing.Window.OnTimeBehavior
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.util.construction.Environments.JavaVersion
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.util.MoreFutures.ExceptionOrResult.IsException
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.util.RowJson.RowJsonDeserializer.NullBehavior
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.values.PCollection.IsBounded
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.beam.sdk.values.WindowingStrategy.AccumulationMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- Values<V> - Class in org.apache.beam.sdk.transforms
-
Values<V>takes aPCollectionofKV<K, V>s and returns aPCollection<V>of the values. - ValueState<T> - Interface in org.apache.beam.sdk.state
-
A
ReadableStatecell containing a single value. - ValueWithRecordId<ValueT> - Class in org.apache.beam.sdk.values
-
For internal use only; no backwards compatibility guarantees.
- ValueWithRecordId(ValueT, byte[]) - Constructor for class org.apache.beam.sdk.values.ValueWithRecordId
- ValueWithRecordId.StripIdsDoFn<T> - Class in org.apache.beam.sdk.values
- ValueWithRecordId.ValueWithRecordIdCoder<ValueT> - Class in org.apache.beam.sdk.values
- ValueWithRecordIdCoder(Coder<ValueT>) - Constructor for class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
- VariableBytes - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A LogicalType representing a variable-length byte array with specified maximum length.
- VariableString - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A LogicalType representing a variable-length string with specified maximum length.
- VarInt - Class in org.apache.beam.sdk.util
-
Variable-length encoding for integers.
- VarInt() - Constructor for class org.apache.beam.sdk.util.VarInt
- VarIntCoder - Class in org.apache.beam.sdk.coders
-
A
Coderthat encodesIntegersusing between 1 and 5 bytes. - VarLongCoder - Class in org.apache.beam.sdk.coders
-
A
Coderthat encodesLongsusing between 1 and 10 bytes. - verifyCompatibility(Schema) - Method in class org.apache.beam.sdk.schemas.transforms.Cast
- verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
- verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
- verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
- verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
- verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
- verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
- verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
- verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
Throw
IncompatibleWindowExceptionif this WindowFn does not perform the same merging as the given $WindowFn. - verifyCompatibility(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.util.IdentityWindowFn
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.AtomicCoder
-
Throw
Coder.NonDeterministicExceptionif the coding is not deterministic. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.BitSetCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.ByteCoder
-
Throw
Coder.NonDeterministicExceptionif the coding is not deterministic. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.Coder
-
Throw
Coder.NonDeterministicExceptionif the coding is not deterministic. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.CustomCoder
-
Throw
Coder.NonDeterministicExceptionif the coding is not deterministic. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.DelegateCoder
-
Throw
Coder.NonDeterministicExceptionif the coding is not deterministic. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.DequeCoder
-
Deque sizes are always known, so DequeIterable may be deterministic while the general IterableLikeCoder is not.
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.DoubleCoder
-
Throw
Coder.NonDeterministicExceptionif the coding is not deterministic. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.DurationCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.FloatCoder
-
Throw
Coder.NonDeterministicExceptionif the coding is not deterministic. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.InstantCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
-
Throw
Coder.NonDeterministicExceptionif the coding is not deterministic. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.KvCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
-
LengthPrefixCoderis deterministic if the nestedCoderis. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.ListCoder
-
List sizes are always known, so ListIterable may be deterministic while the general IterableLikeCoder is not.
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.MapCoder
-
Throw
Coder.NonDeterministicExceptionif the coding is not deterministic. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.NullableCoder
-
NullableCoderis deterministic if the nestedCoderis. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.OptionalCoder
-
OptionalCoderis deterministic if the nestedCoderis. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.SerializableCoder
-
Throw
Coder.NonDeterministicExceptionif the coding is not deterministic. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.SetCoder
-
Throw
Coder.NonDeterministicExceptionif the coding is not deterministic. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.ShardedKeyCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.SnappyCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.SortedMapCoder
-
Throw
Coder.NonDeterministicExceptionif the coding is not deterministic. - verifyDeterministic() - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.TimestampPrefixingWindowCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.VarIntCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.VarLongCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.VoidCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.coders.ZstdCoder
-
Throw
Coder.NonDeterministicExceptionif the coding is not deterministic. - verifyDeterministic() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResultCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.io.ReadableFileCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.testing.TestStream.TestStreamCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindow.Coder
- verifyDeterministic() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo.PaneInfoCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.util.BitSetCoder
-
Deprecated.
- verifyDeterministic() - Method in class org.apache.beam.sdk.util.construction.Timer.Coder
- verifyDeterministic() - Method in class org.apache.beam.sdk.util.ShardedKey.Coder
- verifyDeterministic() - Method in class org.apache.beam.sdk.values.FailsafeValueInSingleWindow.Coder
- verifyDeterministic() - Method in class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadataCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
- verifyDeterministic() - Method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.values.WindowedValues.FullWindowedValueCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
- verifyDeterministic() - Method in class org.apache.beam.sdk.values.WindowedValues.ValueOnlyWindowedValueCoder
-
Deprecated.
- verifyDeterministic(Coder<?>, String, Iterable<Coder<?>>) - Static method in class org.apache.beam.sdk.coders.Coder
-
Verifies all of the provided coders are deterministic.
- verifyDeterministic(Coder<?>, String, Coder<?>...) - Static method in class org.apache.beam.sdk.coders.Coder
-
Verifies all of the provided coders are deterministic.
- verifyFieldValue(Object, Schema.FieldType, String) - Static method in class org.apache.beam.sdk.values.SchemaVerification
- verifyModelCodersRegistered() - Static method in class org.apache.beam.sdk.util.construction.CoderTranslation
-
Explicitly validate that required coders are registered.
- verifyPAssertsSucceeded(Pipeline, PipelineResult) - Static method in class org.apache.beam.sdk.testing.TestPipeline
-
Verifies all {
PAsserts} in the pipeline have been executed and were successful. - verifySchemaSupported(Schema) - Static method in class org.apache.beam.sdk.util.RowJson
-
Throws
RowJson.UnsupportedRowJsonExceptionifschemacontains an unsupported field type. - verifyUnmodified() - Method in interface org.apache.beam.sdk.util.MutationDetector
- via(FileIO.Sink<UserT>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Like
FileIO.Write.via(Contextful), but uses the sameFileIO.Sinkfor all destinations. - via(Contextful<Contextful.Fn<DestinationT, FileIO.Sink<UserT>>>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Like
FileIO.Write.via(Contextful, Contextful), but the output type of the sink is the same as the type of the input collection. - via(Contextful<Contextful.Fn<NewInputT, Iterable<OutputT>>>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
-
Like
FlatMapElements.via(ProcessFunction), but allows access to additional context. - via(Contextful<Contextful.Fn<NewInputT, OutputT>>) - Method in class org.apache.beam.sdk.transforms.MapElements
-
Like
MapElements.via(ProcessFunction), but supports access to context, such as side inputs. - via(Contextful<Contextful.Fn<UserT, OutputT>>, FileIO.Sink<OutputT>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Like
FileIO.Write.via(Contextful, Contextful), but uses the same sink for all destinations. - via(Contextful<Contextful.Fn<UserT, OutputT>>, Contextful<Contextful.Fn<DestinationT, FileIO.Sink<OutputT>>>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Specifies how to create a
FileIO.Sinkfor a particular destination and how to map the element type to the sink's output type. - via(InferableFunction<? super InputT, ? extends Iterable<OutputT>>) - Static method in class org.apache.beam.sdk.transforms.FlatMapElements
-
For a
InferableFunction<InputT, ? extends Iterable<OutputT>>fn, return aPTransformthat appliesfnto every element of the inputPCollection<InputT>and outputs all of the elements to the outputPCollection<OutputT>. - via(InferableFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.MapElements
-
For
InferableFunction<InputT, OutputT>fn, returns aPTransformthat takes an inputPCollection<InputT>and returns aPCollection<OutputT>containingfn.apply(v)for every elementvin the input. - via(ProcessFunction<NewInputT, ? extends Iterable<OutputT>>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
-
For a
ProcessFunction<InputT, ? extends Iterable<OutputT>>fn, returns aPTransformthat appliesfnto every element of the inputPCollection<InputT>and outputs all of the elements to the outputPCollection<OutputT>. - via(ProcessFunction<NewInputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.MapElements
-
For a
ProcessFunction<InputT, OutputT>fnand output type descriptor, returns aPTransformthat takes an inputPCollection<InputT>and returns aPCollection<OutputT>containingfn.apply(v)for every elementvin the input. - via(SerializableFunction<NewInputT, ? extends Iterable<OutputT>>) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
-
Binary compatibility adapter for
FlatMapElements.via(ProcessFunction). - via(SerializableFunction<NewInputT, OutputT>) - Method in class org.apache.beam.sdk.transforms.MapElements
-
Binary compatibility adapter for
MapElements.via(ProcessFunction). - via(SerializableFunction<NewKeyT, K2>) - Method in class org.apache.beam.sdk.transforms.MapKeys
-
Returns a
MapKeys<K1, K2, V>PTransformfor aProcessFunction<NewK1, K2>with predefinedMapKeys.outputType. - via(SerializableFunction<NewValueT, V2>) - Method in class org.apache.beam.sdk.transforms.MapValues
-
Returns a
MapValuestransform for aProcessFunction<NewV1, V2>with predefinedMapValues.outputType. - via(SimpleFunction<? super InputT, ? extends Iterable<OutputT>>) - Static method in class org.apache.beam.sdk.transforms.FlatMapElements
-
Binary compatibility adapter for
FlatMapElements.via(ProcessFunction). - via(SimpleFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.MapElements
-
Binary compatibility adapter for
MapElements.via(InferableFunction). - viaRandomKey() - Static method in class org.apache.beam.sdk.transforms.Reshuffle
-
Encapsulates the sequence "pair input with unique key, apply
Reshuffle.of(), drop the key" commonly used to break fusion. - View - Class in org.apache.beam.sdk.transforms
-
Transforms for creating
PCollectionViewsfromPCollections(to read them as side inputs). - View.AsIterable<T> - Class in org.apache.beam.sdk.transforms
-
For internal use only; no backwards-compatibility guarantees.
- View.AsList<T> - Class in org.apache.beam.sdk.transforms
-
For internal use only; no backwards-compatibility guarantees.
- View.AsMap<K,V> - Class in org.apache.beam.sdk.transforms
-
For internal use only; no backwards-compatibility guarantees.
- View.AsMultimap<K,V> - Class in org.apache.beam.sdk.transforms
-
For internal use only; no backwards-compatibility guarantees.
- View.AsSingleton<T> - Class in org.apache.beam.sdk.transforms
-
For internal use only; no backwards-compatibility guarantees.
- View.CreatePCollectionView<ElemT,ViewT> - Class in org.apache.beam.sdk.transforms
-
For internal use only; no backwards-compatibility guarantees.
- View.ToListViewDoFn<T> - Class in org.apache.beam.sdk.transforms
-
Provides an index to value mapping using a random starting index and also provides an offset range for each window seen.
- viewAsValues(PCollectionView<V>, Coder<V>) - Static method in class org.apache.beam.sdk.transforms.Reify
-
Pairs each element in a collection with the value of a side input associated with the element's window.
- ViewFn<PrimitiveViewT,ViewT> - Class in org.apache.beam.sdk.transforms
-
For internal use only; no backwards-compatibility guarantees.
- ViewFn() - Constructor for class org.apache.beam.sdk.transforms.ViewFn
- viewFnFromProto(RunnerApi.FunctionSpec) - Static method in class org.apache.beam.sdk.util.construction.PCollectionViewTranslation
-
Converts a
RunnerApi.FunctionSpecinto aViewFnusing the URN. - viewFromProto(RunnerApi.SideInput, String, PCollection<?>, RunnerApi.PTransform, RehydratedComponents) - Static method in class org.apache.beam.sdk.util.construction.PCollectionViewTranslation
-
Create a
PCollectionViewfrom a side input spec and an already-deserializedPCollectionthat should be wired up. - viewInGlobalWindow(PCollectionView<V>, Coder<V>) - Static method in class org.apache.beam.sdk.transforms.Reify
-
Returns a
PCollectionconsisting of a single element, containing the value of the given view in the global window. - visit(Pipeline.PipelineVisitor) - Method in class org.apache.beam.sdk.runners.TransformHierarchy
- visitArrayQualifier(FieldSpecifierNotationParser.ArrayQualifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
-
Visit a parse tree produced by
FieldSpecifierNotationParser.arrayQualifier(). - visitArrayQualifier(FieldSpecifierNotationParser.ArrayQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
-
Visit a parse tree produced by
FieldSpecifierNotationParser.arrayQualifier(). - visitArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
-
Visit a parse tree produced by the
arrayQualifierListlabeled alternative inFieldSpecifierNotationParser.qualifierList(). - visitArrayQualifierList(FieldSpecifierNotationParser.ArrayQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
-
Visit a parse tree produced by the
arrayQualifierListlabeled alternative inFieldSpecifierNotationParser.qualifierList(). - visitDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
-
Visit a parse tree produced by
FieldSpecifierNotationParser.dotExpression(). - visitDotExpression(FieldSpecifierNotationParser.DotExpressionContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
-
Visit a parse tree produced by
FieldSpecifierNotationParser.dotExpression(). - visitErrorNode(ErrorNode) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
- visitFieldSpecifier(FieldSpecifierNotationParser.FieldSpecifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
-
Visit a parse tree produced by
FieldSpecifierNotationParser.fieldSpecifier(). - visitFieldSpecifier(FieldSpecifierNotationParser.FieldSpecifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
-
Visit a parse tree produced by
FieldSpecifierNotationParser.fieldSpecifier(). - visitMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
-
Visit a parse tree produced by
FieldSpecifierNotationParser.mapQualifier(). - visitMapQualifier(FieldSpecifierNotationParser.MapQualifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
-
Visit a parse tree produced by
FieldSpecifierNotationParser.mapQualifier(). - visitMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
-
Visit a parse tree produced by the
mapQualifierListlabeled alternative inFieldSpecifierNotationParser.qualifierList(). - visitMapQualifierList(FieldSpecifierNotationParser.MapQualifierListContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
-
Visit a parse tree produced by the
mapQualifierListlabeled alternative inFieldSpecifierNotationParser.qualifierList(). - visitPrimitiveTransform(TransformHierarchy.Node) - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
- visitPrimitiveTransform(TransformHierarchy.Node) - Method in interface org.apache.beam.sdk.Pipeline.PipelineVisitor
-
Called for each primitive transform after all of its topological predecessors and inputs have been visited.
- visitPrimitiveTransform(TransformHierarchy.Node) - Method in class org.apache.beam.sdk.util.construction.renderer.PipelineDotRenderer
- visitQualifiedComponent(FieldSpecifierNotationParser.QualifiedComponentContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
-
Visit a parse tree produced by
FieldSpecifierNotationParser.qualifiedComponent(). - visitQualifiedComponent(FieldSpecifierNotationParser.QualifiedComponentContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
-
Visit a parse tree produced by
FieldSpecifierNotationParser.qualifiedComponent(). - visitQualifyComponent(FieldSpecifierNotationParser.QualifyComponentContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
-
Visit a parse tree produced by the
qualifyComponentlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - visitQualifyComponent(FieldSpecifierNotationParser.QualifyComponentContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
-
Visit a parse tree produced by the
qualifyComponentlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - visitSimpleIdentifier(FieldSpecifierNotationParser.SimpleIdentifierContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
-
Visit a parse tree produced by the
simpleIdentifierlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - visitSimpleIdentifier(FieldSpecifierNotationParser.SimpleIdentifierContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
-
Visit a parse tree produced by the
simpleIdentifierlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - visitTerminal(TerminalNode) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseListener
- visitValue(PValue, TransformHierarchy.Node) - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
- visitValue(PValue, TransformHierarchy.Node) - Method in interface org.apache.beam.sdk.Pipeline.PipelineVisitor
-
Called for each value after the transform that produced the value has been visited.
- visitValue(PValue, TransformHierarchy.Node) - Method in class org.apache.beam.sdk.util.construction.renderer.PipelineDotRenderer
- visitWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationBaseVisitor
-
Visit a parse tree produced by the
wildcardlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - visitWildcard(FieldSpecifierNotationParser.WildcardContext) - Method in interface org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationVisitor
-
Visit a parse tree produced by the
wildcardlabeled alternative inFieldSpecifierNotationParser.dotExpressionComponent(). - VOCABULARY - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- VOCABULARY - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- VoidCoder - Class in org.apache.beam.sdk.coders
-
A
CoderforVoid. - voids() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
W
- Wait - Class in org.apache.beam.sdk.transforms
-
Delays processing of each window in a
PCollectionuntil signaled. - Wait() - Constructor for class org.apache.beam.sdk.transforms.Wait
- Wait.OnSignal<T> - Class in org.apache.beam.sdk.transforms
-
Implementation of
Wait.on(org.apache.beam.sdk.values.PCollection<?>...). - waitUntilFinish() - Method in interface org.apache.beam.sdk.PipelineResult
-
Waits until the pipeline finishes and returns the final status.
- waitUntilFinish(Duration) - Method in interface org.apache.beam.sdk.PipelineResult
-
Waits until the pipeline finishes and returns the final status.
- WallTime(Instant) - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.WatermarkEstimators.WallTime
- WARN - org.apache.beam.sdk.options.SdkHarnessOptions.LogLevel
-
LogLevel for logging warning messages.
- WARNING - org.apache.beam.sdk.options.PipelineOptions.CheckEnabled
- Watch - Class in org.apache.beam.sdk.transforms
-
Given a "poll function" that produces a potentially growing set of outputs for an input, this transform simultaneously continuously watches the growth of output sets of all inputs, until a per-input termination condition is reached.
- Watch() - Constructor for class org.apache.beam.sdk.transforms.Watch
- Watch.Growth<InputT,OutputT,KeyT> - Class in org.apache.beam.sdk.transforms
- Watch.Growth.PollFn<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
A function that computes the current set of outputs for the given input, in the form of a
Watch.Growth.PollResult. - Watch.Growth.PollResult<OutputT> - Class in org.apache.beam.sdk.transforms
-
The result of a single invocation of a
Watch.Growth.PollFn. - Watch.Growth.TerminationCondition<InputT,StateT> - Interface in org.apache.beam.sdk.transforms
-
A strategy for determining whether it is time to stop polling the current input regardless of whether its output is complete or not.
- Watch.WatchGrowthFn<InputT,OutputT,KeyT,TerminationStateT> - Class in org.apache.beam.sdk.transforms
- watchForNewFiles(Duration, Watch.Growth.TerminationCondition<String, ?>) - Method in class org.apache.beam.sdk.io.TextIO.Read
-
Same as
TextIO.Read.watchForNewFiles(Duration, TerminationCondition, boolean)withmatchUpdatedFiles=false. - watchForNewFiles(Duration, Watch.Growth.TerminationCondition<String, ?>) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
-
Deprecated.
- watchForNewFiles(Duration, Watch.Growth.TerminationCondition<String, ?>, boolean) - Method in class org.apache.beam.sdk.io.TextIO.Read
- watchForNewFiles(Duration, Watch.Growth.TerminationCondition<String, ?>, boolean) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
-
Deprecated.
- WATERMARK - org.apache.beam.sdk.testing.TestStream.EventType
- watermarkEstimator() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
If this is a splittable
DoFn, returns the associatedWatermarkEstimatorwith the current call. - watermarkEstimator() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- watermarkEstimator() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- watermarkEstimator(TypeDescriptor<?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- WatermarkEstimator<WatermarkEstimatorStateT> - Interface in org.apache.beam.sdk.transforms.splittabledofn
-
A
WatermarkEstimatorwhich is used for estimating output watermarks of a splittableDoFn. - WatermarkEstimators - Class in org.apache.beam.sdk.fn.splittabledofn
-
Support utilties for interacting with
WatermarkEstimators. - WatermarkEstimators - Class in org.apache.beam.sdk.transforms.splittabledofn
-
A set of
WatermarkEstimators that users can use to advance the output watermark for their associatedsplittable DoFns. - WatermarkEstimators() - Constructor for class org.apache.beam.sdk.fn.splittabledofn.WatermarkEstimators
- WatermarkEstimators.Manual - Class in org.apache.beam.sdk.transforms.splittabledofn
-
Concrete implementation of a
ManualWatermarkEstimator. - WatermarkEstimators.MonotonicallyIncreasing - Class in org.apache.beam.sdk.transforms.splittabledofn
-
A watermark estimator that observes timestamps of records output from a DoFn reporting the timestamp of the last element seen as the current watermark.
- WatermarkEstimators.WallTime - Class in org.apache.beam.sdk.transforms.splittabledofn
-
A watermark estimator that tracks wall time.
- WatermarkEstimators.WatermarkAndStateObserver<WatermarkEstimatorStateT> - Interface in org.apache.beam.sdk.fn.splittabledofn
-
Interface which allows for accessing the current watermark and watermark estimator state.
- watermarkEstimatorState() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
If this is a splittable
DoFn, returns the associated watermark estimator state with the current call. - watermarkEstimatorState() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- watermarkEstimatorState() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- watermarkEstimatorState(TypeDescriptor<?>) - Static method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter
- watermarkEstimatorStateT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialWatermarkEstimatorStateMethod
-
Type of the returned watermark estimator state.
- watermarkEstimatorT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewWatermarkEstimatorMethod
-
Type of the returned
WatermarkEstimator. - watermarkEstimatorT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
-
Concrete type of the
WatermarkEstimatorparameter, if present. - WatermarkEvent() - Constructor for class org.apache.beam.sdk.testing.TestStream.WatermarkEvent
- WatermarkHoldState - Interface in org.apache.beam.sdk.state
-
For internal use only; no backwards-compatibility guarantees.
- watermarkStateInternal(TimestampCombiner) - Static method in class org.apache.beam.sdk.state.StateSpecs
-
For internal use only; no backwards-compatibility guarantees.
- WEAKEN - org.apache.beam.sdk.schemas.Schema.EquivalenceNullablePolicy
- weeks(int, int) - Static method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows
-
Returns a
WindowFnthat windows elements into periods measured by weeks. - Weighted - Interface in org.apache.beam.sdk.util
-
Interface representing an object that has a weight, in unspecified units.
- WeightedList<T> - Class in org.apache.beam.sdk.fn.data
-
Facade for a
Listthat keeps track of weight, for cache limit reasons. - WeightedList(List<T>, long) - Constructor for class org.apache.beam.sdk.fn.data.WeightedList
- WeightedValue<T> - Class in org.apache.beam.sdk.util
-
A
Twith an accompanying weight. - where(Type, Type) - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
A more general form of
TypeDescriptor.where(TypeParameter, TypeDescriptor)that returns a newTypeDescriptorby matchingformalagainstactualto resolve type variables in the currentTypeDescriptor. - where(TypeParameter<X>, TypeDescriptor<X>) - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns a new
TypeDescriptorwhere the type variable represented bytypeParameterare substituted bytype. - whereFieldId(int, SerializableFunction<FieldT, Boolean>) - Method in class org.apache.beam.sdk.schemas.transforms.Filter.Inner
-
Set a predicate based on the value of a field, where the field is specified by id.
- whereFieldIds(List<Integer>, SerializableFunction<Row, Boolean>) - Method in class org.apache.beam.sdk.schemas.transforms.Filter.Inner
-
Set a predicate based on the value of multipled fields, specified by id.
- whereFieldName(String, SerializableFunction<FieldT, Boolean>) - Method in class org.apache.beam.sdk.schemas.transforms.Filter.Inner
-
Set a predicate based on the value of a field, where the field is specified by name.
- whereFieldNames(List<String>, SerializableFunction<Row, Boolean>) - Method in class org.apache.beam.sdk.schemas.transforms.Filter.Inner
-
Set a predicate based on the value of multipled fields, specified by name.
- widening(Schema) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
- Widening() - Constructor for class org.apache.beam.sdk.schemas.transforms.Cast.Widening
- WILDCARD - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- WILDCARD - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- WILDCARD() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.WildcardContext
- WildcardContext(FieldSpecifierNotationParser.DotExpressionComponentContext) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.WildcardContext
- wildcardToRegexp(String) - Static method in class org.apache.beam.sdk.io.FileSystemUtils
-
Expands glob expressions to regular expressions.
- window() - Method in interface org.apache.beam.sdk.state.StateContext
-
Returns the window corresponding to the state.
- window() - Method in class org.apache.beam.sdk.transforms.DoFn.OnTimerContext
-
Returns the window in which the timer is firing.
- window() - Method in class org.apache.beam.sdk.transforms.DoFn.OnWindowExpirationContext
-
Returns the window in which the window expiration is firing.
- window() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnInvoker.ArgumentProvider
-
Construct the
BoundedWindowto use within aDoFnthat needs it. - window() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.BaseArgumentProvider
- window() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnInvoker.DelegatingArgumentProvider
- window() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn.AssignContext
-
Returns the window of the current element prior to this
WindowFnbeing called. - Window<T> - Class in org.apache.beam.sdk.transforms.windowing
-
Windowlogically divides up or groups the elements of aPCollectioninto finite windows according to aWindowFn. - Window() - Constructor for class org.apache.beam.sdk.transforms.windowing.Window
- WINDOW - Static variable in class org.apache.beam.sdk.util.RowStringInterpolator
- Window.Assign<T> - Class in org.apache.beam.sdk.transforms.windowing
-
A Primitive
PTransformthat assigns windows to elements based on aWindowFn. - Window.ClosingBehavior - Enum in org.apache.beam.sdk.transforms.windowing
-
Specifies the conditions under which a final pane will be created when a window is permanently closed.
- Window.OnTimeBehavior - Enum in org.apache.beam.sdk.transforms.windowing
-
Specifies the conditions under which an on-time pane will be created when a window is closed.
- windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
- windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
- windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
- windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
- windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
- windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
- windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
- windowCoder() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
Returns the
Coderused for serializing the windows used by this windowFn. - windowCoder() - Method in class org.apache.beam.sdk.util.IdentityWindowFn
- windowCoderId() - Method in class org.apache.beam.sdk.util.construction.ModelCoders.WindowedValueCoderComponents
- WINDOWED_VALUE_CODER_URN - Static variable in class org.apache.beam.sdk.util.construction.ModelCoders
- WindowedContext() - Constructor for class org.apache.beam.sdk.transforms.DoFn.WindowedContext
- windowedFilename(int, int, BoundedWindow, PaneInfo, FileBasedSink.OutputFileHints) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy
- windowedFilename(int, int, BoundedWindow, PaneInfo, FileBasedSink.OutputFileHints) - Method in class org.apache.beam.sdk.io.FileBasedSink.FilenamePolicy
-
When a sink has requested windowed or triggered output, this method will be invoked to return the file
resourceto be created given the base output directory and aFileBasedSink.OutputFileHintscontaining information about the file, including a suggested extension (e.g. - windowedMultiReceiver(DoFn.WindowedContext, OutputBuilderSupplier) - Static method in class org.apache.beam.sdk.transforms.DoFnOutputReceivers
-
Returns a
DoFn.MultiOutputReceiverthat delegates to aDoFn.WindowedContext. - windowedMultiReceiver(DoFn.WindowedContext, OutputBuilderSupplier, Map<TupleTag<?>, Coder<?>>) - Static method in class org.apache.beam.sdk.transforms.DoFnOutputReceivers
-
Returns a
DoFn.MultiOutputReceiverthat delegates to aDoFn.WindowedContext. - windowedReceiver(DoFn.WindowedContext, OutputBuilderSupplier, TupleTag<T>) - Static method in class org.apache.beam.sdk.transforms.DoFnOutputReceivers
-
Returns a
DoFn.OutputReceiverthat delegates to aDoFn.WindowedContext. - WindowedValue<T> - Interface in org.apache.beam.sdk.values
-
A value along with Beam's windowing information and all other metadata.
- windowedValueCoder(String, String) - Static method in class org.apache.beam.sdk.util.construction.ModelCoders
- WindowedValueCoderComponents() - Constructor for class org.apache.beam.sdk.util.construction.ModelCoders.WindowedValueCoderComponents
- WindowedValueMultiReceiver - Interface in org.apache.beam.sdk.util
-
Encapsulation of a method of output that can output a value with all of its windowing information to a tagged destination.
- WindowedValueReceiver<OutputT> - Interface in org.apache.beam.sdk.util
-
An encapsulated method of output that can output a value with all of its metadata.
- windowedValues(Iterable<WindowedValue<T>>) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns a new
Create.WindowedValuestransform that produces aPCollectioncontaining the elements of the providedIterablewith the specified windowing metadata. - windowedValues(WindowedValue<T>, WindowedValue<T>...) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns a new
Create.WindowedValuestransform that produces aPCollectioncontaining the specified elements with the specified windowing metadata. - WindowedValues - Class in org.apache.beam.sdk.values
-
Implementations of
WindowedValueand static utility methods. - WindowedValues.Builder<T> - Class in org.apache.beam.sdk.values
- WindowedValues.FullWindowedValueCoder<T> - Class in org.apache.beam.sdk.values
-
Coder for
WindowedValue. - WindowedValues.ParamWindowedValueCoder<T> - Class in org.apache.beam.sdk.values
-
A parameterized coder for
WindowedValue. - WindowedValues.SingleWindowedValue - Interface in org.apache.beam.sdk.values
-
A
WindowedValueswhich holds exactly single window per value. - WindowedValues.ValueOnlyWindowedValueCoder<T> - Class in org.apache.beam.sdk.values
-
Deprecated.Use ParamWindowedValueCoder instead, it is a general purpose implementation of the same concept but makes timestamp, windows and pane info configurable.
- WindowedValues.WindowedValueCoder<T> - Class in org.apache.beam.sdk.values
-
Abstract class for
WindowedValuecoder. - windowedWrites - Variable in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
-
Whether windowed writes are being used.
- WindowFn<T,W extends BoundedWindow> - Class in org.apache.beam.sdk.transforms.windowing
-
The argument to the
Windowtransform used to assign elements into windows and to determine how windows are merged. - WindowFn() - Constructor for class org.apache.beam.sdk.transforms.windowing.WindowFn
- WindowFn.AssignContext - Class in org.apache.beam.sdk.transforms.windowing
-
Information available when running
WindowFn.assignWindows(org.apache.beam.sdk.transforms.windowing.WindowFn.AssignContext). - WindowFn.MergeContext - Class in org.apache.beam.sdk.transforms.windowing
-
Information available when running
WindowFn.mergeWindows(org.apache.beam.sdk.transforms.windowing.WindowFn.MergeContext). - windowFnFromProto(RunnerApi.FunctionSpec) - Static method in class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- WindowFnTestUtils - Class in org.apache.beam.sdk.testing
-
A utility class for testing
WindowFns. - WindowFnTestUtils() - Constructor for class org.apache.beam.sdk.testing.WindowFnTestUtils
- WindowingStrategy<T,W extends BoundedWindow> - Class in org.apache.beam.sdk.values
-
A
WindowingStrategydescribes the windowing behavior for a specific collection of values. - WindowingStrategy.AccumulationMode - Enum in org.apache.beam.sdk.values
-
The accumulation modes that can be used with windowing.
- WindowingStrategyTranslation - Class in org.apache.beam.sdk.util.construction
-
Utilities for working with
WindowingStrategies. - WindowingStrategyTranslation() - Constructor for class org.apache.beam.sdk.util.construction.WindowingStrategyTranslation
- WindowIntoTranslation - Class in org.apache.beam.sdk.util.construction
-
Utility methods for translating a
Window.Assignto and fromRunnerApirepresentations. - WindowIntoTranslation() - Constructor for class org.apache.beam.sdk.util.construction.WindowIntoTranslation
- WindowIntoTranslation.Registrar - Class in org.apache.beam.sdk.util.construction
- WindowIntoTranslation.WindowIntoPayloadTranslator - Class in org.apache.beam.sdk.util.construction
- WindowMappingFn<TargetWindowT extends BoundedWindow> - Class in org.apache.beam.sdk.transforms.windowing
-
A function that takes the windows of elements in a main input and maps them to the appropriate window in a
PCollectionViewconsumed as aside input. - WindowMappingFn() - Constructor for class org.apache.beam.sdk.transforms.windowing.WindowMappingFn
-
Create a new
WindowMappingFnwithzeromaximum lookback. - WindowMappingFn(Duration) - Constructor for class org.apache.beam.sdk.transforms.windowing.WindowMappingFn
-
Create a new
WindowMappingFnwith the specified maximum lookback. - windowMappingFnFromProto(RunnerApi.FunctionSpec) - Static method in class org.apache.beam.sdk.util.construction.PCollectionViewTranslation
-
Converts a
RunnerApi.FunctionSpecinto aWindowMappingFnusing the URN. - windowOnlyContext(W) - Static method in class org.apache.beam.sdk.state.StateContexts
- windows() - Static method in class org.apache.beam.sdk.transforms.Reify
-
Create a
PTransformthat will reify information from the processing context into instances ofValueInSingleWindow. - windows() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn.MergeContext
-
Returns the current set of windows.
- windowsInValue() - Static method in class org.apache.beam.sdk.transforms.Reify
-
Create a
PTransformthat will output all inputKVswith the window pane info inside the value. - windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.BundleMethod
-
The type of window expected by this method, if any.
- windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialRestrictionMethod
-
The window type used by this method, if any.
- windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetInitialWatermarkEstimatorStateMethod
-
The window type used by this method, if any.
- windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.GetSizeMethod
-
The window type used by this method, if any.
- windowT() - Method in interface org.apache.beam.sdk.transforms.reflect.DoFnSignature.MethodWithExtraParameters
-
The type of window expected by this method, if any.
- windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewTrackerMethod
-
The window type used by this method, if any.
- windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.NewWatermarkEstimatorMethod
-
The window type used by this method, if any.
- windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerFamilyMethod
-
The window type used by this method, if any.
- windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnTimerMethod
-
The window type used by this method, if any.
- windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.OnWindowExpirationMethod
-
The window type used by this method, if any.
- windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.WindowParameter
- windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.ProcessElementMethod
-
The window type used by this method, if any.
- windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.SplitRestrictionMethod
-
The window type used by this method, if any.
- windowT() - Method in class org.apache.beam.sdk.transforms.reflect.DoFnSignature.TruncateRestrictionMethod
-
The window type used by this method, if any.
- WindowTracing - Class in org.apache.beam.sdk.util
-
Logging for window operations.
- WindowTracing() - Constructor for class org.apache.beam.sdk.util.WindowTracing
- with(PTransform<PBegin, PCollection<T>>) - Static method in class org.apache.beam.sdk.transforms.Flatten
-
Returns a
PTransformthat flattens the inputPCollectionwith the output of anotherPTransformresulting in aPCollectioncontaining all the elements of both the inputPCollections and the output of the givenPTransformas its output. - with(SimpleFunction<DataT, InputT>, Coder<InputT>, CombineFnBase.GlobalCombineFn<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
-
Returns a
CombineFns.ComposedCombineFnWithContextwith an additionalCombineFnBase.GlobalCombineFn. - with(SimpleFunction<DataT, InputT>, Coder, Combine.CombineFn<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposeCombineFnBuilder
-
Like
CombineFns.ComposeCombineFnBuilder.with(SimpleFunction, CombineFn, TupleTag)but with an explicit input coder. - with(SimpleFunction<DataT, InputT>, Coder, Combine.CombineFn<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
-
Returns a
CombineFns.ComposedCombineFnwith an additionalCombine.CombineFn. - with(SimpleFunction<DataT, InputT>, Coder, CombineWithContext.CombineFnWithContext<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposeCombineFnBuilder
-
Like
CombineFns.ComposeCombineFnBuilder.with(SimpleFunction, CombineFnWithContext, TupleTag)but with input coder. - with(SimpleFunction<DataT, InputT>, Coder, CombineWithContext.CombineFnWithContext<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
-
Returns a
CombineFns.ComposedCombineFnWithContextwith an additionalCombineWithContext.CombineFnWithContext. - with(SimpleFunction<DataT, InputT>, Combine.CombineFn<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposeCombineFnBuilder
-
Returns a
CombineFns.ComposedCombineFnthat can take additionalGlobalCombineFnsand apply them as a single combine function. - with(SimpleFunction<DataT, InputT>, Combine.CombineFn<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
-
Returns a
CombineFns.ComposedCombineFnwith an additionalCombine.CombineFn. - with(SimpleFunction<DataT, InputT>, CombineFnBase.GlobalCombineFn<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
-
Returns a
CombineFns.ComposedCombineFnWithContextwith an additionalCombineFnBase.GlobalCombineFn. - with(SimpleFunction<DataT, InputT>, CombineWithContext.CombineFnWithContext<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposeCombineFnBuilder
-
Returns a
CombineFns.ComposedCombineFnWithContextthat can take additionalGlobalCombineFnsand apply them as a single combine function. - with(SimpleFunction<DataT, InputT>, CombineWithContext.CombineFnWithContext<InputT, ?, OutputT>, TupleTag<OutputT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
-
Returns a
CombineFns.ComposedCombineFnWithContextwith an additionalCombineWithContext.CombineFnWithContext. - with(PCollection<T>) - Static method in class org.apache.beam.sdk.transforms.Flatten
-
Returns a
PTransformthat flattens the inputPCollectionwith a givenPCollectionresulting in aPCollectioncontaining all the elements of bothPCollections as its output. - withAccelerator(String) - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHints
-
Declares hardware accelerators that are desired to have in the execution environment.
- withAccumulatorCoder(CombineFnBase.GlobalCombineFn<? super InputT, AccumT, OutputT>, Coder<AccumT>) - Static method in class org.apache.beam.sdk.util.AppliedCombineFn
- withAccumulatorCoder(CombineFnBase.GlobalCombineFn<? super InputT, AccumT, OutputT>, Coder<AccumT>, Iterable<PCollectionView<?>>, KvCoder<K, InputT>, WindowingStrategy<?, ?>) - Static method in class org.apache.beam.sdk.util.AppliedCombineFn
- withAllFields() - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
- withAllowDuplicates(boolean) - Method in class org.apache.beam.sdk.transforms.Redistribute.RedistributeArbitrarily
- withAllowDuplicates(boolean) - Method in class org.apache.beam.sdk.transforms.Redistribute.RedistributeByKey
- withAllowedLateness(Duration) - Method in class org.apache.beam.sdk.transforms.windowing.Window
-
Override the amount of lateness allowed for data elements in the output
PCollectionand downstreamPCollectionsuntil explicitly set again. - withAllowedLateness(Duration) - Method in class org.apache.beam.sdk.values.WindowingStrategy
- withAllowedLateness(Duration, Window.ClosingBehavior) - Method in class org.apache.beam.sdk.transforms.windowing.Window
-
Override the amount of lateness allowed for data elements in the pipeline.
- withAllowedTimestampSkew(Duration) - Method in class org.apache.beam.sdk.transforms.WithTimestamps
-
Deprecated.This method permits a to elements to be emitted behind the watermark. These elements are considered late, and if behind the
allowed latenessof a downstreamPCollectionmay be silently dropped. See https://github.com/apache/beam/issues/18065 for details on a replacement. - withAlreadyMerged(boolean) - Method in class org.apache.beam.sdk.values.WindowingStrategy
- withArg(Class<? super ArgT>, ArgT) - Method in class org.apache.beam.sdk.util.InstanceBuilder
-
Adds an argument to be passed to the factory method.
- withAutoSharding() - Method in class org.apache.beam.sdk.io.FileIO.Write
- withAutoSharding() - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
- withAutoSharding() - Method in class org.apache.beam.sdk.io.TextIO.Write
- withAutoSharding() - Method in class org.apache.beam.sdk.io.WriteFiles
- withBadRecordErrorHandler(ErrorHandler<BadRecord, ?>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Configures a new
FileIO.Writewith an ErrorHandler. - withBadRecordErrorHandler(ErrorHandler<BadRecord, ?>) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
See
FileIO.Write.withBadRecordErrorHandler(ErrorHandler)for details on usage. - withBadRecordErrorHandler(ErrorHandler<BadRecord, ?>) - Method in class org.apache.beam.sdk.io.WriteFiles
-
See
FileIO.Write.withBadRecordErrorHandler(ErrorHandler)for details on usage. - withBaseFilename(ResourceId) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
-
Sets the base filename.
- withBaseFilename(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
-
Like
DefaultFilenamePolicy.Params.withBaseFilename(ResourceId), but takes in aValueProvider. - withBatchMaxBufferingDuration(Duration) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Returns a new
TextIO.TypedWritethat will batch the input records using specified max buffering duration. - withBatchMaxBufferingDuration(Duration) - Method in class org.apache.beam.sdk.io.TextIO.Write
- withBatchMaxBufferingDuration(Duration) - Method in class org.apache.beam.sdk.io.WriteFiles
-
Returns a new
WriteFilesthat will batch the input records using specified max buffering duration. - withBatchSize(Integer) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Returns a new
TextIO.TypedWritethat will batch the input records using specified batch size. - withBatchSize(Integer) - Method in class org.apache.beam.sdk.io.TextIO.Write
- withBatchSize(Integer) - Method in class org.apache.beam.sdk.io.WriteFiles
-
Returns a new
WriteFilesthat will batch the input records using specified batch size. - withBatchSizeBytes(Integer) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Returns a new
TextIO.TypedWritethat will batch the input records using specified batch size in bytes. - withBatchSizeBytes(Integer) - Method in class org.apache.beam.sdk.io.TextIO.Write
- withBatchSizeBytes(Integer) - Method in class org.apache.beam.sdk.io.WriteFiles
-
Returns a new
WriteFilesthat will batch the input records using specified batch size in bytes. - withByteSize(long) - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches
- withByteSize(long, SerializableFunction<InputT, Long>) - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches
- withClosingBehavior(Window.ClosingBehavior) - Method in class org.apache.beam.sdk.values.WindowingStrategy
- withCoder(Coder<T>) - Method in class org.apache.beam.sdk.transforms.Create.TimestampedValues
-
Returns a
Create.TimestampedValuesPTransform like this one that uses the givenCoder<T>to decode each of the objects into a value of typeT. - withCoder(Coder<T>) - Method in class org.apache.beam.sdk.transforms.Create.Values
-
Returns a
Create.ValuesPTransform like this one that uses the givenCoder<T>to decode each of the objects into a value of typeT. - withCoder(Coder<T>) - Method in class org.apache.beam.sdk.transforms.Create.WindowedValues
-
Returns a
Create.WindowedValuesPTransform like this one that uses the givenCoder<T>to decode each of the objects into a value of typeT. - withCompression(Compression) - Method in class org.apache.beam.sdk.io.CompressedSource
-
Like
CompressedSource.withDecompression(org.apache.beam.sdk.io.CompressedSource.DecompressingChannelFactory)but takes a canonicalCompression. - withCompression(Compression) - Method in class org.apache.beam.sdk.io.FileIO.ReadMatches
-
Reads files using the given
Compression. - withCompression(Compression) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Specifies to compress all generated shard files using the given
Compressionand, by default, append the respective extension to the filename. - withCompression(Compression) - Method in class org.apache.beam.sdk.io.TextIO.Read
-
Reads from input sources using the specified compression type.
- withCompression(Compression) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
-
Deprecated.Reads from input sources using the specified compression type.
- withCompression(Compression) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Returns a transform for writing to text files like this one but that compresses output using the given
Compression. - withCompression(Compression) - Method in class org.apache.beam.sdk.io.TextIO.Write
- withCompression(Compression) - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
-
Returns a transform for reading TFRecord files that decompresses all input files using the specified compression type.
- withCompression(Compression) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
-
Writes to output files using the specified compression type.
- withCompressionType(TextIO.CompressionType) - Method in class org.apache.beam.sdk.io.TextIO.Read
-
Deprecated.
- withCompressionType(TextIO.CompressionType) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
-
Deprecated.
- withCompressionType(TFRecordIO.CompressionType) - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
-
Deprecated.
- withCompressionType(TFRecordIO.CompressionType) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
-
Deprecated.
- withConfiguration(FileIO.MatchConfiguration) - Method in class org.apache.beam.sdk.io.FileIO.Match
-
Sets the
FileIO.MatchConfiguration. - withConfiguration(FileIO.MatchConfiguration) - Method in class org.apache.beam.sdk.io.FileIO.MatchAll
- withCPUCount(int) - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHints
-
Sets desired minimal CPU or vCPU count to have in transform's execution environment.
- withDecompression(CompressedSource.DecompressingChannelFactory) - Method in class org.apache.beam.sdk.io.CompressedSource
-
Return a
CompressedSourcethat is like this one but will decompress its underlying file with the givenCompressedSource.DecompressingChannelFactory. - WithDefault() - Constructor for class org.apache.beam.sdk.state.StateSpec.Cases.WithDefault
- WithDefault() - Constructor for class org.apache.beam.sdk.transforms.reflect.DoFnSignature.Parameter.Cases.WithDefault
- withDefaultValue(T) - Method in class org.apache.beam.sdk.transforms.View.AsSingleton
-
Default value to return for windows with no value in them.
- withDelimiter(byte[]) - Method in class org.apache.beam.sdk.io.TextIO.Read
-
Set the custom delimiter to be used in place of the default ones ('\r', '\n' or '\r\n').
- withDelimiter(byte[]) - Method in class org.apache.beam.sdk.io.TextIO.ReadFiles
- withDelimiter(char[]) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Specifies the delimiter after each string written.
- withDelimiter(char[]) - Method in class org.apache.beam.sdk.io.TextIO.Write
- withDescription(String) - Method in class org.apache.beam.sdk.schemas.Schema.Field
-
Returns a copy of the Field with the description set.
- withDestinationCoder(Coder<DestinationT>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Specifies a
Coderfor the destination type, if it can not be inferred fromFileIO.Write.by(org.apache.beam.sdk.transforms.SerializableFunction<UserT, DestinationT>). - withDirectExecutor() - Method in class org.apache.beam.sdk.fn.channel.ManagedChannelFactory
-
Returns a
ManagedChannelFactorylike this one, but will construct the channel to use the direct executor. - withDirectoryTreatment(FileIO.ReadMatches.DirectoryTreatment) - Method in class org.apache.beam.sdk.io.FileIO.ReadMatches
-
Controls how to handle directories in the input
PCollection. - withDropNullsOnWrite(Boolean) - Method in class org.apache.beam.sdk.util.RowJson.RowJsonSerializer
-
Serializer drops nulls on write if set to true instead of writing fieldName: null.
- withDuration(Duration) - Method in class org.apache.beam.sdk.transforms.Deduplicate.KeyedValues
-
Returns a
KeyedValuesPTransformlike this one but with the specified duration. - withDuration(Duration) - Method in class org.apache.beam.sdk.transforms.Deduplicate.Values
-
Returns a
ValuesPTransformlike this one but with the specified duration. - withDuration(Duration) - Method in class org.apache.beam.sdk.transforms.Deduplicate.WithRepresentativeValues
-
Return a
WithRepresentativeValuesPTransformthat is like this one, but with the specified deduplication duration. - withEarlyFirings(Trigger.OnceTrigger) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
- withEarlyFirings(Trigger.OnceTrigger) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
-
Creates a new
Triggerlike the this, except that it fires repeatedly whenever the givenTriggerfires before the watermark has passed the end of the window. - withElementMetadata(boolean) - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
- withEmptyGlobalWindowDestination(DestinationT) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
If
FileIO.Write.withIgnoreWindowing()is specified, specifies a destination to be used in case the collection is empty, to generate the (only, empty) output file. - withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.FileIO.Match
- withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.FileIO.MatchAll
- withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.FileIO.MatchConfiguration
-
Sets the
EmptyMatchTreatment. - withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.TextIO.Read
- withEmptyMatchTreatment(EmptyMatchTreatment) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
-
Deprecated.
- withEndKey(ByteKey) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
-
Returns new
ByteKeyRangelike this one, but with the specified end key. - withEnvironmentId(String) - Method in class org.apache.beam.sdk.values.WindowingStrategy
- withEpsilon(double) - Method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
-
Returns an
ApproximateQuantilesCombineFnthat's like this one except that it uses the specifiedepsilonvalue. - withExceptionReporting(Schema) - Static method in class org.apache.beam.sdk.transforms.JsonToRow
-
Enable Exception Reporting support.
- withExponent(double) - Method in class org.apache.beam.sdk.util.FluentBackoff
-
Returns a copy of this
FluentBackoffthat instead uses the specified exponent to control the exponential growth of delay. - withExtendedErrorInfo() - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
-
Adds the error message to the returned error Row.
- WithFailures - Class in org.apache.beam.sdk.transforms
-
A collection of utilities for writing transforms that can handle exceptions raised during processing of elements.
- WithFailures() - Constructor for class org.apache.beam.sdk.transforms.WithFailures
- WithFailures.ExceptionAsMapHandler<T> - Class in org.apache.beam.sdk.transforms
-
A simple handler that extracts information from an exception to a
Map<String, String>and returns aKVwhere the key is the input element that failed processing, and the value is the map of exception attributes. - WithFailures.ExceptionElement<T> - Class in org.apache.beam.sdk.transforms
-
The value type passed as input to exception handlers.
- WithFailures.Result<OutputT extends POutput,FailureElementT> - Class in org.apache.beam.sdk.transforms
-
An intermediate output type for PTransforms that allows an output collection to live alongside a collection of elements that failed the transform.
- WithFailures.ThrowableHandler<T> - Class in org.apache.beam.sdk.transforms
-
A handler that holds onto the
Throwablethat led to the exception, returning it along with the original value as aKV. - withFanout(int) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
- withFanout(int) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineGlobally
- withFanout(int) - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
Returns a
PTransformidentical to this, but that uses an intermediate node to combine parts of the data to reduce load on the final global combine step. - withFieldAccessDescriptors(Map<FieldAccessDescriptor, Object>) - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
-
Sets field values using the FieldAccessDescriptors.
- withFieldIds(Integer...) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Return a descriptor that access the specified fields.
- withFieldIds(Iterable<Integer>) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Return a descriptor that access the specified fields.
- withFieldIds(FieldAccessDescriptor, Integer...) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Return a descriptor that accesses the specified field ids as nested subfields of the baseDescriptor.
- withFieldIds(FieldAccessDescriptor, Iterable<Integer>) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Return a descriptor that accesses the specified field ids as nested subfields of the baseDescriptor.
- withFieldNameAs(String, String) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Add a field with a new name.
- withFieldNameAs(String, String) - Method in class org.apache.beam.sdk.schemas.transforms.Select.Fields
-
Add a single field to the selection, along with the name the field should take in the selected schema.
- withFieldNameAs(String, String) - Method in class org.apache.beam.sdk.schemas.transforms.Select.Flattened
-
Allows renaming a specific nested field.
- withFieldNames(Iterable<String>) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Return a descriptor that access the specified fields.
- withFieldNames(String...) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Return a descriptor that access the specified fields.
- withFieldNames(FieldAccessDescriptor, Iterable<String>) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Return a descriptor that accesses the specified field names as nested subfields of the baseDescriptor.
- withFieldNames(FieldAccessDescriptor, String...) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Return a descriptor that accesses the specified field names as nested subfields of the baseDescriptor.
- withFieldNamesAs(Map<String, String>) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Return a descriptor that accesses the specified fields, renaming those fields.
- withFields(Iterable<FieldAccessDescriptor.FieldDescriptor>) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Returns a
FieldAccessDescriptorthat accesses the specified fields. - withFields(FieldAccessDescriptor.FieldDescriptor...) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Returns a
FieldAccessDescriptorthat accesses the specified fields. - withFieldValue(Integer, Object) - Method in class org.apache.beam.sdk.values.Row.Builder
-
Set a field value using the field id.
- withFieldValue(Integer, Object) - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
-
Set a field value using the field id.
- withFieldValue(String, Object) - Method in class org.apache.beam.sdk.values.Row.Builder
-
Set a field value using the field name.
- withFieldValue(String, Object) - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
-
Set a field value using the field name.
- withFieldValue(FieldAccessDescriptor, Object) - Method in class org.apache.beam.sdk.values.Row.Builder
-
Set a field value using a FieldAccessDescriptor.
- withFieldValue(FieldAccessDescriptor, Object) - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
-
Set a field value using a FieldAccessDescriptor.
- withFieldValueGetters(Factory<List<FieldValueGetter<T, Object>>>, T) - Method in class org.apache.beam.sdk.values.Row.Builder
- withFieldValues(Map<String, Object>) - Method in class org.apache.beam.sdk.values.Row.Builder
-
Sets field values using the field names.
- withFieldValues(Map<String, Object>) - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
-
Sets field values using the field names.
- withFn(DoFn<InputT, OutputT>) - Method in class org.apache.beam.sdk.util.DoFnInfo
- withFooter(String) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Adds a footer string to each file.
- withFooter(String) - Method in class org.apache.beam.sdk.io.TextIO.Write
- withFooter(String) - Method in class org.apache.beam.sdk.io.TextIO.Sink
- withFormatFunction(SerializableFunction<UserT, String>) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Deprecated.
- withGapDuration(Duration) - Static method in class org.apache.beam.sdk.transforms.windowing.Sessions
-
Creates a
SessionsWindowFnwith the specified gap duration. - withHeader(String) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Adds a header string to each file.
- withHeader(String) - Method in class org.apache.beam.sdk.io.TextIO.Write
- withHeader(String) - Method in class org.apache.beam.sdk.io.TextIO.Sink
- withHint(String, ResourceHint) - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHints
-
Declares a custom resource hint that has a specified URN.
- withHintMatchesManyFiles() - Method in class org.apache.beam.sdk.io.TextIO.Read
-
Hints that the filepattern specified in
TextIO.Read.from(String)matches a very large number of files. - withHotKeyFanout(int) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
- withHotKeyFanout(int) - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
-
Like
Combine.PerKey.withHotKeyFanout(SerializableFunction), but returning the given constant value for every key. - withHotKeyFanout(SerializableFunction<? super K, Integer>) - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
-
If a single key has disproportionately many values, it may become a bottleneck, especially in streaming mode.
- withHotKeyFanout(SerializableFunction<Row, Integer>) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
- withIgnoreWindowing() - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Deprecated.Avoid usage of this method: its effects are complex and it will be removed in future versions of Beam. Right now it exists for compatibility with
WriteFiles. - withInitialBackoff(Duration) - Method in class org.apache.beam.sdk.util.FluentBackoff
-
Returns a copy of this
FluentBackoffthat instead uses the specified initial backoff duration. - withInputCoder(CombineFnBase.GlobalCombineFn<? super InputT, AccumT, OutputT>, CoderRegistry, KvCoder<K, InputT>) - Static method in class org.apache.beam.sdk.util.AppliedCombineFn
- withInputCoder(CombineFnBase.GlobalCombineFn<? super InputT, AccumT, OutputT>, CoderRegistry, KvCoder<K, InputT>, Iterable<PCollectionView<?>>, WindowingStrategy<?, ?>) - Static method in class org.apache.beam.sdk.util.AppliedCombineFn
- withInterceptors(List<ClientInterceptor>) - Method in class org.apache.beam.sdk.fn.channel.ManagedChannelFactory
-
Returns a
ManagedChannelFactorylike this one, but which will apply the providedClientInterceptorsto any channel it creates. - withInterval(Duration) - Method in class org.apache.beam.sdk.transforms.PeriodicImpulse
- withIsReady(Supplier<Boolean>) - Method in class org.apache.beam.sdk.fn.test.TestStreams.Builder
-
Returns a new
TestStreams.Builderlike this one with the specifiedCallStreamObserver.isReady()callback. - withKeyField(String) - Method in class org.apache.beam.sdk.schemas.transforms.CoGroup.Impl
- withKeyField(String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
- withKeyField(String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
Set the name of the key field in the resulting schema.
- WithKeys<T> - Class in org.apache.beam.sdk.schemas.transforms
- WithKeys<K,V> - Class in org.apache.beam.sdk.transforms
-
WithKeys<K, V>takes aPCollection<V>, and either a constant key of typeKor a function fromVtoK, and returns aPCollection<KV<K, V>>, where each of the values in the inputPCollectionhas been paired with either the constant key or a key computed from the value. - withKeyType(TypeDescriptor<K>) - Method in class org.apache.beam.sdk.transforms.WithKeys
-
Return a
WithKeysthat is like this one with the specified key type descriptor. - withLabel(String) - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
Set the item
label. - withLateFirings(Trigger.OnceTrigger) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
- withLateFirings(Trigger.OnceTrigger) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
-
Creates a new
Triggerlike the this, except that it fires repeatedly whenever the givenTriggerfires after the watermark has passed the end of the window. - withLinkUrl(String) - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
Set the item
link url. - withMatchConfiguration(FileIO.MatchConfiguration) - Method in class org.apache.beam.sdk.io.TextIO.Read
-
Sets the
FileIO.MatchConfiguration. - withMatchConfiguration(FileIO.MatchConfiguration) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
-
Deprecated.Sets the
FileIO.MatchConfiguration. - withMaxActiveBundlesPerWorker(int) - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHints
- withMaxBackoff(Duration) - Method in class org.apache.beam.sdk.util.FluentBackoff
-
Returns a copy of this
FluentBackoffthat limits the maximum backoff of an individual attempt to the specified duration. - withMaxBufferingDuration(Duration) - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches
-
Sets a time limit (in processing time) on how long an incomplete batch of elements is allowed to be buffered.
- withMaxCumulativeBackoff(Duration) - Method in class org.apache.beam.sdk.util.FluentBackoff
-
Returns a copy of this
FluentBackoffthat limits the total time spent in backoff returned across all calls toBackOff.nextBackOffMillis(). - withMaxInputSize(long) - Method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
-
Returns an
ApproximateQuantilesCombineFnthat's like this one except that it uses the specifiedmaxNumElementsvalue. - withMaxNumRecords(long) - Method in class org.apache.beam.sdk.io.BoundedReadFromUnboundedSource
-
Returns a new
BoundedReadFromUnboundedSourcethat reads a bounded amount of data from the givenUnboundedSource. - withMaxNumRecords(long) - Method in class org.apache.beam.sdk.io.Read.Unbounded
-
Returns a new
BoundedReadFromUnboundedSourcethat reads a bounded amount of data from the givenUnboundedSource. - withMaxNumWritersPerBundle(int) - Method in class org.apache.beam.sdk.io.WriteFiles
-
Set the maximum number of writers created in a bundle before spilling to shuffle.
- withMaxNumWritersPerBundle(Integer) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Set the maximum number of writers created in a bundle before spilling to shuffle.
- withMaxNumWritersPerBundle(Integer) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Set the maximum number of writers created in a bundle before spilling to shuffle.
- withMaxNumWritersPerBundle(Integer) - Method in class org.apache.beam.sdk.io.TextIO.Write
- withMaxNumWritersPerBundle(Integer) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
-
See
WriteFiles#withMaxNumWritersPerBundle(). - withMaxReadTime(Duration) - Method in class org.apache.beam.sdk.io.Read.Unbounded
-
Returns a new
BoundedReadFromUnboundedSourcethat reads a bounded amount of data from the givenUnboundedSource. - withMaxReadTime(Duration) - Method in class org.apache.beam.sdk.io.BoundedReadFromUnboundedSource
-
Returns a new
BoundedReadFromUnboundedSourcethat reads a bounded amount of data from the givenUnboundedSource. - withMaxReadTime(Duration) - Method in class org.apache.beam.sdk.io.GenerateSequence
-
Specifies to stop generating elements after the given time.
- withMaxRetries(int) - Method in class org.apache.beam.sdk.util.FluentBackoff
-
Returns a copy of this
FluentBackoffthat limits the total number of retries, aka the total number of calls toBackOff.nextBackOffMillis()before returningBackOff.STOP. - withMessage(String) - Static method in class org.apache.beam.sdk.util.construction.UnsupportedOverrideFactory
- withMetadata(String, byte[]) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Deprecated.use schema options instead.
- withMetadata(String, String) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Deprecated.use schema options instead.
- withMetadata(Map<String, byte[]>) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Deprecated.use schema options instead.
- withMinRam(long) - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHints
-
Sets desired minimal available RAM size to have in transform's execution environment.
- withMinRam(String) - Method in class org.apache.beam.sdk.transforms.resourcehints.ResourceHints
-
Sets desired minimal available RAM size to have in transform's execution environment.
- withMode(WindowingStrategy.AccumulationMode) - Method in class org.apache.beam.sdk.values.WindowingStrategy
- withMultiOutputs() - Method in class org.apache.beam.sdk.util.construction.External.SingleOutputExpandableTransform
- withName(String) - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
- withName(String) - Method in class org.apache.beam.sdk.schemas.Schema.Field
-
Returns a copy of the Field with the name set.
- withNamespace(Class<?>) - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
Set the item
namespacefrom the givenClass. - withNaming(FileIO.Write.FileNaming) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Specifies a custom strategy for generating filenames.
- withNaming(Contextful<Contextful.Fn<DestinationT, FileIO.Write.FileNaming>>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Like
FileIO.Write.withNaming(SerializableFunction)but allows accessing context, such as side inputs, from the function. - withNaming(SerializableFunction<DestinationT, FileIO.Write.FileNaming>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Specifies a custom strategy for generating filenames depending on the destination, similar to
FileIO.Write.withNaming(FileNaming). - withNestedField(int, FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Return a descriptor that access the specified nested field.
- withNestedField(String, FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Return a descriptor that access the specified nested field.
- withNestedField(FieldAccessDescriptor.FieldDescriptor, FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
- withNestedFieldAs(String, String, FieldAccessDescriptor) - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
Like
FieldAccessDescriptor.withNestedField(int, org.apache.beam.sdk.schemas.FieldAccessDescriptor)along with a rename of the nested field. - withNewIdPrefix(String) - Method in class org.apache.beam.sdk.util.construction.SdkComponents
-
Returns an SdkComponents like this one, but which will prefix all newly generated ids with the given string.
- withNoOutputTimestamp() - Method in interface org.apache.beam.sdk.state.Timer
-
Asserts that there is no output timestamp.
- withNoSpilling() - Method in class org.apache.beam.sdk.io.FileIO.Write
- withNoSpilling() - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
- withNoSpilling() - Method in class org.apache.beam.sdk.io.TextIO.Write
- withNoSpilling() - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
- withNoSpilling() - Method in class org.apache.beam.sdk.io.WriteFiles
-
Returns a new
WriteFilesthat writes all data without spilling, simplifying the pipeline. - withNullable(boolean) - Method in class org.apache.beam.sdk.schemas.Schema.Field
-
Returns a copy of the Field with isNullable set.
- withNullable(boolean) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
- withNullBehavior(RowJson.RowJsonDeserializer.NullBehavior) - Method in class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
-
Sets the behavior of the deserializer according to
RowJson.RowJsonDeserializer.NullBehavior. - withNullBehavior(RowJson.RowJsonDeserializer.NullBehavior) - Method in class org.apache.beam.sdk.util.RowJson.RowJsonDeserializer
-
Sets the behaviour of the deserializer when retrieving null values in the input JSON.
- withNumBuckets(Integer) - Method in class org.apache.beam.sdk.transforms.Redistribute.RedistributeArbitrarily
- withNumBuckets(Integer) - Method in class org.apache.beam.sdk.transforms.Reshuffle.ViaRandomKey
- withNumShards(int) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Specifies to use a given fixed number of shards per window.
- withNumShards(int) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Configures the number of output shards produced overall (when using unwindowed writes) or per-window (when using windowed writes).
- withNumShards(int) - Method in class org.apache.beam.sdk.io.TextIO.Write
- withNumShards(int) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
-
Writes to the provided number of shards.
- withNumShards(int) - Method in class org.apache.beam.sdk.io.WriteFiles
-
Returns a new
WriteFilesthat will write to the currentFileBasedSinkusing the specified number of shards. - withNumShards(ValueProvider<Integer>) - Method in class org.apache.beam.sdk.io.FileIO.Write
- withNumShards(ValueProvider<Integer>) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
- withNumShards(ValueProvider<Integer>) - Method in class org.apache.beam.sdk.io.TextIO.Write
- withNumShards(ValueProvider<Integer>) - Method in class org.apache.beam.sdk.io.WriteFiles
-
Returns a new
WriteFilesthat will write to the currentFileBasedSinkusing theValueProviderspecified number of shards. - withOffset(Duration) - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
-
Partitions the timestamp space into half-open intervals of the form [N * size + offset, (N + 1) * size + offset), where 0 is the epoch.
- withOffset(Duration) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
-
Assigns timestamps into half-open intervals of the form [N * period + offset, N * period + offset + size).
- withOnCompleted(Runnable) - Method in class org.apache.beam.sdk.fn.test.TestStreams.Builder
-
Returns a new
TestStreams.Builderlike this one with the specifiedStreamObserver.onCompleted()callback. - withOnError(Runnable) - Method in class org.apache.beam.sdk.fn.test.TestStreams.Builder
-
Returns a new
TestStreams.Builderlike this one with the specifiedStreamObserver.onError(java.lang.Throwable)callback. - withOnError(Consumer<Throwable>) - Method in class org.apache.beam.sdk.fn.test.TestStreams.Builder
-
Returns a new
TestStreams.Builderlike this one with the specifiedStreamObserver.onError(java.lang.Throwable)consumer. - withOnNext(Consumer<T>) - Static method in class org.apache.beam.sdk.fn.test.TestStreams
-
Creates a test
CallStreamObserverTestStreams.Builderthat forwardsStreamObserver.onNext(V)calls to the suppliedConsumer. - withOnTimeBehavior(Window.OnTimeBehavior) - Method in class org.apache.beam.sdk.transforms.windowing.Window
-
Override the default
Window.OnTimeBehavior, to control whether to output an empty on-time pane. - withOnTimeBehavior(Window.OnTimeBehavior) - Method in class org.apache.beam.sdk.values.WindowingStrategy
- withOptionalParticipation() - Method in class org.apache.beam.sdk.schemas.transforms.CoGroup.By
-
Means that this field will participate in a join even when not present, similar to SQL outer-join semantics.
- withOptions(Schema.Options) - Method in class org.apache.beam.sdk.schemas.Schema.Field
-
Returns a copy of the Field with the options set.
- withOptions(Schema.Options) - Method in class org.apache.beam.sdk.schemas.Schema
-
Returns a copy of the Schema with the options set.
- withOptions(Schema.Options.Builder) - Method in class org.apache.beam.sdk.schemas.Schema.Field
-
Returns a copy of the Field with the options set.
- withOptions(Schema.Options.Builder) - Method in class org.apache.beam.sdk.schemas.Schema
-
Returns a copy of the Schema with the options set.
- withoutDefaults() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
Returns a
PTransformidentical to this, but that does not attempt to provide a default value in the case of empty input. - withOutputCoder(Map<String, Coder<?>>) - Method in class org.apache.beam.sdk.util.construction.External.MultiOutputExpandableTransform
- withOutputCoder(Coder<?>) - Method in class org.apache.beam.sdk.util.construction.External.SingleOutputExpandableTransform
- withOutputCoder(Coder<OutputT>) - Method in class org.apache.beam.sdk.transforms.Watch.Growth
-
Specifies a
Coderto use for the outputs. - withOutputFilenames() - Method in class org.apache.beam.sdk.io.TextIO.Write
-
Specify that output filenames are wanted.
- withOutputKeyCoder(Coder<KeyT>) - Method in class org.apache.beam.sdk.transforms.Watch.Growth
-
Specifies the coder for the output key.
- withOutputParallelization(boolean) - Method in class org.apache.beam.sdk.io.FileIO.MatchAll
-
Like
Match#withOutputParallelization. - withOutputs(List<TimestampedValue<OutputT>>) - Method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
-
Returns a new
Watch.Growth.PollResultlike this one with the provided outputs. - withOutputSchema(Schema) - Method in class org.apache.beam.sdk.schemas.transforms.Select.Fields
-
Rename all output fields to match the specified schema.
- withOutputSchema(Schema) - Method in class org.apache.beam.sdk.schemas.transforms.Select.Flattened
-
Rename all output fields to match the specified schema.
- withOutputTags(TupleTag<OutputT>, TupleTagList) - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
-
Returns a new multi-output
ParDoPTransformthat's like thisPTransformbut with the specified output tags. - withOutputTimestamp(Instant) - Method in interface org.apache.beam.sdk.state.Timer
-
Sets event time timer's output timestamp.
- withoutSharding() - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Forces a single file as output and empty shard name template.
- withoutSharding() - Method in class org.apache.beam.sdk.io.TextIO.Write
- withoutSharding() - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
-
Forces a single file as output.
- withoutStrictParsing() - Method in class org.apache.beam.sdk.options.PipelineOptionsFactory.Builder
-
During parsing of the arguments, we will skip over improperly formatted and unknown arguments.
- withoutValidation() - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
-
Returns a transform for reading TFRecord files that has GCS path validation on pipeline creation disabled.
- withParent(Schema.TypeName) - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
- withPathPart(String) - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
- withPipeline(Pipeline) - Method in class org.apache.beam.sdk.util.construction.RehydratedComponents
-
Create a new
RehydratedComponentswith a pipeline attached. - withPollInterval(Duration) - Method in class org.apache.beam.sdk.transforms.Watch.Growth
-
Specifies how long to wait after a call to
Watch.Growth.PollFnbefore calling it again (if at all - according toWatch.Growth.PollResultand theWatch.Growth.TerminationCondition). - withPrecombining(boolean) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
Enable precombining.
- withPrefix(String) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Specifies a common prefix to use for all generated filenames, if using the default file naming.
- withPrefix(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Like
FileIO.Write.withPrefix(String)but with aValueProvider. - withRandomAccess() - Method in class org.apache.beam.sdk.transforms.View.AsList
-
Returns a PCollection view like this one, but whose resulting list will have RandomAccess (aka fast indexing).
- withRandomAccess(boolean) - Method in class org.apache.beam.sdk.transforms.View.AsList
-
Returns a PCollection view like this one, but whose resulting list will have RandomAccess (aka fast indexing) according to the input parameter.
- withRate(long, Duration) - Method in class org.apache.beam.sdk.io.GenerateSequence
-
Specifies to generate at most a given number of elements per a given period.
- withRepresentativeCoder(Coder<IdT>) - Method in class org.apache.beam.sdk.transforms.Deduplicate.WithRepresentativeValues
-
Return a
WithRepresentativeValuesPTransformthat is like this one, but with the specified id type coder. - withRepresentativeType(TypeDescriptor<IdT>) - Method in class org.apache.beam.sdk.transforms.Deduplicate.WithRepresentativeValues
-
Return a
WithRepresentativeValuesPTransformthat is like this one, but with the specified id type descriptor. - withRepresentativeType(TypeDescriptor<IdT>) - Method in class org.apache.beam.sdk.transforms.Distinct.WithRepresentativeValues
-
Return a
WithRepresentativeValuesPTransformthat is like this one, but with the specified output type descriptor. - withRepresentativeValueFn(SerializableFunction<T, IdT>) - Static method in class org.apache.beam.sdk.transforms.Deduplicate
-
Returns a deduplication transform that deduplicates values using the supplied representative value for up to 10 mins within the
processing time domain. - withRepresentativeValueFn(SerializableFunction<T, IdT>) - Static method in class org.apache.beam.sdk.transforms.Distinct
-
Returns a
Distinct<T, IdT>PTransform. - withResumeDelay(Duration) - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContinuation
-
Builder method to set the value of
DoFn.ProcessContinuation.resumeDelay(). - withRowSchema(Schema) - Method in class org.apache.beam.sdk.transforms.Create.Values
-
Returns a
Create.ValuesPTransform like this one that uses the givenSchemato represent objects. - withRunnerDeterminedSharding() - Method in class org.apache.beam.sdk.io.WriteFiles
-
Returns a new
WriteFilesthat will write to the currentFileBasedSinkwith runner-determined sharding. - withSchema(Schema) - Static method in class org.apache.beam.sdk.transforms.JsonToRow
- withSchema(Schema) - Static method in class org.apache.beam.sdk.values.Row
-
Creates a row builder with specified
Row.getSchema(). - withSchema(Schema, TypeDescriptor<T>, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Method in class org.apache.beam.sdk.transforms.Create.TimestampedValues
-
Returns a
Create.TimestampedValuesPTransform like this one that uses the givenSchemato represent objects. - withSchema(Schema, TypeDescriptor<T>, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Method in class org.apache.beam.sdk.transforms.Create.Values
-
Returns a
Create.ValuesPTransform like this one that uses the givenSchemato represent objects. - withSchema(Schema, TypeDescriptor<T>, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Method in class org.apache.beam.sdk.transforms.Create.WindowedValues
-
Returns a
Create.WindowedValuesPTransform like this one that uses the givenSchemato represent objects. - withSchemaAndNullBehavior(Schema, RowJson.RowJsonDeserializer.NullBehavior) - Static method in class org.apache.beam.sdk.transforms.JsonToRow
- withShard(int) - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
- withShardedKey() - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches
-
Outputs batched elements associated with sharded input keys.
- withSharding(PTransform<PCollection<UserT>, PCollectionView<Integer>>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Specifies a
PTransformto use for computing the desired number of shards in each window. - withSharding(PTransform<PCollection<UserT>, PCollectionView<Integer>>) - Method in class org.apache.beam.sdk.io.WriteFiles
-
Returns a new
WriteFilesthat will write to the currentFileBasedSinkusing the specifiedPTransformto compute the number of shards. - withShardingFunction(ShardingFunction<UserT, DestinationT>) - Method in class org.apache.beam.sdk.io.WriteFiles
-
Returns a new
WriteFilesthat will write to the currentFileBasedSinkusing the specified sharding function to assign shard for inputs. - withShardNameTemplate(String) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Uses the given
ShardNameTemplatefor naming output files. - withShardNameTemplate(String) - Method in class org.apache.beam.sdk.io.TextIO.Write
- withShardNameTemplate(String) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
-
Uses the given shard name template.
- withShardTemplate(String) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
-
Sets the shard template.
- withSideInput() - Method in class org.apache.beam.sdk.schemas.transforms.CoGroup.By
- withSideInput(String, PCollectionView<?>) - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
-
Returns a new multi-output
ParDoPTransformthat's like thisPTransformbut with the specified additional side inputs. - withSideInput(String, PCollectionView<?>) - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
-
Returns a new
ParDoPTransformthat's like thisPTransformbut with the specified additional side inputs. - withSideInputs(Iterable<? extends PCollectionView<?>>) - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
Returns a
PTransformidentical to this, but with the specified side inputs to use inCombineWithContext.CombineFnWithContext. - withSideInputs(Iterable<? extends PCollectionView<?>>) - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
- withSideInputs(Iterable<? extends PCollectionView<?>>) - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
-
Returns a
PTransformidentical to this, but with the specified side inputs to use inCombineWithContext.CombineFnWithContext. - withSideInputs(Iterable<? extends PCollectionView<?>>) - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
- withSideInputs(Iterable<? extends PCollectionView<?>>) - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
-
Returns a new
ParDoPTransformthat's like thisPTransformbut with the specified additional side inputs. - withSideInputs(List<PCollectionView<?>>) - Method in class org.apache.beam.sdk.io.WriteFiles
- withSideInputs(Map<String, PCollectionView<?>>) - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
-
Returns a new multi-output
ParDoPTransformthat's like thisPTransformbut with the specified additional side inputs. - withSideInputs(Map<String, PCollectionView<?>>) - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
-
Returns a new
ParDoPTransformthat's like thisPTransformbut with the specified additional side inputs. - withSideInputs(PCollectionView<?>...) - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
Returns a
PTransformidentical to this, but with the specified side inputs to use inCombineWithContext.CombineFnWithContext. - withSideInputs(PCollectionView<?>...) - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
- withSideInputs(PCollectionView<?>...) - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
-
Returns a
PTransformidentical to this, but with the specified side inputs to use inCombineWithContext.CombineFnWithContext. - withSideInputs(PCollectionView<?>...) - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
-
Returns a new multi-output
ParDoPTransformthat's like thisPTransformbut with the specified additional side inputs. - withSideInputs(PCollectionView<?>...) - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
-
Returns a new
ParDoPTransformthat's like thisPTransformbut with the specified additional side inputs. - withSingletonValues() - Method in class org.apache.beam.sdk.transforms.View.AsMap
-
Deprecated.this method simply returns this AsMap unmodified
- withSize(long) - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches
- withSkipHeaderLines(int) - Method in class org.apache.beam.sdk.io.TextIO.Read
- withSkipHeaderLines(int) - Method in class org.apache.beam.sdk.io.TextIO.ReadFiles
- withSkipIfEmpty() - Method in class org.apache.beam.sdk.io.WriteFiles
- withSkipIfEmpty(boolean) - Method in class org.apache.beam.sdk.io.WriteFiles
-
Set this sink to skip writing any files if the PCollection is empty.
- withStartingDay(int, int, int) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
- withStartingMonth(int, int) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
- withStartingYear(int) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
- withStartKey(ByteKey) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
-
Returns new
ByteKeyRangelike this one, but with the specified start key. - withSuffix(String) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
-
Sets the suffix.
- withSuffix(String) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Specifies a common suffix to use for all generated filenames, if using the default file naming.
- withSuffix(String) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Configures the filename suffix for written files.
- withSuffix(String) - Method in class org.apache.beam.sdk.io.TextIO.Write
- withSuffix(String) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
-
Writes to the file(s) with the given filename suffix.
- withSuffix(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Like
FileIO.Write.withSuffix(String)but with aValueProvider. - withTempDirectory(String) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Specifies a directory into which all temporary files will be placed.
- withTempDirectory(ResourceId) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Set the base directory used to generate temporary files.
- withTempDirectory(ResourceId) - Method in class org.apache.beam.sdk.io.TextIO.Write
- withTempDirectory(ValueProvider<String>) - Method in class org.apache.beam.sdk.io.FileIO.Write
- withTempDirectory(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Set the base directory used to generate temporary files.
- withTempDirectory(ValueProvider<ResourceId>) - Method in class org.apache.beam.sdk.io.TextIO.Write
- withTerminationPerInput(Watch.Growth.TerminationCondition<InputT, ?>) - Method in class org.apache.beam.sdk.transforms.Watch.Growth
-
Specifies a
Watch.Growth.TerminationConditionthat will be independently used for every input. - withThrottledTimeCounter(Counter) - Method in class org.apache.beam.sdk.util.FluentBackoff
- withTimeDomain(TimeDomain) - Method in class org.apache.beam.sdk.transforms.Deduplicate.KeyedValues
-
Returns a
KeyedValuesPTransformlike this one but with the specified time domain. - withTimeDomain(TimeDomain) - Method in class org.apache.beam.sdk.transforms.Deduplicate.Values
-
Returns a
ValuesPTransformlike this one but with the specified time domain. - withTimeDomain(TimeDomain) - Method in class org.apache.beam.sdk.transforms.Deduplicate.WithRepresentativeValues
-
Returns a
WithRepresentativeValuesPTransformlike this one but with the specified time domain. - withTimestampCombiner(TimestampCombiner) - Method in class org.apache.beam.sdk.transforms.windowing.Window
-
Override the default
TimestampCombiner, to control the output timestamp of values output from aGroupByKeyoperation. - withTimestampCombiner(TimestampCombiner) - Method in class org.apache.beam.sdk.values.WindowingStrategy
- withTimestampFn(SerializableFunction<Long, Instant>) - Method in class org.apache.beam.sdk.io.GenerateSequence
-
Specifies the function to use to assign timestamps to the elements.
- WithTimestamps<T> - Class in org.apache.beam.sdk.transforms
-
A
PTransformfor assigning timestamps to all the elements of aPCollection. - withTimeZone(DateTimeZone) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
- withTimeZone(DateTimeZone) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
- withTimeZone(DateTimeZone) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
- withTrigger(Trigger) - Method in class org.apache.beam.sdk.values.WindowingStrategy
- withType(Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Field
-
Returns a copy of the Field with the
Schema.FieldTypeset. - withType(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.transforms.Create.TimestampedValues
-
Returns a
Create.TimestampedValuesPTransform like this one that uses the givenTypeDescriptor<T>to determine theCoderto use to decode each of the objects into a value of typeT. - withType(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.transforms.Create.Values
-
Returns a
Create.ValuesPTransform like this one that uses the givenTypeDescriptor<T>to determine theCoderto use to decode each of the objects into a value of typeT. - withType(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.transforms.Create.WindowedValues
-
Returns a
Create.WindowedValuesPTransform like this one that uses the givenTypeDescriptor<T>to determine theCoderto use to decode each of the objects into a value of typeT. - withValidation() - Method in class org.apache.beam.sdk.options.PipelineOptionsFactory.Builder
-
After creation we will validate that
PipelineOptionsconforms to all the validation criteria from<T>. - withValidation() - Method in class org.apache.beam.sdk.options.PipelineOptionsFactory
-
After creation we will validate that
<T>conforms to all the validation criteria. - withValue(WindowedValue<OldT>, NewT) - Static method in class org.apache.beam.sdk.values.WindowedValues
-
Returns a new
WindowedValuethat is a copy of this one, but with a different value, which may have a new typeNewT. - withValue(OtherT) - Method in interface org.apache.beam.sdk.values.WindowedValue
-
A
WindowedValuewith identical metadata to the current one, but with the provided value. - withValue(OtherT) - Method in class org.apache.beam.sdk.values.WindowedValues.Builder
- withValueCoder(Coder<NewT>) - Method in class org.apache.beam.sdk.values.WindowedValues.FullWindowedValueCoder
- withValueCoder(Coder<NewT>) - Method in class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
- withValueCoder(Coder<NewT>) - Method in class org.apache.beam.sdk.values.WindowedValues.ValueOnlyWindowedValueCoder
-
Deprecated.
- withValueCoder(Coder<NewT>) - Method in class org.apache.beam.sdk.values.WindowedValues.WindowedValueCoder
-
Returns a new
WindowedValueCoderthat is a copy of this one, but with a different value coder. - withValueField(String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
- withWatermark(Instant) - Method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
-
Returns a new
Watch.Growth.PollResultlike this one with the provided watermark. - withWindowCoder(Coder<? extends BoundedWindow>) - Method in class org.apache.beam.sdk.transforms.Create.WindowedValues
-
Returns a
Create.WindowedValuesPTransform like this one that uses the givenCoder<T>to decode each of the objects into a value of typeT. - withWindowedWrites() - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
-
Specify that writes are windowed.
- withWindowedWrites() - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Preserves windowing of input elements and writes them to files based on the element's window.
- withWindowedWrites() - Method in class org.apache.beam.sdk.io.TextIO.Write
- withWindowedWrites() - Method in class org.apache.beam.sdk.io.WriteFiles
-
Returns a new
WriteFilesthat writes preserves windowing on it's input. - withWindowFn(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.values.WindowingStrategy
- withWritableByteChannelFactory(FileBasedSink.WritableByteChannelFactory) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
Returns a transform for writing to text files like this one but that has the given
FileBasedSink.WritableByteChannelFactoryto be used by theFileBasedSinkduring output. - withWritableByteChannelFactory(FileBasedSink.WritableByteChannelFactory) - Method in class org.apache.beam.sdk.io.TextIO.Write
- witValueField(String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
Set the name of the value field in the resulting schema.
- wrap(String) - Method in class org.apache.beam.sdk.testing.PAssert.PAssertionSite
- wrap(Throwable) - Method in class org.apache.beam.sdk.testing.PAssert.PAssertionSite
- wrap(Throwable) - Static method in exception org.apache.beam.sdk.util.UserCodeException
- wrapIf(boolean, Throwable) - Static method in exception org.apache.beam.sdk.util.UserCodeException
- wrapping(StreamObserver<V>) - Static method in class org.apache.beam.sdk.fn.stream.SynchronizedStreamObserver
-
Create a new
SynchronizedStreamObserverwhich will delegate all calls to the underlyingStreamObserver, synchronizing access to that observer. - wrapProcessContext(DoFn.ProcessContext) - Static method in class org.apache.beam.sdk.transforms.Contextful.Fn.Context
-
Convenience wrapper for creating a
Contextful.Fn.Contextfrom aDoFn.ProcessContext, to support the common case when aPTransformis invoking theclosurefrom inside aDoFn. - wrapSegment(String) - Static method in class org.apache.beam.sdk.metrics.Lineage
-
Wrap segment to valid segment name.
- write() - Static method in class org.apache.beam.sdk.io.FileIO
-
Writes elements to files using a
FileIO.Sink. - write() - Static method in class org.apache.beam.sdk.io.TextIO
-
A
PTransformthat writes aPCollectionto a text file (or multiple text files matching a sharding pattern), with each element of the input collection encoded into its own line. - write() - Static method in class org.apache.beam.sdk.io.TFRecordIO
-
A
PTransformthat writes aPCollectionto TFRecord file (or multiple TFRecord files matching a sharding pattern), with each element of the input collection encoded into its own record. - write(byte[]) - Method in class org.apache.beam.sdk.io.TFRecordIO.Sink
- write(byte[], int, int) - Method in class org.apache.beam.sdk.fn.stream.DataStreams.ElementDelimitedOutputStream
- write(byte[], int, int) - Method in class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
- write(byte[], int, int) - Method in class org.apache.beam.sdk.util.ByteStringOutputStream
- write(byte[], int, int) - Method in class org.apache.beam.sdk.util.ExposedByteArrayOutputStream
- write(byte[], int, int) - Method in class org.apache.beam.sdk.util.UnownedOutputStream
- write(int) - Method in class org.apache.beam.sdk.fn.stream.DataStreams.ElementDelimitedOutputStream
- write(int) - Method in class org.apache.beam.sdk.util.BufferedElementCountingOutputStream
- write(int) - Method in class org.apache.beam.sdk.util.ByteStringOutputStream
- write(int) - Method in class org.apache.beam.sdk.util.ExposedByteArrayOutputStream
- write(ElementT) - Method in interface org.apache.beam.sdk.io.FileIO.Sink
-
Appends a single element to the file.
- write(String) - Method in class org.apache.beam.sdk.io.TextIO.Sink
- write(ByteBuffer) - Method in class org.apache.beam.sdk.util.ShardingWritableByteChannel
-
Writes a buffer to all shards.
- write(OutputT) - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
-
Called for each value in the bundle.
- write(T) - Method in interface org.apache.beam.sdk.state.ValueState
-
Set the value.
- Write() - Constructor for class org.apache.beam.sdk.io.FileIO.Write
- Write() - Constructor for class org.apache.beam.sdk.io.TFRecordIO.Write
- WRITE_FILES_TRANSFORM_URN - Static variable in class org.apache.beam.sdk.util.construction.PTransformTranslation
- writeAndOwn(byte[]) - Method in class org.apache.beam.sdk.util.ExposedByteArrayOutputStream
-
Write
bto the stream and take the ownership ofb. - writeCompressed(WritableByteChannel) - Method in enum org.apache.beam.sdk.io.Compression
- writeCustomType() - Static method in class org.apache.beam.sdk.io.TextIO
-
A
PTransformthat writes aPCollectionto a text file (or multiple text files matching a sharding pattern), with each element of the input collection encoded into its own line. - writeDynamic() - Static method in class org.apache.beam.sdk.io.FileIO
-
Writes elements to files using a
FileIO.Sinkand grouping the elements using "dynamic destinations". - WriteErrorMetrics(String) - Constructor for class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.PTransformErrorHandler.WriteErrorMetrics
- WriteFiles<UserT,DestinationT,OutputT> - Class in org.apache.beam.sdk.io
-
A
PTransformthat writes to aFileBasedSink. - WriteFiles() - Constructor for class org.apache.beam.sdk.io.WriteFiles
- WriteFilesResult<DestinationT> - Class in org.apache.beam.sdk.io
-
The result of a
WriteFilestransform. - WriteFilesTranslation - Class in org.apache.beam.sdk.util.construction
-
Utility methods for translating a
WriteFilesto and fromRunnerApirepresentations. - WriteFilesTranslation() - Constructor for class org.apache.beam.sdk.util.construction.WriteFilesTranslation
- WriteFilesTranslation.Registrar - Class in org.apache.beam.sdk.util.construction
-
Registers
WriteFilesTranslation.WriteFilesTranslator. - writeFooter() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
-
Writes footer at the end of output files.
- writeHeader() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
-
Writes header at the beginning of output files.
- writeMetrics(MetricQueryResults) - Method in interface org.apache.beam.sdk.metrics.MetricsSink
- WriteOperation(FileBasedSink<?, DestinationT, OutputT>) - Constructor for class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
-
Constructs a WriteOperation using the default strategy for generating a temporary directory from the base output filename.
- WriteOperation(FileBasedSink<?, DestinationT, OutputT>, ResourceId) - Constructor for class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
-
Create a new WriteOperation.
- Writer(FileBasedSink.WriteOperation<DestinationT, OutputT>, String) - Constructor for class org.apache.beam.sdk.io.FileBasedSink.Writer
-
Construct a new
FileBasedSink.Writerthat will produce files of the given MIME type. - writeToPort(String, BeamFnApi.RemoteGrpcPort) - Static method in class org.apache.beam.sdk.fn.data.RemoteGrpcPortWrite
-
Create a
RemoteGrpcPortWritewhich writes theRunnerApi.PCollectionwith the provided Pipeline id to the providedBeamFnApi.RemoteGrpcPort. - writeToShard(int, ByteBuffer) - Method in class org.apache.beam.sdk.util.ShardingWritableByteChannel
-
Writes the buffer to the given shard.
- writeWithRunnerDeterminedSharding() - Static method in class org.apache.beam.sdk.util.construction.PTransformMatchers
- WS - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- WS - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
Y
- yamlStringFromMap(Map<String, Object>) - Static method in class org.apache.beam.sdk.schemas.utils.YamlUtils
- yamlStringToMap(String) - Static method in class org.apache.beam.sdk.schemas.utils.YamlUtils
- YamlUtils - Class in org.apache.beam.sdk.schemas.utils
- YamlUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.YamlUtils
- years(int) - Static method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows
-
Returns a
WindowFnthat windows elements into periods measured by years. - YYYY - Static variable in class org.apache.beam.sdk.util.RowStringInterpolator
Z
- ZERO_BACKOFF - Static variable in interface org.apache.beam.sdk.util.BackOff
-
Fixed back-off policy whose back-off time is always zero, meaning that the operation is retried immediately without waiting.
- ZIP - org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.
- ZIP - org.apache.beam.sdk.io.Compression
-
Zip compression.
- ZIP - org.apache.beam.sdk.io.TextIO.CompressionType
-
Deprecated.
- zipDirectory(File, File) - Static method in class org.apache.beam.sdk.util.ZipFiles
-
Zips an entire directory specified by the path.
- zipDirectory(File, OutputStream) - Static method in class org.apache.beam.sdk.util.ZipFiles
-
Zips an entire directory specified by the path.
- zipDirectoryOverwrite(File, File) - Static method in class org.apache.beam.sdk.util.ZipFiles
-
Zips an entire directory specified by the path.
- ZipFiles - Class in org.apache.beam.sdk.util
-
Functions for zipping a directory (including a subdirectory) into a ZIP-file or unzipping it again.
- ZLIB - org.apache.beam.sdk.io.TFRecordIO.CompressionType
-
Deprecated.
- ZSTD - org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.
- ZSTD - org.apache.beam.sdk.io.Compression
-
ZStandard compression.
- ZSTD - org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.
- ZSTD - org.apache.beam.sdk.io.TextIO.CompressionType
-
Deprecated.
- ZstdCoder<T> - Class in org.apache.beam.sdk.coders
-
Wraps an existing coder with Zstandard compression.
_
- _ATN - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- _ATN - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- _decisionToDFA - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- _decisionToDFA - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- _serializedATN - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- _serializedATN - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
- _sharedContextCache - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
- _sharedContextCache - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
All Classes All Packages