- abort() - Method in interface org.apache.beam.runners.fnexecution.state.StateDelegator.Registration
-
De-registers the handler for all future requests for state for the registered process bundle
instruction id.
- abort(Executor) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- absolute(String, String...) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
-
Construct a path from an absolute component path hierarchy.
- AbstractBeamCalcRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamRelNode to replace Project
and Filter
node.
- AbstractBeamCalcRel(RelOptCluster, RelTraitSet, RelNode, RexProgram) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.AbstractBeamCalcRel
-
- AbstractGetterTypeSupplier() - Constructor for class org.apache.beam.sdk.schemas.AutoValueSchema.AbstractGetterTypeSupplier
-
- AbstractJDBCResourceManager<T extends JdbcDatabaseContainer<?>> - Class in org.apache.beam.it.jdbc
-
- AbstractJDBCResourceManager(T, AbstractJDBCResourceManager.Builder<T>) - Constructor for class org.apache.beam.it.jdbc.AbstractJDBCResourceManager
-
- AbstractJDBCResourceManager.Builder<T extends JdbcDatabaseContainer<?>> - Class in org.apache.beam.it.jdbc
-
- AbstractPipelineLauncher - Class in org.apache.beam.it.gcp.dataflow
-
Abstract class covering the common operations between Classic and Flex templates.
- AbstractPipelineLauncher(Dataflow) - Constructor for class org.apache.beam.it.gcp.dataflow.AbstractPipelineLauncher
-
- AbstractReadFileRangesFn(SerializableFunction<String, ? extends FileBasedSource<InT>>, ReadAllViaFileBasedSource.ReadFileRangesFnExceptionHandler) - Constructor for class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform.AbstractReadFileRangesFn
-
- AbstractResult() - Constructor for class org.apache.beam.sdk.io.gcp.healthcare.FhirIO.Write.AbstractResult
-
- accept(BeamFnApi.Elements) - Method in class org.apache.beam.sdk.fn.data.BeamFnDataInboundObserver
-
- 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(T1, T2) - Method in interface org.apache.beam.sdk.function.ThrowingBiConsumer
-
- accept(T) - Method in interface org.apache.beam.sdk.function.ThrowingConsumer
-
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierContext
-
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierListContext
-
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionContext
-
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.FieldSpecifierContext
-
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierContext
-
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierListContext
-
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
-
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifyComponentContext
-
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.SimpleIdentifierContext
-
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.WildcardContext
-
- accept(SchemaZipFold.Context, Schema.FieldType, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold
-
Accepts two components, context.parent() is always ROW, MAP, ARRAY or absent.
- accept(SchemaZipFold.Context, Optional<Schema.Field>, Optional<Schema.Field>) - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold
-
Accepts two fields, context.parent() is always ROW.
- accessPattern() - Method in class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors.SideInputSpec
-
- accessSecret(String) - Method in class org.apache.beam.it.gcp.secretmanager.SecretManagerResourceManager
-
Calls Secret Manager with a Secret Version and returns the secret value.
- 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
-
- AccumulatingCombineFn() - Constructor for class org.apache.beam.sdk.transforms.Combine.AccumulatingCombineFn
-
- accumulatingFiredPanes() - Method in class org.apache.beam.sdk.transforms.windowing.Window
-
Returns a new Window
PTransform
that uses the registered WindowFn and
Triggering behavior, and that accumulates elements in a pane after they are triggered.
- ACCUMULATOR_NAME - Static variable in class org.apache.beam.runners.flink.metrics.FlinkMetricContainer
-
- AccumulatorCheckpointingSparkListener() - Constructor for class org.apache.beam.runners.spark.metrics.MetricsAccumulator.AccumulatorCheckpointingSparkListener
-
- ackDeadlineSeconds(PubsubClient.SubscriptionPath) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient
-
Return the ack deadline, in seconds, for subscription
.
- ackDeadlineSeconds(PubsubClient.SubscriptionPath) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubGrpcClient
-
- ackDeadlineSeconds(PubsubClient.SubscriptionPath) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubJsonClient
-
- ackDeadlineSeconds(PubsubClient.SubscriptionPath) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubTestClient
-
- ackId() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.IncomingMessage
-
Id to pass back to Pubsub to acknowledge receipt of this message.
- acknowledge(PubsubClient.SubscriptionPath, List<String>) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient
-
Acknowldege messages from subscription
with ackIds
.
- acknowledge(PubsubClient.SubscriptionPath, List<String>) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubGrpcClient
-
- acknowledge(PubsubClient.SubscriptionPath, List<String>) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubJsonClient
-
- acknowledge(PubsubClient.SubscriptionPath, List<String>) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubTestClient
-
- acquireTaskAttemptIdLock(Configuration, int) - Method in interface org.apache.beam.sdk.io.hadoop.format.ExternalSynchronization
-
- acquireTaskAttemptIdLock(Configuration, int) - Method in class org.apache.beam.sdk.io.hadoop.format.HDFSSynchronization
-
- acquireTaskIdLock(Configuration) - Method in interface org.apache.beam.sdk.io.hadoop.format.ExternalSynchronization
-
Creates
TaskID
with unique id among given job.
- acquireTaskIdLock(Configuration) - Method in class org.apache.beam.sdk.io.hadoop.format.HDFSSynchronization
-
- ActionFactory - Class in org.apache.beam.sdk.io.gcp.bigtable.changestreams.action
-
Factory class for creating instances that will handle different functions of DoFns.
- ActionFactory() - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.changestreams.action.ActionFactory
-
- ActionFactory - Class in org.apache.beam.sdk.io.gcp.spanner.changestreams.action
-
Factory class for creating instances that will handle each type of record within a change stream
query.
- ActionFactory() - Constructor for class org.apache.beam.sdk.io.gcp.spanner.changestreams.action.ActionFactory
-
- activate(MetricsContainer) - Method in class org.apache.beam.sdk.metrics.MetricsEnvironment.MetricsContainerHolder
-
- activate(MetricsContainer) - Method in interface org.apache.beam.sdk.metrics.MetricsEnvironment.MetricsEnvironmentState
-
- ACTIVE_PARTITION_READ_COUNT - Static variable in class org.apache.beam.sdk.io.gcp.spanner.changestreams.ChangeStreamMetrics
-
Counter for the active partition reads during the execution of the Connector.
- actuateProjectionPushdown(Map<TupleTag<?>, FieldAccessDescriptor>) - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.TypedRead
-
- actuateProjectionPushdown(Map<TupleTag<?>, FieldAccessDescriptor>) - Method in interface org.apache.beam.sdk.schemas.ProjectionProducer
-
Actuate a projection pushdown.
- add(MetricsContainerStepMap) - Method in class org.apache.beam.runners.flink.metrics.MetricsAccumulator
-
- add(MetricsContainerStepMap) - Method in class org.apache.beam.runners.spark.metrics.MetricsContainerStepMapAccumulator
-
- add(MetricsContainerStepMap) - Method in class org.apache.beam.runners.spark.structuredstreaming.metrics.MetricsAccumulator
-
- add(int, GlobalWatermarkHolder.SparkWatermarks) - Static method in class org.apache.beam.runners.spark.util.GlobalWatermarkHolder
-
- add(T) - Method in class org.apache.beam.runners.twister2.translators.functions.Twister2SinkFunction
-
- add(T, long, Coder<T>) - Method in class org.apache.beam.sdk.extensions.sketching.SketchFrequencies.Sketch
-
- add(T, Coder<T>) - Method in class org.apache.beam.sdk.extensions.sketching.SketchFrequencies.Sketch
-
- add(KV<byte[], byte[]>) - Method in class org.apache.beam.sdk.extensions.sorter.BufferedExternalSorter
-
- add(Class<?>, String) - Method in class org.apache.beam.sdk.extensions.sql.impl.UdfImplReflectiveFunctionBase.ParameterListBuilder
-
- add(Type, String, boolean) - Method in class org.apache.beam.sdk.extensions.sql.impl.UdfImplReflectiveFunctionBase.ParameterListBuilder
-
- add(T, long) - Method in class org.apache.beam.sdk.fn.data.WeightedList
-
- add(List<ValueInSingleWindow<T>>, TableDataInsertAllResponse.InsertErrors, TableReference, FailsafeValueInSingleWindow<TableRow, TableRow>) - Method in interface org.apache.beam.sdk.io.gcp.bigquery.ErrorContainer
-
- add(InputT) - Method in interface org.apache.beam.sdk.state.GroupingState
-
Add a value to the buffer.
- add(Iterable<TimestampedValue<T>>) - Static method in class org.apache.beam.sdk.testing.TestStream.ElementEvent
-
For internal use only: no backwards compatibility guarantees.
- add(long) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique
-
Deprecated.
Adds a value to the heap, returning whether the value is (large enough to be) in the heap.
- add(DisplayData.ItemSpec<?>) - Method in interface org.apache.beam.sdk.transforms.display.DisplayData.Builder
-
Register the given display item.
- addAccum(AccumT) - Method in interface org.apache.beam.sdk.state.CombiningState
-
Add an accumulator to this state cell.
- addAll(Map<Integer, Queue<GlobalWatermarkHolder.SparkWatermarks>>) - Static method in class org.apache.beam.runners.spark.util.GlobalWatermarkHolder
-
- addAll(WeightedList<T>) - Method in class org.apache.beam.sdk.fn.data.WeightedList
-
- addAll(List<T>, long) - Method in class org.apache.beam.sdk.fn.data.WeightedList
-
- addAnnotation(String, byte[]) - Method in class org.apache.beam.sdk.transforms.PTransform
-
- addArray(Collection<T>) - Method in class org.apache.beam.sdk.values.Row.Builder
-
- addArray(Object...) - Method in class org.apache.beam.sdk.values.Row.Builder
-
- addArrayField(String, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addAttempted(T, BiFunction<T, T, T>) - Method in class org.apache.beam.sdk.metrics.MetricResult
-
- addBatchWriteRequest(long, boolean) - Method in interface org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandler.Stats
-
- addBoolean(Map<String, Object>, String, boolean) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- 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
-
- addCoderAndEncodedRecord(Coder<T>, T) - Method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record.Builder
-
- addCollectionToSingletonOutput(PCollection<?>, String, PCollectionView<?>) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.StepTranslationContext
-
Adds an output to this CollectionToSingleton
Dataflow step, consuming the specified
input PValue
and producing the specified output PValue
.
- addCommitted(T, BiFunction<T, T, T>) - Method in class org.apache.beam.sdk.metrics.MetricResult
-
- addDataSet(String, DataSet<T>) - Method in class org.apache.beam.runners.flink.FlinkBatchPortablePipelineTranslator.BatchTranslationContext
-
- addDataStream(String, DataStream<T>) - Method in class org.apache.beam.runners.flink.FlinkStreamingPortablePipelineTranslator.StreamingTranslationContext
-
- addDateTimeField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addDecimalField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addDictionary(Map<String, Object>, String, Map<String, Object>) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- addDouble(Map<String, Object>, String, Double) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- addDoubleField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addElements(T, T...) - Method in class org.apache.beam.sdk.testing.TestStream.Builder
-
Adds the specified elements to the source with timestamp equal to the current watermark.
- addElements(TimestampedValue<T>, TimestampedValue<T>...) - Method in class org.apache.beam.sdk.testing.TestStream.Builder
-
Adds the specified elements to the source with the provided timestamps.
- addEncodingInput(Coder<?>) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.StepTranslationContext
-
Sets the encoding for this Dataflow step.
- 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
-
- addErrorForCode(int, String) - Method in class org.apache.beam.sdk.extensions.gcp.util.CustomHttpErrors.Builder
-
Adds a matcher to log the provided string if the error matches a particular status code.
- addErrorForCodeAndUrlContains(int, String, String) - Method in class org.apache.beam.sdk.extensions.gcp.util.CustomHttpErrors.Builder
-
Adds a matcher to log the provided string if the error matches a particular status code and
the url contains a certain string.
- 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.
- addFailure(String, String) - Method in class org.apache.beam.sdk.io.cdap.context.FailureCollectorWrapper
-
- addField(Schema.Field) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addField(String, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addFields(List<Schema.Field>) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addFields(Schema.Field...) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- AddFields - Class in org.apache.beam.sdk.schemas.transforms
-
A transform to add new nullable fields to a PCollection's schema.
- AddFields() - Constructor for class org.apache.beam.sdk.schemas.transforms.AddFields
-
- AddFields.Inner<T> - Class in org.apache.beam.sdk.schemas.transforms
-
Inner PTransform for AddFields.
- addFloatField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- AddHarnessIdInterceptor - Class in org.apache.beam.sdk.fn.channel
-
A ClientInterceptor
that 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 true
if it was added and false
otherwise.
- addIfNotDefault(DisplayData.ItemSpec<T>, T) - Method in interface org.apache.beam.sdk.transforms.display.DisplayData.Builder
-
Register the given display item if the value is different than the specified default.
- addIfNotNull(DisplayData.ItemSpec<?>) - Method in interface org.apache.beam.sdk.transforms.display.DisplayData.Builder
-
Register the given display item if the value is not null.
- addIncompleteNewPartitions(NewPartition) - Method in class org.apache.beam.sdk.io.gcp.bigtable.changestreams.reconciler.OrphanedMetadataCleaner
-
Add NewPartition if it hasn't been updated for 15 minutes.
- addIncompleteNewPartitions(NewPartition) - Method in class org.apache.beam.sdk.io.gcp.bigtable.changestreams.reconciler.PartitionReconciler
-
Capture NewPartition row that cannot merge on its own.
- addInput(String, Boolean) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.StepTranslationContext
-
Adds an input with the given name and value to this Dataflow step.
- addInput(String, String) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.StepTranslationContext
-
Adds an input with the given name and value to this Dataflow step.
- addInput(String, Long) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.StepTranslationContext
-
Adds an input with the given name and value to this Dataflow step.
- addInput(String, PInput) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.StepTranslationContext
-
Adds an input with the given name to this Dataflow step, coming from the specified input
PValue.
- addInput(String, Map<String, Object>) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.StepTranslationContext
-
Adds an input that is a dictionary of strings to objects.
- addInput(String, List<? extends Map<String, Object>>) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.StepTranslationContext
-
Adds an input that is a list of objects.
- addInput(HyperLogLogPlus, InputT) - Method in class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct.ApproximateDistinctFn
-
- addInput(SketchFrequencies.Sketch<InputT>, InputT) - Method in class org.apache.beam.sdk.extensions.sketching.SketchFrequencies.CountMinSketchFn
-
- addInput(MergingDigest, Double) - Method in class org.apache.beam.sdk.extensions.sketching.TDigestQuantiles.TDigestQuantilesFn
-
- addInput(AccumT, InputT) - Method in class org.apache.beam.sdk.extensions.sql.impl.LazyAggregateCombineFn
-
- addInput(long[], Boolean) - Method in class org.apache.beam.sdk.extensions.sql.impl.transform.agg.CountIf.CountIfFn
-
- addInput(CovarianceAccumulator, Row) - Method in class org.apache.beam.sdk.extensions.sql.impl.transform.agg.CovarianceFn
-
- addInput(VarianceAccumulator, T) - Method in class org.apache.beam.sdk.extensions.sql.impl.transform.agg.VarianceFn
-
- addInput(BeamBuiltinAggregations.BitXOr.Accum, T) - Method in class org.apache.beam.sdk.extensions.sql.impl.transform.BeamBuiltinAggregations.BitXOr
-
- addInput(AccumT, InputT, Long, Long, Long) - Method in class org.apache.beam.sdk.extensions.sql.impl.transform.BeamBuiltinAnalyticFunctions.PositionAwareCombineFn
-
- addInput(AccumT, InputT) - Method in class org.apache.beam.sdk.extensions.sql.impl.transform.BeamBuiltinAnalyticFunctions.PositionAwareCombineFn
-
- addInput(List<T>, T) - Method in class org.apache.beam.sdk.extensions.sql.impl.udaf.ArrayAgg.ArrayAggArray
-
- addInput(String, byte[]) - Method in class org.apache.beam.sdk.extensions.sql.impl.udaf.StringAgg.StringAggByte
-
- addInput(String, String) - Method in class org.apache.beam.sdk.extensions.sql.impl.udaf.StringAgg.StringAggString
-
- addInput(Long, Long) - Method in class org.apache.beam.sdk.extensions.sql.provider.UdfTestProvider.Sum
-
- addInput(AccumT, InputT) - Method in class org.apache.beam.sdk.extensions.sql.TypedCombineFnDelegate
-
- addInput(AccumT, InputT) - Method in interface org.apache.beam.sdk.extensions.sql.udf.AggregateFn
-
Adds the given input value to the given accumulator, returning the new accumulator value.
- addInput(List<String>, String) - Method in class org.apache.beam.sdk.io.snowflake.SnowflakeIO.Concatenate
-
- addInput(ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique, T) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
-
Deprecated.
- addInput(InputT) - Method in interface org.apache.beam.sdk.transforms.Combine.AccumulatingCombineFn.Accumulator
-
Adds the given input value to this accumulator, modifying this accumulator.
- addInput(AccumT, InputT) - Method in class org.apache.beam.sdk.transforms.Combine.AccumulatingCombineFn
-
- addInput(double[], Double) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
-
- addInput(Combine.Holder<V>, V) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
-
- addInput(int[], Integer) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
-
- addInput(long[], Long) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
-
- addInput(AccumT, InputT) - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
-
Adds the given input value to the given accumulator, returning the new accumulator value.
- addInput(List<V>, V) - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
-
- addInput(Object[], DataT) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
-
- addInput(Object[], DataT, CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
-
- addInput(AccumT, InputT, CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
-
Adds the given input value to the given accumulator, returning the new accumulator value.
- addInput(Top.BoundedHeap<KV<Integer, T>, SerializableComparator<KV<Integer, T>>>, T) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
-
- addInt16Field(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addInt32Field(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addInt64Field(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addIterable(Iterable<T>) - Method in class org.apache.beam.sdk.values.Row.Builder
-
- addIterableField(String, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addLabel(String, String) - Method in class org.apache.beam.sdk.metrics.LabeledMetricNameUtils.MetricNameBuilder
-
Add a metric label KV pair to the metric name.
- addLengthPrefixedCoder(String, RunnerApi.Components.Builder, boolean) - Static method in class org.apache.beam.runners.fnexecution.wire.LengthPrefixUnknownCoders
-
- addList(Map<String, Object>, String, List<? extends Map<String, Object>>) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- addList(Map<String, Object>, String, T[]) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- addLogicalTypeConversions(GenericData) - Static method in class org.apache.beam.sdk.extensions.avro.schemas.utils.AvroUtils
-
- addLogicalTypeField(String, Schema.LogicalType<InputT, BaseT>) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addLong(Map<String, Object>, String, long) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- addLongs(Map<String, Object>, String, long...) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- addMapField(String, Schema.FieldType, Schema.FieldType) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addMessageListener(Consumer<JobApi.JobMessage>) - Method in class org.apache.beam.runners.jobsubmission.JobInvocation
-
Listen for job messages with a Consumer
.
- addMethodParameters(Method) - Method in class org.apache.beam.sdk.extensions.sql.impl.UdfImplReflectiveFunctionBase.ParameterListBuilder
-
- addMissingPartitions(List<Range.ByteStringRange>) - Method in class org.apache.beam.sdk.io.gcp.bigtable.changestreams.reconciler.OrphanedMetadataCleaner
-
Add all the missingPartitions.
- addMissingPartitions(List<Range.ByteStringRange>) - Method in class org.apache.beam.sdk.io.gcp.bigtable.changestreams.reconciler.PartitionReconciler
-
Capture partitions that are not currently being streamed.
- addNameFilter(MetricNameFilter) - Method in class org.apache.beam.sdk.metrics.MetricsFilter.Builder
-
- addNull(Map<String, Object>, String) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- 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
-
- addObject(Map<String, Object>, String, Map<String, Object>) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- addOptions(Schema.Options) - Method in class org.apache.beam.sdk.schemas.Schema.Options.Builder
-
- addOutput(String, PCollection<?>) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.StepTranslationContext
-
Adds a primitive output to this Dataflow step with the given name as the local output name,
producing the specified output PValue
, including its Coder
if a TypedPValue
.
- addOutput(Output) - Method in class org.apache.beam.sdk.io.cdap.context.BatchSinkContextImpl
-
Overrides the output configuration of this Batch job to the specified
Output
.
- addOutputColumnList(List<ResolvedNodes.ResolvedOutputColumn>) - Method in class org.apache.beam.sdk.extensions.sql.zetasql.QueryTrait
-
- addOverrideForClass(Class<?>, DataflowWorkerLoggingOptions.Level) - Method in class org.apache.beam.runners.dataflow.options.DataflowWorkerLoggingOptions.WorkerLogLevelOverrides
-
Deprecated.
Overrides the default log level for the passed in class.
- 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, DataflowWorkerLoggingOptions.Level) - Method in class org.apache.beam.runners.dataflow.options.DataflowWorkerLoggingOptions.WorkerLogLevelOverrides
-
Deprecated.
Overrides the default log level for the passed in name.
- 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, DataflowWorkerLoggingOptions.Level) - Method in class org.apache.beam.runners.dataflow.options.DataflowWorkerLoggingOptions.WorkerLogLevelOverrides
-
Deprecated.
Overrides the default log level for the passed in package.
- addOverrideForPackage(Package, SdkHarnessOptions.LogLevel) - Method in class org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides
-
Overrides the default log level for the passed in package.
- addProperties(MetadataEntity, Map<String, String>) - Method in class org.apache.beam.sdk.io.cdap.context.BatchContextImpl
-
- addResolvedTable(TableResolution.SimpleTableWithPath) - Method in class org.apache.beam.sdk.extensions.sql.zetasql.QueryTrait
-
Store a table together with its full path for repeated resolutions.
- addRowField(String, Schema) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addRows(Object...) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestBoundedTable
-
Add rows to the builder.
- addRows(String, Row...) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestTableProvider
-
- addRows(Duration, Object...) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestUnboundedTable
-
Add rows to the builder.
- addRunnerWireCoder(PipelineNode.PCollectionNode, RunnerApi.Components.Builder, RunnerApi.ExecutableStagePayload.WireCoderSetting) - Static method in class org.apache.beam.runners.fnexecution.wire.WireCoders
-
Creates a runner-side wire coder for a port read/write for the given PCollection.
- addSchema(String, TableProvider) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlEnv.BeamSqlEnvBuilder
-
Add a top-level schema backed by the table provider.
- addSdkWireCoder(PipelineNode.PCollectionNode, RunnerApi.Components.Builder, RunnerApi.ExecutableStagePayload.WireCoderSetting) - Static method in class org.apache.beam.runners.fnexecution.wire.WireCoders
-
Creates an SDK-side wire coder for a port read/write for the given PCollection.
- addSecretVersion(String, String) - Method in class org.apache.beam.it.gcp.secretmanager.SecretManagerResourceManager
-
Creates a new SecretVersion containing secret data and attaches it to an existing Secret.
- addStateListener(Consumer<JobApi.JobStateEvent>) - Method in class org.apache.beam.runners.jobsubmission.JobInvocation
-
Listen for job state changes with a Consumer
.
- addStep(PTransform<?, ?>, String) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.TranslationContext
-
Adds a step to the Dataflow workflow for the given transform, with the given Dataflow step
type.
- addStep(String) - Method in class org.apache.beam.sdk.metrics.MetricsFilter.Builder
-
Add a step filter.
- addString(Map<String, Object>, String, String) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- addStringField(String) - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- addStringList(Map<String, Object>, String, List<String>) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- addTags(MetadataEntity, String...) - Method in class org.apache.beam.sdk.io.cdap.context.BatchContextImpl
-
- addTags(MetadataEntity, Iterable<String>) - Method in class org.apache.beam.sdk.io.cdap.context.BatchContextImpl
-
- addTraceFor(AbstractGoogleClient, String) - Method in class org.apache.beam.sdk.extensions.gcp.options.GoogleApiDebugOptions.GoogleApiTracer
-
- addTraceFor(AbstractGoogleClientRequest<?>, String) - Method in class org.apache.beam.sdk.extensions.gcp.options.GoogleApiDebugOptions.GoogleApiTracer
-
- addUdaf(String, Combine.CombineFn) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlEnv.BeamSqlEnvBuilder
-
Register a UDAF function which can be used in GROUP-BY expression.
- addUdf(String, Class<?>, String) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlEnv.BeamSqlEnvBuilder
-
Register a UDF function which can be used in SQL expression.
- addUdf(String, Class<? extends BeamSqlUdf>) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlEnv.BeamSqlEnvBuilder
-
Register a UDF function which can be used in SQL expression.
- addUdf(String, SerializableFunction) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlEnv.BeamSqlEnvBuilder
-
Register a UDF function which can be used in SQL expression.
- addUuids() - Static method in class org.apache.beam.sdk.io.gcp.pubsublite.PubsubLiteIO
-
Add Uuids to to-be-published messages that ensures that uniqueness is maintained.
- AddUuidsTransform - Class in org.apache.beam.sdk.io.gcp.pubsublite.internal
-
A transform to add UUIDs to each message to be written to Pub/Sub Lite.
- AddUuidsTransform() - Constructor for class org.apache.beam.sdk.io.gcp.pubsublite.internal.AddUuidsTransform
-
- addValue(Object) - Method in class org.apache.beam.sdk.values.Row.Builder
-
- addValues(List<Object>) - Method in class org.apache.beam.sdk.values.Row.Builder
-
- addValues(Object...) - Method in class org.apache.beam.sdk.values.Row.Builder
-
- advance() - Method in class org.apache.beam.runners.spark.io.MicrobatchSource.Reader
-
- advance() - Static method in class org.apache.beam.runners.spark.util.GlobalWatermarkHolder
-
- advance() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubTestClient
-
For subscription mode only: Track progression of time according to the Clock
passed .
- advance() - Method in class org.apache.beam.sdk.io.gcp.pubsublite.internal.UnboundedReaderImpl
-
- 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.
- 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.
- advanceNextBatchWatermarkToInfinity() - Method in class org.apache.beam.runners.spark.io.CreateStream
-
Advances the watermark in the next batch to the end-of-time.
- 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.
- advanceWatermark() - Method in class org.apache.beam.runners.spark.stateful.SparkTimerInternals
-
Advances the watermark.
- advanceWatermarkForNextBatch(Instant) - Method in class org.apache.beam.runners.spark.io.CreateStream
-
Advances the watermark in the next batch.
- 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 Phaser
which 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
Trigger
that fires when all of its sub-triggers are ready.
- afterBundleCommit(Instant, DoFn.BundleFinalizer.Callback) - Method in interface org.apache.beam.sdk.transforms.DoFn.BundleFinalizer
-
The provided function will be called after the runner successfully commits the output of a
successful bundle.
- AfterEach - Class in org.apache.beam.sdk.transforms.windowing
-
A composite
Trigger
that executes its sub-triggers in order.
- AfterFirst - Class in org.apache.beam.sdk.transforms.windowing
-
A composite
Trigger
that fires once after at least one of its sub-triggers have fired.
- afterIterations(int) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
- AfterPane - Class in org.apache.beam.sdk.transforms.windowing
-
A
Trigger
that fires at some point after a specified number of input elements have
arrived.
- AfterProcessingTime - Class in org.apache.beam.sdk.transforms.windowing
-
A
Trigger
trigger that fires at a specified point in processing time, relative to when
input first arrives.
- AfterSynchronizedProcessingTime - Class in org.apache.beam.sdk.transforms.windowing
-
FOR INTERNAL USE ONLY.
- afterTimeSinceNewOutput(ReadableDuration) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
- afterTimeSinceNewOutput(SerializableFunction<InputT, ReadableDuration>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
- afterTotalOf(ReadableDuration) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
- afterTotalOf(SerializableFunction<InputT, ReadableDuration>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
- AfterWatermark - Class in org.apache.beam.sdk.transforms.windowing
-
AfterWatermark
triggers fire based on progress of the system watermark.
- AfterWatermark.AfterWatermarkEarlyAndLate - Class in org.apache.beam.sdk.transforms.windowing
-
- AfterWatermark.FromEndOfWindow - Class in org.apache.beam.sdk.transforms.windowing
-
A watermark trigger targeted relative to the end of the window.
- aggregate(Combine.CombineFn<InputT, ?, OutputT>) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
- AggregateCombiner() - Constructor for class org.apache.beam.sdk.schemas.transforms.Group.AggregateCombiner
-
- 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(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>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
Build up an aggregation function over the input elements.
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
- aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
Build up an aggregation function over the input elements.
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
- aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
Build up an aggregation function over the input elements.
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
- aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
Build up an aggregation function over the input elements.
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
- aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
Build up an aggregation function over the input elements.
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
- aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
Build up an aggregation function over the input elements.
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
- aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
Build up an aggregation function over the input elements.
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
- aggregateField(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
Build up an aggregation function over the input elements.
- aggregateField(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
- aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
- aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
- aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
- aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
- aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
- aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
- aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
- aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
- aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
- aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
- aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
- aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
- aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
- aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
- aggregateFieldBaseValue(String, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
- aggregateFieldBaseValue(int, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
- aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
Build up an aggregation function over the input elements.
- aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
Build up an aggregation function over the input elements.
- aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
Build up an aggregation function over the input elements.
- aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
Build up an aggregation function over the input elements.
- aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
Build up an aggregation function over the input elements.
- aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
Build up an aggregation function over the input elements.
- aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
Build up an aggregation function over the input elements.
- aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
Build up an aggregation function over the input elements.
- aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
Build up an aggregation function over the input elements.
- aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
Build up an aggregation function over the input elements.
- aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
Build up an aggregation function over the input elements.
- aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
Build up an aggregation function over the input elements.
- aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
Build up an aggregation function over the input elements.
- aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
Build up an aggregation function over the input elements.
- aggregateFields(List<String>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
Build up an aggregation function over the input elements.
- aggregateFields(FieldAccessDescriptor, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
Build up an aggregation function over the input elements.
- aggregateFieldsById(List<Integer>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, 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>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
- aggregateFieldsById(List<Integer>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
- aggregateFieldsById(List<Integer>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
- aggregateFieldsById(List<Integer>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
- aggregateFieldsById(List<Integer>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
- aggregateFieldsById(List<Integer>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, String) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
- aggregateFieldsById(List<Integer>, Combine.CombineFn<CombineInputT, AccumT, CombineOutputT>, Schema.Field) - Method in class org.apache.beam.sdk.schemas.transforms.Group.Global
-
- AggregateFn<InputT,AccumT,OutputT> - Interface in org.apache.beam.sdk.extensions.sql.udf
-
An aggregate function that can be executed as part of a SQL query.
- AggregationCombineFnAdapter<T> - Class in org.apache.beam.sdk.extensions.sql.impl.transform.agg
-
- AggregationCombineFnAdapter() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.transform.agg.AggregationCombineFnAdapter
-
- AggregationQuery - Class in org.apache.beam.sdk.io.mongodb
-
Builds a MongoDB AggregateIterable object.
- AggregationQuery() - Constructor for class org.apache.beam.sdk.io.mongodb.AggregationQuery
-
- algorithm(String) - Method in class org.apache.beam.sdk.io.aws2.s3.SSECustomerKey.Builder
-
- align(Duration) - Method in interface org.apache.beam.sdk.state.Timer
-
- alignedTo(Duration, Instant) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
-
Aligns timestamps to the smallest multiple of period
since the offset
greater
than the timestamp.
- alignedTo(Duration) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
-
Aligns the time to be the smallest multiple of period
greater than the epoch boundary
(aka new Instant(0)
).
- alignTo(Duration, Instant) - Static method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform
-
For internal use only; no backwards-compatibility guarantees.
- alignTo(Duration) - Static method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform
-
For internal use only; no backwards-compatibility guarantees.
- AlignTo() - Constructor for class org.apache.beam.sdk.transforms.windowing.TimestampTransform.AlignTo
-
- ALL_CONTEXTS - Static variable in class org.apache.beam.sdk.testing.CoderProperties
-
All the contexts, for use in test cases.
- ALL_KEYS - Static variable in class org.apache.beam.sdk.io.range.ByteKeyRange
-
The range of all keys, with empty start and end keys.
- allLeavesDescriptor(Schema, SerializableFunction<List<String>, String>) - Static method in class org.apache.beam.sdk.schemas.utils.SelectHelpers
-
- allMatches(String) - Static method in class org.apache.beam.sdk.transforms.Regex
-
- allMatches(Pattern) - Static method in class org.apache.beam.sdk.transforms.Regex
-
- AllMatches(Pattern) - Constructor for class org.apache.beam.sdk.transforms.Regex.AllMatches
-
- allMetrics() - Method in class org.apache.beam.sdk.metrics.MetricResults
-
- 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(ServiceT, ServerFactory) - Static method in class org.apache.beam.sdk.fn.server.GrpcFnServer
-
- allocatePortAndCreateFor(List<? extends FnService>, ServerFactory) - Static method in class org.apache.beam.sdk.fn.server.GrpcFnServer
-
- allOf(Iterable<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- allOf(SerializableMatcher<T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- allOf(Watch.Growth.TerminationCondition<InputT, FirstStateT>, Watch.Growth.TerminationCondition<InputT, SecondStateT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
- ALLOW_DUPLICATES - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- allowedTables() - Method in class org.apache.beam.it.gcp.datastream.JDBCSource
-
- ALLOWS_SHARDABLE_STATE - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- 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.
- AlwaysPassMatcher() - Constructor for class org.apache.beam.sdk.testing.TestPipelineOptions.AlwaysPassMatcher
-
- AlwaysPassMatcherFactory() - Constructor for class org.apache.beam.sdk.testing.TestPipelineOptions.AlwaysPassMatcherFactory
-
- alwaysRetry() - Static method in class org.apache.beam.sdk.io.gcp.bigquery.InsertRetryPolicy
-
Always retry all failures.
- alwaysUseRead() - Method in class org.apache.beam.sdk.transforms.Create.Values
-
- AmqpIO - Class in org.apache.beam.sdk.io.amqp
-
AmqpIO supports AMQP 1.0 protocol using the Apache QPid Proton-J library.
- AmqpIO.Read - Class in org.apache.beam.sdk.io.amqp
-
A
PTransform
to read/receive messages using AMQP 1.0 protocol.
- AmqpIO.Write - Class in org.apache.beam.sdk.io.amqp
-
A
PTransform
to send messages using AMQP 1.0 protocol.
- AmqpMessageCoder - Class in org.apache.beam.sdk.io.amqp
-
A coder for AMQP message.
- AmqpMessageCoder() - Constructor for class org.apache.beam.sdk.io.amqp.AmqpMessageCoder
-
- AmqpMessageCoderProviderRegistrar - Class in org.apache.beam.sdk.io.amqp
-
- AmqpMessageCoderProviderRegistrar() - Constructor for class org.apache.beam.sdk.io.amqp.AmqpMessageCoderProviderRegistrar
-
- and(ConditionCheck) - Method in class org.apache.beam.it.conditions.ConditionCheck
-
- and(TupleTag<V>, List<V>) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
Returns a new
CoGbkResult
based on this, with the given tag and given data added to it.
- and(TupleTag<V>, PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
Returns a new KeyedPCollectionTuple<K>
that is the same as this, appended with the
given PCollection.
- and(String, PCollection<KV<K, V>>) - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
- and(PCollection.IsBounded) - Method in enum org.apache.beam.sdk.values.PCollection.IsBounded
-
Returns the composed IsBounded property.
- and(PCollection<T>) - Method in class org.apache.beam.sdk.values.PCollectionList
-
- and(Iterable<PCollection<T>>) - Method in class org.apache.beam.sdk.values.PCollectionList
-
- and(String, PCollection<Row>) - Method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
- and(TupleTag<T>, PCollection<T>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
- and(String, PCollection<T>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
- and(TupleTag<?>) - Method in class org.apache.beam.sdk.values.TupleTagList
-
- and(List<TupleTag<?>>) - Method in class org.apache.beam.sdk.values.TupleTagList
-
- annotateFromBytes(PCollectionView<Map<ByteString, VideoContext>>, List<Feature>) - Static method in class org.apache.beam.sdk.extensions.ml.VideoIntelligence
-
Annotates videos from ByteStrings of their contents.
- annotateFromBytesWithContext(List<Feature>) - Static method in class org.apache.beam.sdk.extensions.ml.VideoIntelligence
-
Annotates videos from key-value pairs of ByteStrings and VideoContext.
- annotateFromURI(List<Feature>, PCollectionView<Map<String, VideoContext>>) - Static method in class org.apache.beam.sdk.extensions.ml.VideoIntelligence
-
Annotates videos from GCS URIs.
- annotateFromUriWithContext(List<Feature>) - Static method in class org.apache.beam.sdk.extensions.ml.VideoIntelligence
-
Annotates videos from key-value pairs of GCS URI and VideoContext.
- annotateImagesFromBytes(PCollectionView<Map<ByteString, ImageContext>>, List<Feature>, long, int) - Static method in class org.apache.beam.sdk.extensions.ml.CloudVision
-
Creates a
PTransform
that annotates images from their
contents encoded in
ByteString
s.
- annotateImagesFromBytes(PCollectionView<Map<ByteString, ImageContext>>, List<Feature>, long) - Static method in class org.apache.beam.sdk.extensions.ml.CloudVision
-
Creates a
PTransform
that annotates images from their
contents encoded in
ByteString
s.
- AnnotateImagesFromBytes(PCollectionView<Map<ByteString, ImageContext>>, List<Feature>, long, int) - Constructor for class org.apache.beam.sdk.extensions.ml.CloudVision.AnnotateImagesFromBytes
-
- annotateImagesFromBytesWithContext(List<Feature>, long, int) - Static method in class org.apache.beam.sdk.extensions.ml.CloudVision
-
Creates a
PTransform
that annotates images from KVs of
their GCS addresses in Strings and
ImageContext
for each image.
- annotateImagesFromBytesWithContext(List<Feature>, long) - Static method in class org.apache.beam.sdk.extensions.ml.CloudVision
-
Creates a
PTransform
that annotates images from KVs of
their GCS addresses in Strings and
ImageContext
for each image.
- AnnotateImagesFromBytesWithContext(List<Feature>, long, int) - Constructor for class org.apache.beam.sdk.extensions.ml.CloudVision.AnnotateImagesFromBytesWithContext
-
- annotateImagesFromGcsUri(PCollectionView<Map<String, ImageContext>>, List<Feature>, long, int) - Static method in class org.apache.beam.sdk.extensions.ml.CloudVision
-
Creates a
PTransform
that annotates images from their
GCS addresses.
- annotateImagesFromGcsUri(PCollectionView<Map<String, ImageContext>>, List<Feature>, long) - Static method in class org.apache.beam.sdk.extensions.ml.CloudVision
-
Creates a
PTransform
that annotates images from their
GCS addresses.
- AnnotateImagesFromGcsUri(PCollectionView<Map<String, ImageContext>>, List<Feature>, long, int) - Constructor for class org.apache.beam.sdk.extensions.ml.CloudVision.AnnotateImagesFromGcsUri
-
- annotateImagesFromGcsUriWithContext(List<Feature>, long, int) - Static method in class org.apache.beam.sdk.extensions.ml.CloudVision
-
Creates a
PTransform
that annotates images from KVs of
their String-encoded contents and
ImageContext
for each image.
- annotateImagesFromGcsUriWithContext(List<Feature>, long) - Static method in class org.apache.beam.sdk.extensions.ml.CloudVision
-
Creates a
PTransform
that annotates images from KVs of
their String-encoded contents and
ImageContext
for each image.
- AnnotateImagesFromGcsUriWithContext(List<Feature>, long, int) - Constructor for class org.apache.beam.sdk.extensions.ml.CloudVision.AnnotateImagesFromGcsUriWithContext
-
- AnnotateText - Class in org.apache.beam.sdk.extensions.ml
-
A
PTransform
using the Cloud AI Natural language processing capability.
- AnnotateText() - Constructor for class org.apache.beam.sdk.extensions.ml.AnnotateText
-
- AnnotateText.Builder - Class in org.apache.beam.sdk.extensions.ml
-
- AnnotateVideoFromBytes(PCollectionView<Map<ByteString, VideoContext>>, List<Feature>) - Constructor for class org.apache.beam.sdk.extensions.ml.VideoIntelligence.AnnotateVideoFromBytes
-
- AnnotateVideoFromBytesWithContext(List<Feature>) - Constructor for class org.apache.beam.sdk.extensions.ml.VideoIntelligence.AnnotateVideoFromBytesWithContext
-
- AnnotateVideoFromUri(PCollectionView<Map<String, VideoContext>>, List<Feature>) - Constructor for class org.apache.beam.sdk.extensions.ml.VideoIntelligence.AnnotateVideoFromUri
-
- AnnotateVideoFromURIWithContext(List<Feature>) - Constructor for class org.apache.beam.sdk.extensions.ml.VideoIntelligence.AnnotateVideoFromURIWithContext
-
- 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 a PCollection<T>
and a limit, and produces a new PCollection<T>
containing up to limit elements of the input PCollection
.
- anyCombineFn(int) - Static method in class org.apache.beam.sdk.transforms.Sample
-
Returns a
Combine.CombineFn
that computes a fixed-sized potentially non-uniform sample of its
inputs.
- anyOf(Iterable<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- anyOf(SerializableMatcher<T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- anything() - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- anyValueCombineFn() - Static method in class org.apache.beam.sdk.transforms.Sample
-
Returns a
Combine.CombineFn
that computes a single and potentially non-uniform sample value of
its inputs.
- API_METRIC_LABEL - Static variable in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryServicesImpl
-
- ApiIOError - Class in org.apache.beam.io.requestresponse
-
ApiIOError
is a data class for storing details about an error.
- ApiIOError() - Constructor for class org.apache.beam.io.requestresponse.ApiIOError
-
- append(K, W, Iterator<V>) - Method in interface org.apache.beam.runners.fnexecution.state.StateRequestHandlers.BagUserStateHandler
-
Appends the values to the bag user state for the given key and window.
- appendRows(long, ProtoRows) - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryServices.StreamAppendClient
-
Append rows to a Storage API write stream at the given offset.
- appendRowsRowStatusCounter(BigQuerySinkMetrics.RowStatus, String, String) - Static method in class org.apache.beam.sdk.io.gcp.bigquery.BigQuerySinkMetrics
-
- 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.
- apply(Tuple2<ByteArray, byte[]>) - Method in class org.apache.beam.runners.spark.coders.CoderHelpers.FromByteFunction
-
- apply(KV<String, Long>) - Method in class org.apache.beam.runners.spark.structuredstreaming.examples.WordCount.FormatAsTextFn
-
- apply(InputT) - Method in interface org.apache.beam.sdk.coders.DelegateCoder.CodingFunction
-
- apply(Pipeline, String, RunnerApi.FunctionSpec, Map<String, PCollection<?>>) - Method in interface org.apache.beam.sdk.expansion.service.TransformProvider
-
- apply(Schema, Schema) - Method in class org.apache.beam.sdk.extensions.avro.io.AvroDatumFactory.GenericDatumFactory
-
- apply(Schema) - Method in class org.apache.beam.sdk.extensions.avro.io.AvroDatumFactory.GenericDatumFactory
-
- apply(Schema, Schema) - Method in class org.apache.beam.sdk.extensions.avro.io.AvroDatumFactory.ReflectDatumFactory
-
- apply(Schema) - Method in class org.apache.beam.sdk.extensions.avro.io.AvroDatumFactory.ReflectDatumFactory
-
- apply(Schema, Schema) - Method in class org.apache.beam.sdk.extensions.avro.io.AvroDatumFactory.SpecificDatumFactory
-
- apply(Schema) - Method in class org.apache.beam.sdk.extensions.avro.io.AvroDatumFactory.SpecificDatumFactory
-
- apply(Schema) - Method in interface org.apache.beam.sdk.extensions.avro.io.AvroSink.DatumWriterFactory
-
- apply(Schema, Schema) - Method in interface org.apache.beam.sdk.extensions.avro.io.AvroSource.DatumReaderFactory
-
- apply(Row) - Method in class org.apache.beam.sdk.extensions.sql.impl.transform.BeamSetOperatorsTransforms.BeamSqlRow2KvFn
-
- apply(Iterable<? extends InputT>) - Method in class org.apache.beam.sdk.extensions.sql.TypedCombineFnDelegate
-
- apply(T1, T2) - Method in interface org.apache.beam.sdk.function.ThrowingBiFunction
-
- apply(T1) - Method in interface org.apache.beam.sdk.function.ThrowingFunction
-
- apply(String, T) - Method in interface org.apache.beam.sdk.io.aws2.sqs.SqsIO.WriteBatches.EntryMapperFn.Builder
-
- apply(Statement, Description) - Method in class org.apache.beam.sdk.io.gcp.bigquery.TestBigQuery
-
- apply(Row) - Method in class org.apache.beam.sdk.io.gcp.bigtable.BeamRowToBigtableMutation.ToBigtableRowFn
-
- apply(Row) - Method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableReadSchemaTransformProvider.BigtableRowToBeamRow
-
- apply(Row) - Method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableWriteSchemaTransformProvider.GetMutationsFromBeamRow
-
- apply(HealthcareIOError<T>) - Method in class org.apache.beam.sdk.io.gcp.healthcare.HealthcareIOErrorToTableRow
-
- apply(ValueInSingleWindow<byte[]>) - Method in class org.apache.beam.sdk.io.gcp.pubsub.ExternalWrite.ParsePubsubMessageProtoAsPayloadFromWindowedValue
-
- apply(byte[]) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessages.DeserializeBytesIntoPubsubMessagePayloadOnly
-
- apply(PubsubMessage) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessages.ParsePayloadAsPubsubMessageProto
-
- apply(byte[]) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessages.ParsePubsubMessageProtoAsPayload
-
- apply(Statement, Description) - Method in class org.apache.beam.sdk.io.gcp.pubsub.TestPubsub
-
- apply(Statement, Description) - Method in class org.apache.beam.sdk.io.gcp.pubsub.TestPubsubSignal
-
- apply(Void) - Method in class org.apache.beam.sdk.io.jdbc.JdbcIO.DataSourceProviderFromDataSourceConfiguration
-
- apply(SQLException) - Method in class org.apache.beam.sdk.io.jdbc.JdbcIO.DefaultRetryStrategy
-
- apply(Void) - Method in class org.apache.beam.sdk.io.jdbc.JdbcIO.PoolableDataSourceProvider
-
- apply(SQLException) - Method in interface org.apache.beam.sdk.io.jdbc.JdbcIO.RetryStrategy
-
- apply(String, Session) - Method in class org.apache.beam.sdk.io.jms.TextMessageMapper
-
- apply(TopicPartition) - Method in class org.apache.beam.sdk.io.kafka.CheckStopReadingFnWrapper
-
- apply(MongoCollection<Document>) - Method in class org.apache.beam.sdk.io.mongodb.AggregationQuery
-
- apply(MongoCollection<Document>) - Method in class org.apache.beam.sdk.io.mongodb.FindQuery
-
- apply(Void) - Method in class org.apache.beam.sdk.io.neo4j.Neo4jIO.DriverProviderFromDriverConfiguration
-
- apply(FileIO.ReadableFile, OffsetRange, Exception) - Method in class org.apache.beam.sdk.io.ReadAllViaFileBasedSource.ReadFileRangesFnExceptionHandler
-
- apply(Void) - Method in class org.apache.beam.sdk.io.snowflake.SnowflakeIO.DataSourceProviderFromDataSourceConfiguration
-
- apply(PTransform<? super PBegin, OutputT>) - Method in class org.apache.beam.sdk.Pipeline
-
- apply(String, PTransform<? super PBegin, OutputT>) - Method in class org.apache.beam.sdk.Pipeline
-
- apply(Schema, Schema) - Method in class org.apache.beam.sdk.schemas.transforms.Cast.Narrowing
-
- apply(Schema, Schema) - Method in interface org.apache.beam.sdk.schemas.transforms.Cast.Validator
-
- apply(Schema, Schema) - Method in class org.apache.beam.sdk.schemas.transforms.Cast.Widening
-
- apply(Schema, Schema) - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold
-
- apply(T) - Method in class org.apache.beam.sdk.testing.PAssert.MatcherCheckerFn
-
- apply(Statement, Description) - Method in class org.apache.beam.sdk.testing.TestPipeline
-
- apply(double, double) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
-
Applies the binary operation to the two operands, returning the result.
- apply(V, V) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
-
Applies the binary operation to the two operands, returning the result.
- apply(int, int) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
-
Applies the binary operation to the two operands, returning the result.
- apply(long, long) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
-
Applies the binary operation to the two operands, returning the result.
- apply(Iterable<? extends InputT>) - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
-
Applies this CombineFn
to a collection of input values to produce a combined output
value.
- apply(Iterable<? extends InputT>, CombineWithContext.Context) - Method in class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
-
Applies this CombineFnWithContext
to a collection of input values to produce a
combined output value.
- apply(InputT, Contextful.Fn.Context) - Method in interface org.apache.beam.sdk.transforms.Contextful.Fn
-
Invokes the function on the given input with the given context.
- apply(InputT) - Method in class org.apache.beam.sdk.transforms.InferableFunction
-
- apply(PTransform<KeyedPCollectionTuple<K>, OutputT>) - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
- apply(String, PTransform<KeyedPCollectionTuple<K>, OutputT>) - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
Applies the given
PTransform
to this input
KeyedPCollectionTuple
and returns
its
OutputT
.
- apply(InputT) - Method in interface org.apache.beam.sdk.transforms.ProcessFunction
-
Returns the result of invoking this function on the given input.
- apply(InputT) - Method in interface org.apache.beam.sdk.transforms.SerializableFunction
-
Returns the result of invoking this function on the given input.
- apply(InputT) - Method in class org.apache.beam.sdk.transforms.SimpleFunction
-
- apply(PrimitiveViewT) - Method in class org.apache.beam.sdk.transforms.ViewFn
-
A function to adapt a primitive view type to a desired view type.
- apply(WithFailures.ExceptionElement<T>) - Method in class org.apache.beam.sdk.transforms.WithFailures.ExceptionAsMapHandler
-
- apply(WithFailures.ExceptionElement<T>) - Method in class org.apache.beam.sdk.transforms.WithFailures.ThrowableHandler
-
- apply(PTransform<? super PBegin, OutputT>) - Method in class org.apache.beam.sdk.values.PBegin
-
- apply(String, PTransform<? super PBegin, OutputT>) - Method in class org.apache.beam.sdk.values.PBegin
-
Applies the given
PTransform
to this
PBegin
, using
name
to identify
this specific application of the transform.
- apply(PTransform<? super PCollection<T>, OutputT>) - Method in class org.apache.beam.sdk.values.PCollection
-
- apply(String, PTransform<? super PCollection<T>, OutputT>) - Method in class org.apache.beam.sdk.values.PCollection
-
Applies the given
PTransform
to this input
PCollection
, using
name
to
identify this specific application of the transform.
- apply(PTransform<PCollectionList<T>, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionList
-
- apply(String, PTransform<PCollectionList<T>, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionList
-
Applies the given
PTransform
to this input
PCollectionList
, using
name
to identify this specific application of the transform.
- apply(PTransform<? super PCollectionRowTuple, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
- apply(String, PTransform<? super PCollectionRowTuple, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionRowTuple
-
- apply(PTransform<? super PCollectionTuple, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
- apply(String, PTransform<? super PCollectionTuple, OutputT>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
- apply(Materializations.MultimapView<Void, T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryListFromMultimapViewFn
-
- apply(Materializations.IterableView<T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryListViewFn
-
- apply(Materializations.MultimapView<Void, KV<K, V>>) - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMapFromVoidKeyViewFn
-
- apply(Materializations.IterableView<KV<K, V>>) - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMapViewFn
-
- apply(Materializations.MultimapView<Void, KV<K, V>>) - Method in class org.apache.beam.sdk.values.PCollectionViews.InMemoryMultimapFromVoidKeyViewFn
-
- 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.IterableBackedListViewFn
-
- apply(Materializations.MultimapView<Void, T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn
-
Deprecated.
- apply(Materializations.IterableView<T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn2
-
- apply(Materializations.MultimapView<Void, T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.ListViewFn
-
Deprecated.
- 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.MapViewFn
-
Deprecated.
- apply(Materializations.MultimapView<K, V>) - Method in class org.apache.beam.sdk.values.PCollectionViews.MapViewFn2
-
- apply(Materializations.MultimapView<Void, KV<K, V>>) - Method in class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn
-
Deprecated.
- apply(Materializations.MultimapView<K, V>) - Method in class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn2
-
- apply(Materializations.MultimapView<Void, T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
-
Deprecated.
- apply(Materializations.IterableView<T>) - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn2
-
- applyBeamPTransform(DataSet<InputT>, PTransform<CollectionT, PCollection<OutputT>>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataSetAdapter
-
- applyBeamPTransform(Map<String, ? extends DataSet<?>>, PTransform<PCollectionTuple, PCollection<OutputT>>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataSetAdapter
-
- applyBeamPTransform(ExecutionEnvironment, PTransform<PBegin, PCollection<OutputT>>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataSetAdapter
-
- applyBeamPTransform(DataStream<InputT>, PTransform<CollectionT, PCollection<OutputT>>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataStreamAdapter
-
- applyBeamPTransform(Map<String, ? extends DataStream<?>>, PTransform<PCollectionTuple, PCollection<OutputT>>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataStreamAdapter
-
- applyBeamPTransform(StreamExecutionEnvironment, PTransform<PBegin, PCollection<OutputT>>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataStreamAdapter
-
- applyMultiOutputBeamPTransform(DataSet<InputT>, PTransform<CollectionT, PCollectionTuple>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataSetAdapter
-
- applyMultiOutputBeamPTransform(Map<String, ? extends DataSet<?>>, PTransform<PCollectionTuple, PCollectionTuple>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataSetAdapter
-
- applyMultiOutputBeamPTransform(ExecutionEnvironment, PTransform<PBegin, PCollectionTuple>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataSetAdapter
-
- applyMultiOutputBeamPTransform(DataStream<InputT>, PTransform<CollectionT, PCollectionTuple>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataStreamAdapter
-
- applyMultiOutputBeamPTransform(Map<String, ? extends DataStream<?>>, PTransform<PCollectionTuple, PCollectionTuple>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataStreamAdapter
-
- applyMultiOutputBeamPTransform(StreamExecutionEnvironment, PTransform<PBegin, PCollectionTuple>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataStreamAdapter
-
- applyNoOutputBeamPTransform(DataSet<InputT>, PTransform<CollectionT, PDone>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataSetAdapter
-
- applyNoOutputBeamPTransform(Map<String, ? extends DataSet<?>>, PTransform<PCollectionTuple, PDone>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataSetAdapter
-
- applyNoOutputBeamPTransform(ExecutionEnvironment, PTransform<PBegin, PDone>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataSetAdapter
-
- applyNoOutputBeamPTransform(DataStream<InputT>, PTransform<CollectionT, PDone>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataStreamAdapter
-
- applyNoOutputBeamPTransform(Map<String, ? extends DataStream<?>>, PTransform<PCollectionTuple, PDone>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataStreamAdapter
-
- applyNoOutputBeamPTransform(StreamExecutionEnvironment, PTransform<PBegin, PDone>) - Method in class org.apache.beam.runners.flink.adapter.BeamFlinkDataStreamAdapter
-
- applyRowMutations() - Static method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO
-
- applySdkEnvironmentOverrides(RunnerApi.Pipeline, DataflowPipelineOptions) - Method in class org.apache.beam.runners.dataflow.DataflowRunner
-
- 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
-
- ApproximateCountDistinct - Class in org.apache.beam.sdk.extensions.zetasketch
-
PTransform
s for estimating the number of distinct elements in a PCollection
, or
the number of distinct values associated with each key in a PCollection
of KV
s.
- ApproximateCountDistinct() - Constructor for class org.apache.beam.sdk.extensions.zetasketch.ApproximateCountDistinct
-
- ApproximateCountDistinct.Globally<T> - Class in org.apache.beam.sdk.extensions.zetasketch
-
PTransform
for estimating the number of distinct elements in a PCollection
.
- ApproximateCountDistinct.Globally.Builder<T> - Class in org.apache.beam.sdk.extensions.zetasketch
-
- ApproximateCountDistinct.PerKey<K,V> - Class in org.apache.beam.sdk.extensions.zetasketch
-
- ApproximateCountDistinct.PerKey.Builder<K,V> - Class in org.apache.beam.sdk.extensions.zetasketch
-
- ApproximateDistinct - Class in org.apache.beam.sdk.extensions.sketching
-
PTransform
s for computing the approximate number of distinct elements in a stream.
- ApproximateDistinct() - Constructor for class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct
-
- ApproximateDistinct.ApproximateDistinctFn<InputT> - Class in org.apache.beam.sdk.extensions.sketching
-
- ApproximateDistinct.GloballyDistinct<InputT> - Class in org.apache.beam.sdk.extensions.sketching
-
- ApproximateDistinct.HyperLogLogPlusCoder - Class in org.apache.beam.sdk.extensions.sketching
-
Coder for HyperLogLogPlus
class.
- ApproximateDistinct.PerKeyDistinct<K,V> - Class in org.apache.beam.sdk.extensions.sketching
-
- ApproximateQuantiles - Class in org.apache.beam.sdk.transforms
-
PTransform
s for getting an idea of a PCollection
's data distribution using
approximate N
-tiles (e.g.
- ApproximateQuantiles.ApproximateQuantilesCombineFn<T,ComparatorT extends java.util.Comparator<T> & java.io.Serializable> - Class in org.apache.beam.sdk.transforms
-
The ApproximateQuantilesCombineFn
combiner gives an idea of the distribution of a
collection of values using approximate N
-tiles.
- ApproximateUnique - Class in org.apache.beam.sdk.transforms
-
- ApproximateUnique() - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique
-
Deprecated.
- ApproximateUnique.ApproximateUniqueCombineFn<T> - Class in org.apache.beam.sdk.transforms
-
Deprecated.
CombineFn
that computes an estimate of the number of distinct values that were
combined.
- ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique - Class in org.apache.beam.sdk.transforms
-
Deprecated.
A heap utility class to efficiently track the largest added elements.
- ApproximateUnique.Globally<T> - Class in org.apache.beam.sdk.transforms
-
Deprecated.
PTransform
for estimating the number of distinct elements in a PCollection
.
- ApproximateUnique.PerKey<K,V> - Class in org.apache.beam.sdk.transforms
-
Deprecated.
PTransform
for estimating the number of distinct values associated with each key in a
PCollection
of KV
s.
- ApproximateUniqueCombineFn(long, Coder<T>) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
-
Deprecated.
- arbitrarily() - Static method in class org.apache.beam.sdk.transforms.Redistribute
-
- array() - Method in class org.apache.beam.runners.dataflow.util.RandomAccessData
-
Returns the backing array.
- array(TableSchema.ColumnType) - Static method in class org.apache.beam.sdk.io.clickhouse.TableSchema.ColumnType
-
- 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
-
- ARRAY_AGG_FN - Static variable in class org.apache.beam.sdk.extensions.sql.zetasql.translation.SqlOperators
-
- ArrayAgg - Class in org.apache.beam.sdk.extensions.sql.impl.udaf
-
- ArrayAgg() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.udaf.ArrayAgg
-
- ArrayAgg.ArrayAggArray<T> - Class in org.apache.beam.sdk.extensions.sql.impl.udaf
-
- ArrayAggArray() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.udaf.ArrayAgg.ArrayAggArray
-
- arrayContaining(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- arrayContaining(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- arrayContaining(SerializableMatcher<? super T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- arrayContaining(List<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- arrayContainingInAnyOrder(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- arrayContainingInAnyOrder(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- arrayContainingInAnyOrder(SerializableMatcher<? super T>...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- arrayContainingInAnyOrder(Collection<SerializableMatcher<? super T>>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- ArrayCopyState() - Constructor for class org.apache.beam.sdk.jmh.util.ByteStringOutputStreamBenchmark.NewVsCopy.ArrayCopyState
-
- arrayElementType() - Method in class org.apache.beam.sdk.io.clickhouse.TableSchema.ColumnType
-
- ArrayNewState() - Constructor for class org.apache.beam.sdk.jmh.util.ByteStringOutputStreamBenchmark.NewVsCopy.ArrayNewState
-
- ArrayOfNestedStringBundle() - Constructor for class org.apache.beam.sdk.jmh.schemas.RowBundles.ArrayOfNestedStringBundle
-
- ArrayOfStringBundle() - Constructor for class org.apache.beam.sdk.jmh.schemas.RowBundles.ArrayOfStringBundle
-
- arrayQualifier() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
-
- arrayQualifier() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierListContext
-
- ArrayQualifierContext(ParserRuleContext, int) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierContext
-
- ArrayQualifierListContext(FieldSpecifierNotationParser.QualifierListContext) - Constructor for class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierListContext
-
- arrayWithSize(int) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- arrayWithSize(SerializableMatcher<? super Integer>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- ArrowConversion - Class in org.apache.beam.sdk.extensions.arrow
-
Utilities to create
Iterable
s of Beam
Row
instances backed by Arrow record
batches.
- ArrowConversion.ArrowSchemaTranslator - Class in org.apache.beam.sdk.extensions.arrow
-
Converts Arrow schema to Beam row schema.
- ArrowConversion.RecordBatchRowIterator - Class in org.apache.beam.sdk.extensions.arrow
-
- arrowSchemaFromInput(InputStream) - Static method in class org.apache.beam.sdk.extensions.arrow.ArrowConversion
-
- ArrowSchemaTranslator() - Constructor for class org.apache.beam.sdk.extensions.arrow.ArrowConversion.ArrowSchemaTranslator
-
- Artifact - Interface in org.apache.beam.it.gcp.artifacts
-
Represents a single artifact.
- ArtifactAsserts - Class in org.apache.beam.it.gcp.artifacts.matchers
-
- ArtifactAsserts() - Constructor for class org.apache.beam.it.gcp.artifacts.matchers.ArtifactAsserts
-
- ArtifactClient - Interface in org.apache.beam.it.gcp.artifacts
-
Interface for working with test artifacts.
- ArtifactDestination() - Constructor for class org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService.ArtifactDestination
-
- ArtifactRetrievalService - Class in org.apache.beam.runners.fnexecution.artifact
-
- ArtifactRetrievalService() - Constructor for class org.apache.beam.runners.fnexecution.artifact.ArtifactRetrievalService
-
- ArtifactRetrievalService(ArtifactResolver) - Constructor for class org.apache.beam.runners.fnexecution.artifact.ArtifactRetrievalService
-
- ArtifactRetrievalService(int) - Constructor for class org.apache.beam.runners.fnexecution.artifact.ArtifactRetrievalService
-
- ArtifactRetrievalService(ArtifactResolver, int) - Constructor for class org.apache.beam.runners.fnexecution.artifact.ArtifactRetrievalService
-
- ArtifactsSubject - Class in org.apache.beam.it.gcp.artifacts.matchers
-
Subject that has assertion operations for artifact lists (GCS files), usually coming from the
result of a template.
- ArtifactStagingService - Class in org.apache.beam.runners.fnexecution.artifact
-
- ArtifactStagingService(ArtifactStagingService.ArtifactDestinationProvider) - Constructor for class org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService
-
- ArtifactStagingService.ArtifactDestination - Class in org.apache.beam.runners.fnexecution.artifact
-
A pairing of a newly created artifact type and an output stream that will be readable at that
type.
- ArtifactStagingService.ArtifactDestinationProvider - Interface in org.apache.beam.runners.fnexecution.artifact
-
Provides a concrete location to which artifacts can be staged on retrieval.
- ArtifactUtils - Class in org.apache.beam.it.gcp.artifacts.utils
-
Utilities for working with test artifacts.
- 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.
- asAvroRecords(Schema) - Method in class org.apache.beam.it.gcp.artifacts.matchers.ArtifactsSubject
-
Parse artifacts to Avro records to be used for assertions.
- asCloudObject(Coder<?>, SdkComponents) - Static method in class org.apache.beam.runners.dataflow.util.CloudObjects
-
- asInputStream(int, int) - Method in class org.apache.beam.runners.dataflow.util.RandomAccessData
-
Returns an InputStream
wrapper which supplies the portion of this backing byte buffer
starting at offset
and up to length
bytes.
- asIterable() - Static method in class org.apache.beam.sdk.transforms.View
-
- asJsonRecords() - Method in class org.apache.beam.it.gcp.artifacts.matchers.ArtifactsSubject
-
Parse artifacts as Json records to be used for assertions.
- AsJsons<InputT> - Class in org.apache.beam.sdk.extensions.jackson
-
PTransform
for serializing objects to JSON
Strings
.
- AsJsons.AsJsonsWithFailures<FailureT> - Class in org.apache.beam.sdk.extensions.jackson
-
A
PTransform
that adds exception handling to
AsJsons
.
- asList() - Static method in class org.apache.beam.sdk.transforms.View
-
- asMap() - Method in class org.apache.beam.sdk.transforms.display.DisplayData
-
- asMap() - Static method in class org.apache.beam.sdk.transforms.View
-
- asMultimap() - Static method in class org.apache.beam.sdk.transforms.View
-
- asOutputReference(PValue, AppliedPTransform<?, ?, ?>) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.TranslationContext
-
Encode a PValue reference as an output reference.
- asOutputStream() - Method in class org.apache.beam.runners.dataflow.util.RandomAccessData
-
Returns an output stream which writes to the backing buffer from the current position.
- asParquetRecords() - Method in class org.apache.beam.it.gcp.artifacts.matchers.ArtifactsSubject
-
Parse artifacts to Parquet GenericRecord to be used for assertions.
- asPath() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.PubsubSubscription
-
Returns the string representation of this subscription as a path used in the Cloud Pub/Sub
API.
- asPath() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.PubsubTopic
-
Returns the string representation of this topic as a path used in the Cloud Pub/Sub API.
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteTable
-
- asResponseObserver() - Method in class org.apache.beam.runners.fnexecution.control.FnApiControlClient
-
- assertionError() - Method in class org.apache.beam.sdk.testing.SuccessOrFailure
-
- assertSourcesEqualReferenceSource(BoundedSource<T>, List<? extends BoundedSource<T>>, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Given a reference Source
and a list of Source
s, assert that the union of the
records read from the list of sources is equal to the records read from the reference source.
- assertSplitAtFractionBehavior(BoundedSource<T>, int, double, SourceTestUtils.ExpectedSplitOutcome, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
- assertSplitAtFractionExhaustive(BoundedSource<T>, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Asserts that for each possible start position, BoundedSource.BoundedReader#splitAtFraction
at every interesting fraction (halfway between two
fractions that differ by at least one item) can be called successfully and the results are
consistent if a split succeeds.
- assertSplitAtFractionFails(BoundedSource<T>, int, double, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Asserts that the source
's reader fails to splitAtFraction(fraction)
after
reading numItemsToReadBeforeSplit
items.
- assertSplitAtFractionSucceedsAndConsistent(BoundedSource<T>, int, double, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Verifies some consistency properties of BoundedSource.BoundedReader#splitAtFraction
on
the given source.
- assertSubscriptionEventuallyCreated(String, Duration) - Method in class org.apache.beam.sdk.io.gcp.pubsub.TestPubsub
-
Block until a subscription is created for this test topic in the specified project.
- assertThatAllRows(Schema) - Method in class org.apache.beam.sdk.io.gcp.bigquery.TestBigQuery
-
- assertThatArtifact(Artifact) - Static method in class org.apache.beam.it.gcp.artifacts.matchers.ArtifactAsserts
-
Creates an
ArtifactsSubject
to assert information for an artifact obtained from Cloud
Storage.
- assertThatArtifacts(List<Artifact>) - Static method in class org.apache.beam.it.gcp.artifacts.matchers.ArtifactAsserts
-
Creates an
ArtifactsSubject
to assert information within a list of artifacts obtained
from Cloud Storage.
- assertThatBigQueryRecords(TableResult) - Static method in class org.apache.beam.it.gcp.bigquery.matchers.BigQueryAsserts
-
Creates a RecordsSubject
to assert information within a list of records.
- assertThatBigtableRecords(Iterable<Row>, String) - Static method in class org.apache.beam.it.gcp.bigtable.matchers.BigtableAsserts
-
Creates a RecordsSubject
to assert information within a list of records.
- assertThatCassandraRecords(Iterable<Row>) - Static method in class org.apache.beam.it.cassandra.matchers.CassandraAsserts
-
Creates a RecordsSubject
to assert information within a list of records.
- assertThatDatastoreRecords(Collection<Entity>) - Static method in class org.apache.beam.it.gcp.datastore.matchers.DatastoreAsserts
-
Creates a RecordsSubject
to assert information within a list of records.
- assertThatGenericRecords(List<GenericRecord>) - Static method in class org.apache.beam.it.gcp.artifacts.matchers.ArtifactAsserts
-
Creates an RecordsSubject
to assert information within a list of records.
- assertThatMongoDBDocuments(Collection<Document>) - Static method in class org.apache.beam.it.mongodb.matchers.MongoDBAsserts
-
Creates a RecordsSubject
to assert information within a list of records.
- assertThatMutations(List<Mutation>) - Static method in class org.apache.beam.it.gcp.spanner.matchers.SpannerAsserts
-
Creates a RecordsSubject
to assert information within a list of records.
- assertThatSplunkEvents(Collection<SplunkEvent>) - Static method in class org.apache.beam.it.splunk.matchers.SplunkAsserts
-
Creates a RecordsSubject
to assert information within a list of records.
- assertThatStructs(List<Struct>) - Static method in class org.apache.beam.it.gcp.spanner.matchers.SpannerAsserts
-
Creates a RecordsSubject
to assert information within a list of records.
- assertThatTopicEventuallyReceives(Matcher<PubsubMessage>...) - Method in class org.apache.beam.sdk.io.gcp.pubsub.TestPubsub
-
Repeatedly pull messages from
TestPubsub.subscriptionPath()
until receiving one for each matcher
(or timeout is reached), then assert that the received messages match the expectations.
- assertUnstartedReaderReadsSameAsItsSource(BoundedSource.BoundedReader<T>, PipelineOptions) - Static method in class org.apache.beam.sdk.testing.SourceTestUtils
-
Assert that a Reader
returns a Source
that, when read from, produces the same
records as the reader.
- assign(BoundedWindow, Instant) - Method in enum org.apache.beam.sdk.transforms.windowing.TimestampCombiner
-
- assignableTo(Schema) - Method in class org.apache.beam.sdk.schemas.Schema
-
Returns true if this Schema can be assigned to another Schema.
- assignableToIgnoreNullable(Schema) - Method in class org.apache.beam.sdk.schemas.Schema
-
Returns true if this Schema can be assigned to another Schema, ignoring nullable.
- AssignContext() - Constructor for class org.apache.beam.sdk.transforms.windowing.WindowFn.AssignContext
-
- assignDestinationMetadata(Row) - Method in interface org.apache.beam.sdk.io.iceberg.DynamicDestinations
-
- 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
WindowFn
always assigns an element to exactly one window.
- 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.
- AssignWindowP<T> - Class in org.apache.beam.runners.jet.processors
-
/** * Jet Processor
implementation for Beam's Windowing primitive.
- assignWindows(WindowFn<Object, IntervalWindow>.AssignContext) - Method in class org.apache.beam.sdk.extensions.sql.impl.TVFSlidingWindowFn
-
- assignWindows(WindowFn<Object, GlobalWindow>.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
-
- assignWindows(WindowFn<T, W>.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn
-
- assignWindows(WindowFn<Object, IntervalWindow>.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
-
- assignWindows(WindowFn<Object, IntervalWindow>.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
-
- assignWindows(Instant) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
-
- assignWindows(WindowFn<T, W>.AssignContext) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
Given a timestamp and element, returns the set of windows into which it should be placed.
- AssignWindowsFunction<T> - Class in org.apache.beam.runners.twister2.translators.functions
-
Assign Windows function.
- AssignWindowsFunction(WindowFn<T, BoundedWindow>, PipelineOptions) - Constructor for class org.apache.beam.runners.twister2.translators.functions.AssignWindowsFunction
-
- AssignWindowTranslatorBatch<T> - Class in org.apache.beam.runners.twister2.translators.batch
-
Assign Window translator.
- AssignWindowTranslatorBatch() - Constructor for class org.apache.beam.runners.twister2.translators.batch.AssignWindowTranslatorBatch
-
- asSingleton() - Static method in class org.apache.beam.sdk.transforms.View
-
- asSingletonView() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
Returns a
PTransform
that produces a
PCollectionView
whose elements are the
result of combining elements per-window in the input
PCollection
.
- assumeSingleMessageSchema() - Method in class org.apache.beam.sdk.extensions.sbe.SbeSchema.IrOptions
-
- ASTERISK - Static variable in class org.apache.beam.sdk.extensions.sql.impl.cep.Quantifier
-
- ASTERISK_RELUCTANT - Static variable in class org.apache.beam.sdk.extensions.sql.impl.cep.Quantifier
-
- asV1Beta1Path() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.PubsubSubscription
-
- asV1Beta1Path() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.PubsubTopic
-
- asV1Beta2Path() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.PubsubSubscription
-
- asV1Beta2Path() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.PubsubTopic
-
- AsyncBatchWriteHandler<RecT,ResT> - Class in org.apache.beam.sdk.io.aws2.common
-
Async handler that automatically retries unprocessed records in case of a partial success.
- AsyncBatchWriteHandler(int, FluentBackoff, AsyncBatchWriteHandler.Stats, Function<ResT, String>, BiFunction<String, List<RecT>, CompletableFuture<List<ResT>>>) - Constructor for class org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandler
-
- AsyncBatchWriteHandler.Stats - Interface in org.apache.beam.sdk.io.aws2.common
-
Statistics on the batch request.
- atMinimumTimestamp(V) - Static method in class org.apache.beam.sdk.values.TimestampedValue
-
- AtomicCoder<T> - Class in org.apache.beam.sdk.coders
-
A
Coder
that has no component
Coders
or other configuration.
- AtomicCoder() - Constructor for class org.apache.beam.sdk.coders.AtomicCoder
-
- AtomicLongFactory() - Constructor for class org.apache.beam.sdk.options.PipelineOptions.AtomicLongFactory
-
- attached() - Method in class org.apache.beam.sdk.io.gcp.spanner.MutationGroup
-
- attachValues(List<Object>) - Method in class org.apache.beam.sdk.values.Row.Builder
-
- attachValues(Object...) - Method in class org.apache.beam.sdk.values.Row.Builder
-
- attempted(MetricKey, T) - Static method in class org.apache.beam.sdk.metrics.MetricResult
-
- ATTRIBUTE_ARRAY_ENTRY_SCHEMA - Static variable in class org.apache.beam.sdk.io.gcp.pubsub.PubsubSchemaIOProvider
-
- ATTRIBUTE_ARRAY_FIELD_TYPE - Static variable in class org.apache.beam.sdk.io.gcp.pubsub.PubsubSchemaIOProvider
-
- ATTRIBUTE_MAP_FIELD_TYPE - Static variable in class org.apache.beam.sdk.io.gcp.pubsub.PubsubSchemaIOProvider
-
- AttributeValueCoder - Class in org.apache.beam.sdk.io.aws.dynamodb
-
- AttributeValueCoder - Class in org.apache.beam.sdk.io.aws2.dynamodb
-
- AttributeValueCoderProviderRegistrar - Class in org.apache.beam.sdk.io.aws.dynamodb
-
- AttributeValueCoderProviderRegistrar() - Constructor for class org.apache.beam.sdk.io.aws.dynamodb.AttributeValueCoderProviderRegistrar
-
- AUTH_VALIDATION_GROUP - Static variable in interface org.apache.beam.sdk.io.snowflake.SnowflakePipelineOptions
-
- AuthenticatedRetryInitializer(GoogleCredentials) - Constructor for class org.apache.beam.sdk.io.gcp.healthcare.HttpHealthcareApiClient.AuthenticatedRetryInitializer
-
- AUTO - Static variable in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- autoCastField(Schema.Field, Object) - Static method in class org.apache.beam.sdk.extensions.sql.impl.schema.BeamTableUtils
-
Attempt to cast an object to a specified Schema.Field.Type.
- autoLoadUserDefinedFunctions() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlEnv.BeamSqlEnvBuilder
-
- AutoScaler - Interface in org.apache.beam.sdk.io.jms
-
Enables users to specify their own `JMS` backlog reporters enabling
JmsIO
to report
UnboundedSource.UnboundedReader#getTotalBacklogBytes()
.
- AUTOVALUE_CLASS - Static variable in class org.apache.beam.sdk.io.kafka.KafkaIO.Read
-
- AUTOVALUE_CLASS - Static variable in class org.apache.beam.sdk.io.kafka.KafkaIO.Write
-
- AutoValueSchema - Class in org.apache.beam.sdk.schemas
-
- AutoValueSchema() - Constructor for class org.apache.beam.sdk.schemas.AutoValueSchema
-
- AutoValueSchema.AbstractGetterTypeSupplier - Class in org.apache.beam.sdk.schemas
-
- AutoValueUtils - Class in org.apache.beam.sdk.schemas.utils
-
Utilities for managing AutoValue schemas.
- AutoValueUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.AutoValueUtils
-
- AvailableParallelismFactory() - Constructor for class org.apache.beam.runners.direct.DirectOptions.AvailableParallelismFactory
-
- AVRO_CODER_URN - Static variable in class org.apache.beam.sdk.extensions.avro.AvroGenericCoderRegistrar
-
- AvroCoder<T> - Class in org.apache.beam.sdk.extensions.avro.coders
-
A
Coder
using Avro binary format.
- AvroCoder(Class<T>, Schema) - Constructor for class org.apache.beam.sdk.extensions.avro.coders.AvroCoder
-
- AvroCoder(Class<T>, Schema, boolean) - Constructor for class org.apache.beam.sdk.extensions.avro.coders.AvroCoder
-
- AvroCoder(AvroDatumFactory<T>, Schema) - Constructor for class org.apache.beam.sdk.extensions.avro.coders.AvroCoder
-
- AvroConvertType(boolean) - Constructor for class org.apache.beam.sdk.extensions.avro.schemas.utils.AvroUtils.AvroConvertType
-
- AvroDatumFactory<T> - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroDatumFactory(Class<T>) - Constructor for class org.apache.beam.sdk.extensions.avro.io.AvroDatumFactory
-
- AvroDatumFactory.GenericDatumFactory - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroDatumFactory.ReflectDatumFactory<T> - Class in org.apache.beam.sdk.extensions.avro.io
-
Specialized
AvroDatumFactory
for java classes transforming to avro through reflection.
- AvroDatumFactory.SpecificDatumFactory<T> - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroGenericCoder - Class in org.apache.beam.sdk.extensions.avro.coders
-
AvroCoder specialisation for GenericRecord, needed for cross-language transforms.
- AvroGenericCoderRegistrar - Class in org.apache.beam.sdk.extensions.avro
-
Coder registrar for AvroGenericCoder.
- AvroGenericCoderRegistrar() - Constructor for class org.apache.beam.sdk.extensions.avro.AvroGenericCoderRegistrar
-
- AvroGenericCoderTranslator - Class in org.apache.beam.sdk.extensions.avro
-
Coder translator for AvroGenericCoder.
- AvroGenericCoderTranslator() - Constructor for class org.apache.beam.sdk.extensions.avro.AvroGenericCoderTranslator
-
- AvroGenericRecordToStorageApiProto - Class in org.apache.beam.sdk.io.gcp.bigquery
-
Utility methods for converting Avro
GenericRecord
objects to dynamic protocol message,
for use with the Storage write API.
- AvroGenericRecordToStorageApiProto() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.AvroGenericRecordToStorageApiProto
-
- AvroIO - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroIO.Parse<T> - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroIO.ParseAll<T> - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroIO.ParseFiles<T> - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroIO.Read<T> - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroIO.ReadAll<T> - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroIO.ReadFiles<T> - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroIO.RecordFormatter<ElementT> - Interface in org.apache.beam.sdk.extensions.avro.io
-
- AvroIO.Sink<ElementT> - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroIO.TypedWrite<UserT,DestinationT,OutputT> - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroIO.Write<T> - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroJavaTimeConversions - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
Avro 1.8 ships with joda time conversions only.
- AvroJavaTimeConversions() - Constructor for class org.apache.beam.sdk.extensions.avro.schemas.utils.AvroJavaTimeConversions
-
- AvroJavaTimeConversions.DateConversion - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJavaTimeConversions.LocalTimestampMicros - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJavaTimeConversions.LocalTimestampMicrosConversion - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJavaTimeConversions.LocalTimestampMillis - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJavaTimeConversions.LocalTimestampMillisConversion - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJavaTimeConversions.TimeMicrosConversion - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJavaTimeConversions.TimeMillisConversion - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJavaTimeConversions.TimestampMicrosConversion - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJavaTimeConversions.TimestampMillisConversion - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJodaTimeConversions - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
Avro 1.8 & 1.9 ship joda time conversions.
- AvroJodaTimeConversions() - Constructor for class org.apache.beam.sdk.extensions.avro.schemas.utils.AvroJodaTimeConversions
-
- AvroJodaTimeConversions.DateConversion - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJodaTimeConversions.LossyTimeMicrosConversion - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJodaTimeConversions.LossyTimestampMicrosConversion - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJodaTimeConversions.TimeConversion - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJodaTimeConversions.TimeMicrosConversion - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJodaTimeConversions.TimestampConversion - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroJodaTimeConversions.TimestampMicrosConversion - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroPayloadSerializerProvider - Class in org.apache.beam.sdk.extensions.avro.schemas.io.payloads
-
- AvroPayloadSerializerProvider() - Constructor for class org.apache.beam.sdk.extensions.avro.schemas.io.payloads.AvroPayloadSerializerProvider
-
- AvroReader(AvroSource<T>) - Constructor for class org.apache.beam.sdk.extensions.avro.io.AvroSource.AvroReader
-
Reads Avro records of type T
from the specified source.
- AvroReadSchemaTransformFormatProvider - Class in org.apache.beam.sdk.io.fileschematransform
-
- AvroReadSchemaTransformFormatProvider() - Constructor for class org.apache.beam.sdk.io.fileschematransform.AvroReadSchemaTransformFormatProvider
-
- AvroRecordSchema - Class in org.apache.beam.sdk.extensions.avro.schemas
-
- AvroRecordSchema() - Constructor for class org.apache.beam.sdk.extensions.avro.schemas.AvroRecordSchema
-
- AvroSchemaInformationProvider - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroSchemaInformationProvider() - Constructor for class org.apache.beam.sdk.extensions.avro.schemas.utils.AvroSchemaInformationProvider
-
- AvroSchemaIOProvider - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroSchemaIOProvider() - Constructor for class org.apache.beam.sdk.extensions.avro.io.AvroSchemaIOProvider
-
- AvroSink<UserT,DestinationT,OutputT> - Class in org.apache.beam.sdk.extensions.avro.io
-
- AvroSink.DatumWriterFactory<T> - Interface in org.apache.beam.sdk.extensions.avro.io
-
- AvroSource<T> - Class in org.apache.beam.sdk.extensions.avro.io
-
Do not use in pipelines directly: most users should use
AvroIO.Read
.
- AvroSource.AvroReader<T> - Class in org.apache.beam.sdk.extensions.avro.io
-
A BlockBasedReader
for reading blocks from Avro files.
- AvroSource.DatumReaderFactory<T> - Interface in org.apache.beam.sdk.extensions.avro.io
-
- AvroTableProvider - Class in org.apache.beam.sdk.extensions.sql.meta.provider.avro
-
- AvroTableProvider() - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.avro.AvroTableProvider
-
- AvroTestUtil - Class in org.apache.beam.it.gcp.artifacts.utils
-
The
AvroTestUtil
class provides common utilities used for executing tests that involve
Avro.
- AvroTestUtil() - Constructor for class org.apache.beam.it.gcp.artifacts.utils.AvroTestUtil
-
- AvroUtils - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
Utils to convert AVRO records to Beam rows.
- AvroUtils.AvroConvertType - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroUtils.AvroConvertValueForGetter - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroUtils.AvroConvertValueForSetter - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroUtils.FixedBytesField - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
Wrapper for fixed byte fields.
- AvroUtils.TypeWithNullability - Class in org.apache.beam.sdk.extensions.avro.schemas.utils
-
- AvroWriteRequest<T> - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- AvroWriteRequest(T, Schema) - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.AvroWriteRequest
-
- AvroWriteSchemaTransformFormatProvider - Class in org.apache.beam.sdk.io.fileschematransform
-
- AvroWriteSchemaTransformFormatProvider() - Constructor for class org.apache.beam.sdk.io.fileschematransform.AvroWriteSchemaTransformFormatProvider
-
- 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(Duration) - Method in class org.apache.beam.runners.spark.SparkPipelineResult
-
- awaitTermination(Duration) - Method in class org.apache.beam.runners.spark.SparkRunnerDebugger.DebugSparkPipelineResult
-
- AwsBuilderFactory<PojoT extends SdkPojo,BuilderT extends SdkBuilder<BuilderT,PojoT> & SdkPojo> - Class in org.apache.beam.sdk.io.aws2.schemas
-
Builder factory for AWS
SdkPojo
to avoid using reflection to instantiate a builder.
- AwsBuilderFactory() - Constructor for class org.apache.beam.sdk.io.aws2.schemas.AwsBuilderFactory
-
- AwsClientsProvider - Interface in org.apache.beam.sdk.io.aws.dynamodb
-
Provides instances of AWS clients.
- AwsClientsProvider - Interface in org.apache.beam.sdk.io.aws.sns
-
Provides instances of AWS clients.
- AWSClientsProvider - Interface in org.apache.beam.sdk.io.kinesis
-
Provides instances of AWS clients.
- AwsCoders - Class in org.apache.beam.sdk.io.aws.coders
-
Coder
s for common AWS SDK objects.
- AwsModule - Class in org.apache.beam.sdk.io.aws.options
-
- AwsModule() - Constructor for class org.apache.beam.sdk.io.aws.options.AwsModule
-
- AwsModule - Class in org.apache.beam.sdk.io.aws2.options
-
- AwsModule() - Constructor for class org.apache.beam.sdk.io.aws2.options.AwsModule
-
- AwsOptions - Interface in org.apache.beam.sdk.io.aws.options
-
Options used to configure Amazon Web Services specific options such as credentials and region.
- AwsOptions - Interface in org.apache.beam.sdk.io.aws2.options
-
Options used to configure Amazon Web Services specific options such as credentials and region.
- AwsOptions.AwsRegionFactory - Class in org.apache.beam.sdk.io.aws.options
-
Attempt to load default region.
- AwsOptions.AwsRegionFactory - Class in org.apache.beam.sdk.io.aws2.options
-
Attempt to load default region.
- AwsOptions.AwsUserCredentialsFactory - Class in org.apache.beam.sdk.io.aws.options
-
Attempts to load AWS credentials.
- AwsOptions.AwsUserCredentialsFactory - Class in org.apache.beam.sdk.io.aws2.options
-
- AwsOptions.ClientConfigurationFactory - Class in org.apache.beam.sdk.io.aws.options
-
Default AWS client configuration.
- AwsPipelineOptionsRegistrar - Class in org.apache.beam.sdk.io.aws.options
-
A registrar containing the default AWS options.
- AwsPipelineOptionsRegistrar() - Constructor for class org.apache.beam.sdk.io.aws.options.AwsPipelineOptionsRegistrar
-
- AwsPipelineOptionsRegistrar - Class in org.apache.beam.sdk.io.aws2.options
-
A registrar containing the default AWS options.
- AwsPipelineOptionsRegistrar() - Constructor for class org.apache.beam.sdk.io.aws2.options.AwsPipelineOptionsRegistrar
-
- AwsRegionFactory() - Constructor for class org.apache.beam.sdk.io.aws.options.AwsOptions.AwsRegionFactory
-
- AwsRegionFactory() - Constructor for class org.apache.beam.sdk.io.aws2.options.AwsOptions.AwsRegionFactory
-
- AwsSchemaProvider - Class in org.apache.beam.sdk.io.aws2.schemas
-
- AwsSchemaProvider() - Constructor for class org.apache.beam.sdk.io.aws2.schemas.AwsSchemaProvider
-
- AwsSchemaRegistrar - Class in org.apache.beam.sdk.io.aws2.schemas
-
- AwsSchemaRegistrar() - Constructor for class org.apache.beam.sdk.io.aws2.schemas.AwsSchemaRegistrar
-
- AwsSerializableUtils - Class in org.apache.beam.sdk.io.aws2.options
-
Utilities for working with AWS Serializables.
- AwsSerializableUtils() - Constructor for class org.apache.beam.sdk.io.aws2.options.AwsSerializableUtils
-
- AwsSerializableUtils - Class in org.apache.beam.sdk.io.kinesis.serde
-
Utilities for working with AWS Serializables.
- AwsSerializableUtils() - Constructor for class org.apache.beam.sdk.io.kinesis.serde.AwsSerializableUtils
-
- AwsTypes - Class in org.apache.beam.sdk.io.aws2.schemas
-
- AwsTypes() - Constructor for class org.apache.beam.sdk.io.aws2.schemas.AwsTypes
-
- AwsUserCredentialsFactory() - Constructor for class org.apache.beam.sdk.io.aws.options.AwsOptions.AwsUserCredentialsFactory
-
- AwsUserCredentialsFactory() - Constructor for class org.apache.beam.sdk.io.aws2.options.AwsOptions.AwsUserCredentialsFactory
-
- AzureBlobStoreFileSystemRegistrar - Class in org.apache.beam.sdk.io.azure.blobstore
-
AutoService
registrar for the AzureBlobStoreFileSystem
.
- AzureBlobStoreFileSystemRegistrar() - Constructor for class org.apache.beam.sdk.io.azure.blobstore.AzureBlobStoreFileSystemRegistrar
-
- AzureModule - Class in org.apache.beam.sdk.io.azure.options
-
- AzureModule() - Constructor for class org.apache.beam.sdk.io.azure.options.AzureModule
-
- AzureOptions - Interface in org.apache.beam.sdk.io.azure.options
-
- AzureOptions.AzureUserCredentialsFactory - Class in org.apache.beam.sdk.io.azure.options
-
Attempts to load Azure credentials.
- AzurePipelineOptionsRegistrar - Class in org.apache.beam.sdk.io.azure.options
-
A registrar containing the default Azure options.
- AzurePipelineOptionsRegistrar() - Constructor for class org.apache.beam.sdk.io.azure.options.AzurePipelineOptionsRegistrar
-
- AzureUserCredentialsFactory() - Constructor for class org.apache.beam.sdk.io.azure.options.AzureOptions.AzureUserCredentialsFactory
-
- 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.
- BackOffAdapter - Class in org.apache.beam.sdk.extensions.gcp.util
-
An adapter for converting between Apache Beam and Google API client representations of backoffs.
- BackOffAdapter() - Constructor for class org.apache.beam.sdk.extensions.gcp.util.BackOffAdapter
-
- 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
-
Create a
StateSpec
for a
BagState
, optimized for adding values frequently and
occasionally retrieving all the values that have been added.
- bag(Coder<T>) - Static method in class org.apache.beam.sdk.state.StateSpecs
-
- BagState<T> - Interface in org.apache.beam.sdk.state
-
- BagUserStateSpec() - Constructor for class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors.BagUserStateSpec
-
- BASE_IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.FixedPrecisionNumeric
-
Identifier of the unspecified precision numeric type.
- baseBackoff() - Method in class org.apache.beam.sdk.io.aws2.common.RetryConfiguration
-
- baseBackoff(Duration) - Method in class org.apache.beam.sdk.io.aws2.common.RetryConfiguration.Builder
-
- BaseBeamTable - Class in org.apache.beam.sdk.extensions.sql.meta
-
- BaseBeamTable() - Constructor for class org.apache.beam.sdk.extensions.sql.meta.BaseBeamTable
-
- baseNameBuilder(String) - Static method in class org.apache.beam.sdk.metrics.LabeledMetricNameUtils.MetricNameBuilder
-
- baseUrl() - Method in class org.apache.beam.sdk.io.solr.SolrIO.ReplicaInfo
-
- BASIC_CONNECTION_INFO_VALIDATION_GROUP - Static variable in interface org.apache.beam.sdk.io.snowflake.SnowflakePipelineOptions
-
- BasicDynamoDBProvider - Class in org.apache.beam.sdk.io.aws.dynamodb
-
- BatchContextImpl - Class in org.apache.beam.sdk.io.cdap.context
-
Class for Batch, Sink and Stream CDAP wrapper classes that use it to provide common details.
- BatchContextImpl() - Constructor for class org.apache.beam.sdk.io.cdap.context.BatchContextImpl
-
- batchGetDocuments() - Method in class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.Read
-
Factory method to create a new type safe builder for BatchGetDocumentsRequest
operations.
- BatchingParams() - Constructor for class org.apache.beam.sdk.transforms.GroupIntoBatches.BatchingParams
-
- BatchSideInputHandlerFactory - Class in org.apache.beam.runners.fnexecution.translation
-
- BatchSideInputHandlerFactory.SideInputGetter - Interface in org.apache.beam.runners.fnexecution.translation
-
Returns the value for the side input with the given PCollection id from the runner.
- BatchSinkContextImpl - Class in org.apache.beam.sdk.io.cdap.context
-
Class for creating context object of different CDAP classes with batch sink type.
- BatchSinkContextImpl() - Constructor for class org.apache.beam.sdk.io.cdap.context.BatchSinkContextImpl
-
- batchSize() - Method in class org.apache.beam.sdk.extensions.ml.RecommendationAIImportCatalogItems
-
- batchSize() - Method in class org.apache.beam.sdk.extensions.ml.RecommendationAIImportUserEvents
-
- BatchSourceContextImpl - Class in org.apache.beam.sdk.io.cdap.context
-
Class for creating context object of different CDAP classes with batch source type.
- BatchSourceContextImpl() - Constructor for class org.apache.beam.sdk.io.cdap.context.BatchSourceContextImpl
-
- BatchStatefulParDoOverrides - Class in org.apache.beam.runners.dataflow
-
PTransformOverrideFactories
that expands to correctly implement
stateful
ParDo
using window-unaware
BatchViewOverrides.GroupByKeyAndSortValuesOnly
to linearize
processing per key.
- BatchStatefulParDoOverrides() - Constructor for class org.apache.beam.runners.dataflow.BatchStatefulParDoOverrides
-
- BatchStatefulParDoOverrides.BatchStatefulDoFn<K,V,OutputT> - Class in org.apache.beam.runners.dataflow
-
A key-preserving
DoFn
that explodes an iterable that has been grouped by key and
window.
- BatchTransformTranslator<TransformT extends PTransform> - Interface in org.apache.beam.runners.twister2.translators
-
Batch TransformTranslator interface.
- batchWrite(String, List<RecT>) - Method in class org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandler
-
Asynchronously trigger a batch write request (unless already in error state).
- batchWrite(String, List<RecT>, boolean) - Method in class org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandler
-
Asynchronously trigger a batch write request (unless already in error state).
- batchWrite() - Method in class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.Write
-
Factory method to create a new type safe builder for Write
operations.
- BEAM_INSTANCE_PROPERTY - Static variable in class org.apache.beam.io.debezium.KafkaSourceConsumerFn
-
- BEAM_METRICS_NAMESPACE - Static variable in class org.apache.beam.it.gcp.IOLoadTestBase
-
Namespace for Beam provided pipeline metrics (set up by Metrics transform).
- BeamAggregateProjectMergeRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
This rule is essentially a wrapper around Calcite's AggregateProjectMergeRule
.
- BeamAggregateProjectMergeRule(Class<? extends Aggregate>, Class<? extends Project>, RelBuilderFactory) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rule.BeamAggregateProjectMergeRule
-
- BeamAggregationRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
- BeamAggregationRel(RelOptCluster, RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>, WindowFn<Row, IntervalWindow>, int) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamAggregationRel
-
- BeamAggregationRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
Rule to detect the window/trigger settings.
- BeamAggregationRule(Class<? extends Aggregate>, Class<? extends Project>, RelBuilderFactory) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rule.BeamAggregationRule
-
- BeamBasicAggregationRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
Aggregation rule that doesn't include projection.
- BeamBasicAggregationRule(Class<? extends Aggregate>, RelBuilderFactory) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rule.BeamBasicAggregationRule
-
- BeamBatchTSetEnvironment - Class in org.apache.beam.runners.twister2
-
This is a shell tset environment which is used on as a central driver model to fit what beam
expects.
- BeamBatchTSetEnvironment() - Constructor for class org.apache.beam.runners.twister2.BeamBatchTSetEnvironment
-
- BeamBatchWorker - Class in org.apache.beam.runners.twister2
-
The Twister2 worker that will execute the job logic once the job is submitted from the run
method.
- BeamBatchWorker() - Constructor for class org.apache.beam.runners.twister2.BeamBatchWorker
-
- BeamBigQuerySqlDialect - Class in org.apache.beam.sdk.extensions.sql.meta.provider.bigquery
-
- BeamBigQuerySqlDialect(SqlDialect.Context) - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BeamBigQuerySqlDialect
-
- BeamBuiltinAggregations - Class in org.apache.beam.sdk.extensions.sql.impl.transform
-
Built-in aggregations functions for COUNT/MAX/MIN/SUM/AVG/VAR_POP/VAR_SAMP.
- BeamBuiltinAggregations() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.transform.BeamBuiltinAggregations
-
- BeamBuiltinAggregations.BitXOr<T extends java.lang.Number> - Class in org.apache.beam.sdk.extensions.sql.impl.transform
-
- BeamBuiltinAnalyticFunctions - Class in org.apache.beam.sdk.extensions.sql.impl.transform
-
Built-in Analytic Functions for the aggregation analytics functionality.
- BeamBuiltinAnalyticFunctions() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.transform.BeamBuiltinAnalyticFunctions
-
- BeamBuiltinAnalyticFunctions.PositionAwareCombineFn<InputT,AccumT,OutputT> - Class in org.apache.beam.sdk.extensions.sql.impl.transform
-
- BeamBuiltinFunctionProvider - Class in org.apache.beam.sdk.extensions.sql.impl.udf
-
BeamBuiltinFunctionClass interface.
- BeamBuiltinFunctionProvider() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.udf.BeamBuiltinFunctionProvider
-
- BeamBuiltinMethods - Class in org.apache.beam.sdk.extensions.sql.zetasql.translation.impl
-
BeamBuiltinMethods.
- BeamBuiltinMethods() - Constructor for class org.apache.beam.sdk.extensions.sql.zetasql.translation.impl.BeamBuiltinMethods
-
- BeamCalciteSchema - Class in org.apache.beam.sdk.extensions.sql.impl
-
- BeamCalciteTable - Class in org.apache.beam.sdk.extensions.sql.impl
-
- BeamCalcMergeRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
- BeamCalcMergeRule() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rule.BeamCalcMergeRule
-
- BeamCalcRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamRelNode to replace Project
and Filter
node.
- BeamCalcRel(RelOptCluster, RelTraitSet, RelNode, RexProgram) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamCalcRel
-
- BeamCalcRel.WrappedList<T> - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
WrappedList translates List
on access.
- BeamCalcRel.WrappedMap<V> - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
WrappedMap translates Map
on access.
- BeamCalcRel.WrappedRow - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
WrappedRow translates Row
on access.
- BeamCalcRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
- BeamCalcSplittingRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
- BeamCalcSplittingRule(String) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rule.BeamCalcSplittingRule
-
- BeamCodegenUtils - Class in org.apache.beam.sdk.extensions.sql.zetasql.translation.impl
-
BeamCodegenUtils.
- BeamCodegenUtils() - Constructor for class org.apache.beam.sdk.extensions.sql.zetasql.translation.impl.BeamCodegenUtils
-
- BeamCoGBKJoinRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
A BeamJoinRel
which does CoGBK Join
- BeamCoGBKJoinRel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamCoGBKJoinRel
-
- BeamCoGBKJoinRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
Rule to convert LogicalJoin
node to BeamCoGBKJoinRel
node.
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.AbstractBeamCalcRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamAggregationRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamIntersectRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamIOSinkRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamIOSourceRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamJoinRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamMatchRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamMinusRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamPushDownIOSourceRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in interface org.apache.beam.sdk.extensions.sql.impl.rel.BeamRelNode
-
This method is called by org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner.NonCumulativeCostImpl
.
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSortRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamTableFunctionScanRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamUncollectRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamUnionRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamUnnestRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamValuesRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamWindowRel
-
A dummy cost computation based on a fixed multiplier.
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.zetasql.unnest.BeamZetaSqlUncollectRel
-
- beamComputeSelfCost(RelOptPlanner, BeamRelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.zetasql.unnest.BeamZetaSqlUnnestRel
-
- BeamCostModel - Class in org.apache.beam.sdk.extensions.sql.impl.planner
-
VolcanoCost
represents the cost of a plan node.
- BeamCostModel.Factory - Class in org.apache.beam.sdk.extensions.sql.impl.planner
-
- BeamEnumerableConverter - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamRelNode to replace a Enumerable
node.
- BeamEnumerableConverter(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamEnumerableConverter
-
- BeamEnumerableConverterRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
A
ConverterRule
to Convert
BeamRelNode
to
EnumerableConvention
.
- beamFilesystemArtifactDestinationProvider(String) - Static method in class org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService
-
An ArtifactDestinationProvider that places new artifacts as files in a Beam filesystem.
- BeamFlinkDataSetAdapter - Class in org.apache.beam.runners.flink.adapter
-
An adapter class that allows one to apply Apache Beam PTransforms directly to Flink DataSets.
- BeamFlinkDataSetAdapter() - Constructor for class org.apache.beam.runners.flink.adapter.BeamFlinkDataSetAdapter
-
- BeamFlinkDataSetAdapter(PipelineOptions) - Constructor for class org.apache.beam.runners.flink.adapter.BeamFlinkDataSetAdapter
-
- BeamFlinkDataStreamAdapter - Class in org.apache.beam.runners.flink.adapter
-
An adapter class that allows one to apply Apache Beam PTransforms directly to Flink DataStreams.
- BeamFlinkDataStreamAdapter() - Constructor for class org.apache.beam.runners.flink.adapter.BeamFlinkDataStreamAdapter
-
- BeamFlinkDataStreamAdapter(PipelineOptions) - Constructor for class org.apache.beam.runners.flink.adapter.BeamFlinkDataStreamAdapter
-
- 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
-
- BeamIntersectRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamRelNode
to replace a Intersect
node.
- BeamIntersectRel(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamIntersectRel
-
- BeamIntersectRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
ConverterRule
to replace Intersect
with BeamIntersectRel
.
- BeamIOPushDownRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
- BeamIOPushDownRule(RelBuilderFactory) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rule.BeamIOPushDownRule
-
- BeamIOSinkRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamRelNode to replace a TableModify
node.
- BeamIOSinkRel(RelOptCluster, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean, BeamSqlTable, Map<String, String>) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamIOSinkRel
-
- BeamIOSinkRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
- BeamIOSourceRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamRelNode to replace a TableScan
node.
- BeamIOSourceRel(RelOptCluster, RelTraitSet, RelOptTable, BeamSqlTable, Map<String, String>, BeamCalciteTable) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamIOSourceRel
-
- BeamJavaTypeFactory - Class in org.apache.beam.sdk.extensions.sql.impl.planner
-
customized data type in Beam.
- BeamJavaUdfCalcRule - Class in org.apache.beam.sdk.extensions.sql.zetasql
-
- BeamJoinAssociateRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
This is very similar to JoinAssociateRule
.
- BeamJoinPushThroughJoinRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
This is exactly similar to JoinPushThroughJoinRule
.
- BeamJoinRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
An abstract BeamRelNode
to implement Join Rels.
- BeamJoinRel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamJoinRel
-
- BeamJoinTransforms - Class in org.apache.beam.sdk.extensions.sql.impl.transform
-
Collections of PTransform
and DoFn
used to perform JOIN operation.
- BeamJoinTransforms() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.transform.BeamJoinTransforms
-
- BeamJoinTransforms.JoinAsLookup - Class in org.apache.beam.sdk.extensions.sql.impl.transform
-
Transform to execute Join as Lookup.
- BeamKafkaCSVTable - Class in org.apache.beam.sdk.extensions.sql.meta.provider.kafka
-
A Kafka topic that saves records as CSV format.
- BeamKafkaCSVTable(Schema, String, List<String>) - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaCSVTable
-
- BeamKafkaCSVTable(Schema, String, List<String>, CSVFormat) - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaCSVTable
-
- BeamKafkaTable - Class in org.apache.beam.sdk.extensions.sql.meta.provider.kafka
-
BeamKafkaTable
represent a Kafka topic, as source or target.
- BeamKafkaTable(Schema) - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaTable
-
- BeamKafkaTable(Schema, String, List<String>) - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaTable
-
- BeamKafkaTable(Schema, List<TopicPartition>, String) - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaTable
-
- BeamLogicalConvention - Enum in org.apache.beam.sdk.extensions.sql.impl.rel
-
Convention for Beam SQL.
- BeamMatchRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamRelNode
to replace a Match
node.
- BeamMatchRel(RelOptCluster, RelTraitSet, RelNode, RelDataType, RexNode, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, ImmutableBitSet, RelCollation, RexNode) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamMatchRel
-
- BeamMatchRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
ConverterRule
to replace Match
with BeamMatchRel
.
- BeamMinusRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamRelNode
to replace a Minus
node.
- BeamMinusRel(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamMinusRel
-
- BeamMinusRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
ConverterRule
to replace Minus
with BeamMinusRel
.
- BeamPCollectionTable<InputT> - Class in org.apache.beam.sdk.extensions.sql.impl.schema
-
BeamPCollectionTable
converts a PCollection<Row>
as a virtual table, then a
downstream query can query directly.
- BeamPCollectionTable(PCollection<InputT>) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.schema.BeamPCollectionTable
-
- BeamPushDownIOSourceRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
- BeamPushDownIOSourceRel(RelOptCluster, RelTraitSet, RelOptTable, BeamSqlTable, List<String>, BeamSqlTableFilter, Map<String, String>, BeamCalciteTable) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamPushDownIOSourceRel
-
- BeamRelDataTypeSystem - Class in org.apache.beam.sdk.extensions.sql.impl.planner
-
customized data type in Beam.
- BeamRelMetadataQuery - Class in org.apache.beam.sdk.extensions.sql.impl.planner
-
- BeamRelNode - Interface in org.apache.beam.sdk.extensions.sql.impl.rel
-
A
RelNode
that can also give a
PTransform
that implements the expression.
- beamRow2CsvLine(Row, CSVFormat) - Static method in class org.apache.beam.sdk.extensions.sql.impl.schema.BeamTableUtils
-
- beamRowFromSourceRecordFn(Schema) - Static method in class org.apache.beam.io.debezium.KafkaConnectUtils
-
- BeamRowToBigtableMutation - Class in org.apache.beam.sdk.io.gcp.bigtable
-
- BeamRowToBigtableMutation(Map<String, Set<String>>) - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.BeamRowToBigtableMutation
-
- BeamRowToBigtableMutation.ToBigtableRowFn - Class in org.apache.beam.sdk.io.gcp.bigtable
-
- BeamRowToStorageApiProto - Class in org.apache.beam.sdk.io.gcp.bigquery
-
Utility methods for converting Beam
Row
objects to dynamic protocol message, for use with
the Storage write API.
- BeamRowToStorageApiProto() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BeamRowToStorageApiProto
-
- BeamRuleSets - Class in org.apache.beam.sdk.extensions.sql.impl.planner
-
RuleSet
used in BeamQueryPlanner
.
- BeamRuleSets() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.planner.BeamRuleSets
-
- beamSchemaFromJsonSchema(String) - Static method in class org.apache.beam.sdk.schemas.utils.JsonUtils
-
- beamSchemaFromKafkaConnectSchema(Schema) - Static method in class org.apache.beam.io.debezium.KafkaConnectUtils
-
- beamSchemaTypeFromKafkaType(Schema) - Static method in class org.apache.beam.io.debezium.KafkaConnectUtils
-
- BeamSetOperatorRelBase - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
Delegate for Set operators: BeamUnionRel
, BeamIntersectRel
and BeamMinusRel
.
- BeamSetOperatorRelBase(BeamRelNode, BeamSetOperatorRelBase.OpType, boolean) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSetOperatorRelBase
-
- BeamSetOperatorRelBase.OpType - Enum in org.apache.beam.sdk.extensions.sql.impl.rel
-
Set operator type.
- BeamSetOperatorsTransforms - Class in org.apache.beam.sdk.extensions.sql.impl.transform
-
Collections of PTransform
and DoFn
used to perform Set operations.
- BeamSetOperatorsTransforms() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.transform.BeamSetOperatorsTransforms
-
- BeamSetOperatorsTransforms.BeamSqlRow2KvFn - Class in org.apache.beam.sdk.extensions.sql.impl.transform
-
Transform a BeamSqlRow
to a KV<BeamSqlRow, BeamSqlRow>
.
- BeamSetOperatorsTransforms.SetOperatorFilteringDoFn - Class in org.apache.beam.sdk.extensions.sql.impl.transform
-
Filter function used for Set operators.
- BeamSideInputJoinRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
A BeamJoinRel
which does sideinput Join
- BeamSideInputJoinRel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSideInputJoinRel
-
- BeamSideInputJoinRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
Rule to convert LogicalJoin
node to BeamSideInputJoinRel
node.
- BeamSideInputLookupJoinRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
A BeamJoinRel
which does Lookup Join
- BeamSideInputLookupJoinRel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSideInputLookupJoinRel
-
- BeamSideInputLookupJoinRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
Rule to convert LogicalJoin
node to BeamSideInputLookupJoinRel
node.
- BeamSideInputLookupJoinRule() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rule.BeamSideInputLookupJoinRule
-
- BeamSortRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamRelNode
to replace a Sort
node.
- BeamSortRel(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSortRel
-
- BeamSortRel.BeamSqlRowComparator - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
- BeamSortRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
ConverterRule
to replace Sort
with BeamSortRel
.
- BeamSqlCli - Class in org.apache.beam.sdk.extensions.sql
-
BeamSqlCli
provides methods to execute Beam SQL with an interactive client.
- BeamSqlCli() - Constructor for class org.apache.beam.sdk.extensions.sql.BeamSqlCli
-
- BeamSqlDataCatalogExample - Class in org.apache.beam.sdk.extensions.sql.example
-
Example pipeline that uses Google Cloud Data Catalog to retrieve the table metadata.
- BeamSqlDataCatalogExample() - Constructor for class org.apache.beam.sdk.extensions.sql.example.BeamSqlDataCatalogExample
-
- BeamSqlDataCatalogExample.DCExamplePipelineOptions - Interface in org.apache.beam.sdk.extensions.sql.example
-
Pipeline options to specify the query and the output for the example.
- BeamSqlEnv - Class in org.apache.beam.sdk.extensions.sql.impl
-
Contains the metadata of tables/UDF functions, and exposes APIs to
query/validate/optimize/translate SQL statements.
- BeamSqlEnv.BeamSqlEnvBuilder - Class in org.apache.beam.sdk.extensions.sql.impl
-
BeamSqlEnv's Builder.
- BeamSqlOutputToConsoleFn - Class in org.apache.beam.sdk.extensions.sql.impl.transform
-
A test PTransform to display output in console.
- BeamSqlOutputToConsoleFn(String) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.transform.BeamSqlOutputToConsoleFn
-
- BeamSqlParser - Class in org.apache.beam.sdk.extensions.sql.impl.parser
-
- BeamSqlPipelineOptions - Interface in org.apache.beam.sdk.extensions.sql.impl
-
Options used to configure BeamSQL.
- BeamSqlPipelineOptionsRegistrar - Class in org.apache.beam.sdk.extensions.sql.impl
-
- BeamSqlPipelineOptionsRegistrar() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.BeamSqlPipelineOptionsRegistrar
-
- BeamSqlRelUtils - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
Utilities for BeamRelNode
.
- BeamSqlRelUtils() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSqlRelUtils
-
- BeamSqlRow2KvFn() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.transform.BeamSetOperatorsTransforms.BeamSqlRow2KvFn
-
- BeamSqlRowComparator(List<Integer>, List<Boolean>, List<Boolean>) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSortRel.BeamSqlRowComparator
-
- BeamSqlSeekableTable - Interface in org.apache.beam.sdk.extensions.sql
-
A seekable table converts a JOIN operator to an inline lookup.
- BeamSqlTable - Interface in org.apache.beam.sdk.extensions.sql.meta
-
This interface defines a Beam Sql Table.
- BeamSqlTableFilter - Interface in org.apache.beam.sdk.extensions.sql.meta
-
This interface defines Beam SQL Table Filter.
- BeamSqlUdf - Interface in org.apache.beam.sdk.extensions.sql
-
Interface to create a UDF in Beam SQL.
- BeamSqlUnparseContext - Class in org.apache.beam.sdk.extensions.sql.meta.provider.bigquery
-
- BeamSqlUnparseContext(IntFunction<SqlNode>) - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BeamSqlUnparseContext
-
- BeamTableFunctionScanRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamRelNode to replace TableFunctionScan
.
- BeamTableFunctionScanRel(RelOptCluster, RelTraitSet, List<RelNode>, RexNode, Type, RelDataType, Set<RelColumnMapping>) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamTableFunctionScanRel
-
- BeamTableFunctionScanRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
This is the conveter rule that converts a Calcite TableFunctionScan
to Beam TableFunctionScanRel
.
- BeamTableStatistics - Class in org.apache.beam.sdk.extensions.sql.impl
-
This class stores row count statistics.
- BeamTableUtils - Class in org.apache.beam.sdk.extensions.sql.impl.schema
-
Utility methods for working with BeamTable
.
- BeamTableUtils() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.schema.BeamTableUtils
-
- BeamUncollectRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamRelNode
to implement an uncorrelated
Uncollect
, aka UNNEST.
- BeamUncollectRel(RelOptCluster, RelTraitSet, RelNode, boolean) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamUncollectRel
-
- BeamUncollectRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
- BeamUnionRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
- BeamUnionRel(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamUnionRel
-
- BeamUnionRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
- BeamUnnestRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamRelNode
to implement UNNEST, supporting specifically only
Correlate
with
Uncollect
.
- BeamUnnestRel(RelOptCluster, RelTraitSet, RelNode, RelDataType, List<Integer>) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamUnnestRel
-
- BeamUnnestRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
- BeamValuesRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamRelNode
to replace a Values
node.
- BeamValuesRel(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, RelTraitSet) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamValuesRel
-
- BeamValuesRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
ConverterRule
to replace Values
with BeamValuesRel
.
- BeamWindowRel - Class in org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamRelNode
to replace a Window
node.
- BeamWindowRel(RelOptCluster, RelTraitSet, RelNode, List<RexLiteral>, RelDataType, List<Window.Group>) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.rel.BeamWindowRel
-
- BeamWindowRule - Class in org.apache.beam.sdk.extensions.sql.impl.rule
-
- BeamWorkerStatusGrpcService - Class in org.apache.beam.runners.fnexecution.status
-
A Fn Status service which can collect run-time status information from SDK harnesses for
debugging purpose.
- BeamZetaSqlCalcMergeRule - Class in org.apache.beam.sdk.extensions.sql.zetasql
-
- BeamZetaSqlCalcMergeRule() - Constructor for class org.apache.beam.sdk.extensions.sql.zetasql.BeamZetaSqlCalcMergeRule
-
- BeamZetaSqlCalcRel - Class in org.apache.beam.sdk.extensions.sql.zetasql
-
BeamRelNode to replace Project
and Filter
node based on the ZetaSQL
expression evaluator.
- BeamZetaSqlCalcRel(RelOptCluster, RelTraitSet, RelNode, RexProgram) - Constructor for class org.apache.beam.sdk.extensions.sql.zetasql.BeamZetaSqlCalcRel
-
- BeamZetaSqlCalcRule - Class in org.apache.beam.sdk.extensions.sql.zetasql
-
- BeamZetaSqlCalcSplittingRule - Class in org.apache.beam.sdk.extensions.sql.zetasql
-
- BeamZetaSqlCatalog - Class in org.apache.beam.sdk.extensions.sql.zetasql
-
Catalog for registering tables and functions.
- BeamZetaSqlUncollectRel - Class in org.apache.beam.sdk.extensions.sql.zetasql.unnest
-
- BeamZetaSqlUncollectRel(RelOptCluster, RelTraitSet, RelNode, boolean) - Constructor for class org.apache.beam.sdk.extensions.sql.zetasql.unnest.BeamZetaSqlUncollectRel
-
- BeamZetaSqlUncollectRule - Class in org.apache.beam.sdk.extensions.sql.zetasql.unnest
-
- BeamZetaSqlUnnestRel - Class in org.apache.beam.sdk.extensions.sql.zetasql.unnest
-
- BeamZetaSqlUnnestRel(RelOptCluster, RelTraitSet, RelNode, RelDataType, List<Integer>) - Constructor for class org.apache.beam.sdk.extensions.sql.zetasql.unnest.BeamZetaSqlUnnestRel
-
- BeamZetaSqlUnnestRule - Class in org.apache.beam.sdk.extensions.sql.zetasql.unnest
-
- 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
PBegin
owned by this Pipeline.
- beginningOnDay(int) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
-
- beginningOnDay(int, int) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
-
- benchmarkHadoopLineReader(TextSourceBenchmark.Data) - Method in class org.apache.beam.sdk.jmh.io.TextSourceBenchmark
-
- benchmarkTextSource(TextSourceBenchmark.Data) - Method in class org.apache.beam.sdk.jmh.io.TextSourceBenchmark
-
- BIG_INT - Static variable in class org.apache.beam.sdk.extensions.sql.impl.utils.CalciteUtils
-
- BIG_QUERY_INSERT_ERROR_ERROR_CONTAINER - Static variable in interface org.apache.beam.sdk.io.gcp.bigquery.ErrorContainer
-
- BigDecimalCoder - Class in org.apache.beam.sdk.coders
-
- BigDecimalConverter - Class in org.apache.beam.sdk.extensions.sql.impl.utils
-
Provides converters from
BigDecimal
to other numeric types based on the input
Schema.TypeName
.
- BigDecimalConverter() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.utils.BigDecimalConverter
-
- bigdecimals() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
- BigEndianIntegerCoder - Class in org.apache.beam.sdk.coders
-
- BigEndianLongCoder - Class in org.apache.beam.sdk.coders
-
- BigEndianShortCoder - Class in org.apache.beam.sdk.coders
-
- BigIntegerCoder - Class in org.apache.beam.sdk.coders
-
- bigintegers() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
- BIGQUERY_EARLY_ROLLOUT_REGION - Static variable in interface org.apache.beam.sdk.io.gcp.bigquery.TestBigQueryOptions
-
- BIGQUERY_JOB_TEMPLATE - Static variable in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO
-
Template for BigQuery jobs created by BigQueryIO.
- BigQueryAsserts - Class in org.apache.beam.it.gcp.bigquery.matchers
-
Assert utilities for BigQuery tests.
- BigQueryAsserts() - Constructor for class org.apache.beam.it.gcp.bigquery.matchers.BigQueryAsserts
-
- BigqueryClient - Class in org.apache.beam.sdk.io.gcp.testing
-
A wrapper class to call Bigquery API calls.
- BigqueryClient(String) - Constructor for class org.apache.beam.sdk.io.gcp.testing.BigqueryClient
-
- BigQueryCoderProviderRegistrar - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryCoderProviderRegistrar() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryCoderProviderRegistrar
-
- BigQueryDirectReadSchemaTransformConfiguration() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryDirectReadSchemaTransformProvider.BigQueryDirectReadSchemaTransformConfiguration
-
- BigQueryDirectReadSchemaTransformProvider - Class in org.apache.beam.sdk.io.gcp.bigquery.providers
-
- BigQueryDirectReadSchemaTransformProvider() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryDirectReadSchemaTransformProvider
-
- BigQueryDirectReadSchemaTransformProvider.BigQueryDirectReadSchemaTransform - Class in org.apache.beam.sdk.io.gcp.bigquery.providers
-
- BigQueryDirectReadSchemaTransformProvider.BigQueryDirectReadSchemaTransformConfiguration - Class in org.apache.beam.sdk.io.gcp.bigquery.providers
-
Configuration for reading from BigQuery with Storage Read API.
- BigQueryDirectReadSchemaTransformProvider.BigQueryDirectReadSchemaTransformConfiguration.Builder - Class in org.apache.beam.sdk.io.gcp.bigquery.providers
-
- BigQueryDlqProvider - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryDlqProvider() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryDlqProvider
-
- BigQueryExportReadSchemaTransformConfiguration - Class in org.apache.beam.sdk.io.gcp.bigquery
-
Configuration for reading from BigQuery.
- BigQueryExportReadSchemaTransformConfiguration() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryExportReadSchemaTransformConfiguration
-
- BigQueryExportReadSchemaTransformConfiguration.Builder - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryExportReadSchemaTransformProvider - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryExportReadSchemaTransformProvider() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryExportReadSchemaTransformProvider
-
- BigQueryExportReadSchemaTransformProvider.BigQueryExportSchemaTransform - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryFileLoadsWriteSchemaTransformConfiguration - Class in org.apache.beam.sdk.io.gcp.bigquery
-
Configuration for writing to BigQuery.
- BigQueryFileLoadsWriteSchemaTransformConfiguration() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryFileLoadsWriteSchemaTransformConfiguration
-
- BigQueryFileLoadsWriteSchemaTransformConfiguration.Builder - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryFileLoadsWriteSchemaTransformProvider - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryFileLoadsWriteSchemaTransformProvider() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryFileLoadsWriteSchemaTransformProvider
-
- BigQueryFileLoadsWriteSchemaTransformProvider.BigQueryWriteSchemaTransform - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryFilter - Class in org.apache.beam.sdk.extensions.sql.meta.provider.bigquery
-
- BigQueryFilter(List<RexNode>) - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryFilter
-
- BigQueryHelpers - Class in org.apache.beam.sdk.io.gcp.bigquery
-
A set of helper functions and classes used by
BigQueryIO
.
- BigQueryHelpers() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryHelpers
-
- BigQueryInsertError - Class in org.apache.beam.sdk.io.gcp.bigquery
-
Model definition for BigQueryInsertError.
- BigQueryInsertError(TableRow, TableDataInsertAllResponse.InsertErrors, TableReference) - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryInsertError
-
- BigQueryInsertErrorCoder - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryInsertErrorCoder() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryInsertErrorCoder
-
- BigQueryIO - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryIO.Read - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryIO.TypedRead<T> - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryIO.TypedRead.Method - Enum in org.apache.beam.sdk.io.gcp.bigquery
-
Determines the method used to read data from BigQuery.
- BigQueryIO.TypedRead.QueryPriority - Enum in org.apache.beam.sdk.io.gcp.bigquery
-
An enumeration type for the priority of a query.
- BigQueryIO.Write<T> - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryIO.Write.CreateDisposition - Enum in org.apache.beam.sdk.io.gcp.bigquery
-
An enumeration type for the BigQuery create disposition strings.
- BigQueryIO.Write.Method - Enum in org.apache.beam.sdk.io.gcp.bigquery
-
Determines the method used to insert data in BigQuery.
- BigQueryIO.Write.SchemaUpdateOption - Enum in org.apache.beam.sdk.io.gcp.bigquery
-
An enumeration type for the BigQuery schema update options strings.
- BigQueryIO.Write.WriteDisposition - Enum in org.apache.beam.sdk.io.gcp.bigquery
-
An enumeration type for the BigQuery write disposition strings.
- BigQueryIOTranslation - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryIOTranslation() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIOTranslation
-
- BigQueryIOTranslation.ReadRegistrar - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryIOTranslation.WriteRegistrar - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigqueryMatcher - Class in org.apache.beam.sdk.io.gcp.testing
-
A matcher to verify data in BigQuery by processing given query and comparing with content's
checksum.
- BigqueryMatcher.TableAndQuery - Class in org.apache.beam.sdk.io.gcp.testing
-
- BigQueryOptions - Interface in org.apache.beam.sdk.io.gcp.bigquery
-
Properties needed when using Google BigQuery with the Apache Beam SDK.
- BigQueryResourceManager - Class in org.apache.beam.it.gcp.bigquery
-
Client for managing BigQuery resources.
- BigQueryResourceManager.Builder - Class in org.apache.beam.it.gcp.bigquery
-
- BigQueryResourceManagerException - Exception in org.apache.beam.it.gcp.bigquery
-
- BigQueryResourceManagerException(String, Throwable) - Constructor for exception org.apache.beam.it.gcp.bigquery.BigQueryResourceManagerException
-
- BigQueryResourceManagerUtils - Class in org.apache.beam.it.gcp.bigquery
-
- BigQueryRowsCheck - Class in org.apache.beam.it.gcp.bigquery.conditions
-
ConditionCheck to validate if BigQuery has received a certain number of rows.
- BigQueryRowsCheck() - Constructor for class org.apache.beam.it.gcp.bigquery.conditions.BigQueryRowsCheck
-
- BigQueryRowsCheck.Builder - Class in org.apache.beam.it.gcp.bigquery.conditions
-
- bigQueryRowsToRecords(List<InsertAllRequest.RowToInsert>) - Static method in class org.apache.beam.it.gcp.bigquery.matchers.BigQueryAsserts
-
Convert BigQuery InsertAllRequest.RowToInsert
to a list of maps.
- bigQueryRowsToRecords(List<InsertAllRequest.RowToInsert>, List<String>) - Static method in class org.apache.beam.it.gcp.bigquery.matchers.BigQueryAsserts
-
Convert BigQuery InsertAllRequest.RowToInsert
to a list of maps.
- BigQuerySchemaIOProvider - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQuerySchemaIOProvider() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider
-
- BigQuerySchemaRetrievalException - Exception in org.apache.beam.sdk.io.gcp.bigquery
-
Exception to signal that BigQuery schema retrieval failed.
- BigQueryServices - Interface in org.apache.beam.sdk.io.gcp.bigquery
-
An interface for real, mock, or fake implementations of Cloud BigQuery services.
- BigQueryServices.BigQueryServerStream<T> - Interface in org.apache.beam.sdk.io.gcp.bigquery
-
Container for reading data from streaming endpoints.
- BigQueryServices.DatasetService - Interface in org.apache.beam.sdk.io.gcp.bigquery
-
An interface to get, create and delete Cloud BigQuery datasets and tables.
- BigQueryServices.DatasetService.TableMetadataView - Enum in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryServices.JobService - Interface in org.apache.beam.sdk.io.gcp.bigquery
-
An interface for the Cloud BigQuery load service.
- BigQueryServices.StorageClient - Interface in org.apache.beam.sdk.io.gcp.bigquery
-
An interface representing a client object for making calls to the BigQuery Storage API.
- BigQueryServices.StreamAppendClient - Interface in org.apache.beam.sdk.io.gcp.bigquery
-
An interface for appending records to a Storage API write stream.
- BigQueryServices.WriteStreamService - Interface in org.apache.beam.sdk.io.gcp.bigquery
-
An interface to get, create and flush Cloud BigQuery STORAGE API write streams.
- BigQueryServicesImpl - Class in org.apache.beam.sdk.io.gcp.bigquery
-
An implementation of
BigQueryServices
that actually communicates with the cloud BigQuery
service.
- BigQueryServicesImpl() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryServicesImpl
-
- BigQueryServicesImpl.DatasetServiceImpl - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryServicesImpl.WriteStreamServiceImpl - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQuerySinkMetrics - Class in org.apache.beam.sdk.io.gcp.bigquery
-
Helper class to create perworker metrics for BigQuery Sink stages.
- BigQuerySinkMetrics() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQuerySinkMetrics
-
- BigQuerySinkMetrics.RpcMethod - Enum in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryStorageApiInsertError - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryStorageApiInsertError(TableRow) - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageApiInsertError
-
- BigQueryStorageApiInsertError(TableRow, String) - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageApiInsertError
-
- BigQueryStorageApiInsertErrorCoder - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryStorageApiInsertErrorCoder() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageApiInsertErrorCoder
-
- BigQueryStorageTableSource<T> - Class in org.apache.beam.sdk.io.gcp.bigquery
-
A
Source
representing reading from a table.
- BigQueryStorageWriteApiSchemaTransformConfiguration() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryStorageWriteApiSchemaTransformProvider.BigQueryStorageWriteApiSchemaTransformConfiguration
-
- BigQueryStorageWriteApiSchemaTransformProvider - Class in org.apache.beam.sdk.io.gcp.bigquery.providers
-
- BigQueryStorageWriteApiSchemaTransformProvider() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryStorageWriteApiSchemaTransformProvider
-
- BigQueryStorageWriteApiSchemaTransformProvider.BigQueryStorageWriteApiSchemaTransform - Class in org.apache.beam.sdk.io.gcp.bigquery.providers
-
- BigQueryStorageWriteApiSchemaTransformProvider.BigQueryStorageWriteApiSchemaTransformConfiguration - Class in org.apache.beam.sdk.io.gcp.bigquery.providers
-
Configuration for writing to BigQuery with Storage Write API.
- BigQueryStorageWriteApiSchemaTransformProvider.BigQueryStorageWriteApiSchemaTransformConfiguration.Builder - Class in org.apache.beam.sdk.io.gcp.bigquery.providers
-
- BigQueryStorageWriteApiSchemaTransformProvider.BigQueryStorageWriteApiSchemaTransformConfiguration.ErrorHandling - Class in org.apache.beam.sdk.io.gcp.bigquery.providers
-
- BigQueryStorageWriteApiSchemaTransformProvider.BigQueryStorageWriteApiSchemaTransformConfiguration.ErrorHandling.Builder - Class in org.apache.beam.sdk.io.gcp.bigquery.providers
-
- BigQueryTableProvider - Class in org.apache.beam.sdk.extensions.sql.meta.provider.bigquery
-
BigQuery table provider.
- BigQueryTableProvider() - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTableProvider
-
- BigQueryTestUtil - Class in org.apache.beam.it.gcp.bigquery.utils
-
Utilities for BigQuery tests.
- BigQueryUtils - Class in org.apache.beam.sdk.io.gcp.bigquery
-
Utility methods for BigQuery related operations.
- BigQueryUtils() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryUtils
-
- BigQueryUtils.ConversionOptions - Class in org.apache.beam.sdk.io.gcp.bigquery
-
Options for how to convert BigQuery data to Beam data.
- BigQueryUtils.ConversionOptions.Builder - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigQueryUtils.ConversionOptions.TruncateTimestamps - Enum in org.apache.beam.sdk.io.gcp.bigquery
-
Controls whether to truncate timestamps to millisecond precision lossily, or to crash when
truncation would result.
- BigQueryUtils.SchemaConversionOptions - Class in org.apache.beam.sdk.io.gcp.bigquery
-
Options for how to convert BigQuery schemas to Beam schemas.
- BigQueryUtils.SchemaConversionOptions.Builder - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- BigtableAsserts - Class in org.apache.beam.it.gcp.bigtable.matchers
-
- BigtableAsserts() - Constructor for class org.apache.beam.it.gcp.bigtable.matchers.BigtableAsserts
-
- BigtableChangeStreamAccessor - Class in org.apache.beam.sdk.io.gcp.bigtable.changestreams.dao
-
This is probably a temporary solution to what is a bigger migration from
cloud-bigtable-client-core to java-bigtable.
- BigtableChangeStreamTestOptions - Interface in org.apache.beam.sdk.io.gcp.bigtable.changestreams
-
- BigtableClientOverride - Interface in org.apache.beam.sdk.io.gcp.bigtable.changestreams.dao
-
Override the configuration of Cloud Bigtable data and admin client.
- BigtableConfig - Class in org.apache.beam.sdk.io.gcp.bigtable
-
Configuration for a Cloud Bigtable client.
- BigtableConfig() - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.BigtableConfig
-
- bigtableDataClient() - Method in class org.apache.beam.it.gcp.bigtable.BigtableResourceManagerClientFactory
-
Returns the Data client for reading and writing data to Bigtable tables.
- bigtableInstanceAdminClient() - Method in class org.apache.beam.it.gcp.bigtable.BigtableResourceManagerClientFactory
-
Returns the Instance admin client for managing Bigtable instances.
- BigtableIO - Class in org.apache.beam.sdk.io.gcp.bigtable
-
Transforms
for reading from and writing to Google Cloud Bigtable.
- BigtableIO.ExistingPipelineOptions - Enum in org.apache.beam.sdk.io.gcp.bigtable
-
Overwrite options to determine what to do if change stream name is being reused and there
exists metadata of the same change stream name.
- BigtableIO.Read - Class in org.apache.beam.sdk.io.gcp.bigtable
-
A
PTransform
that reads from Google Cloud Bigtable.
- BigtableIO.ReadChangeStream - Class in org.apache.beam.sdk.io.gcp.bigtable
-
- BigtableIO.Write - Class in org.apache.beam.sdk.io.gcp.bigtable
-
A
PTransform
that writes to Google Cloud Bigtable.
- BigtableIO.WriteWithResults - Class in org.apache.beam.sdk.io.gcp.bigtable
-
- BigtableReadSchemaTransformConfiguration() - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.BigtableReadSchemaTransformProvider.BigtableReadSchemaTransformConfiguration
-
- BigtableReadSchemaTransformProvider - Class in org.apache.beam.sdk.io.gcp.bigtable
-
- BigtableReadSchemaTransformProvider() - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.BigtableReadSchemaTransformProvider
-
- BigtableReadSchemaTransformProvider.BigtableReadSchemaTransformConfiguration - Class in org.apache.beam.sdk.io.gcp.bigtable
-
Configuration for reading from Bigtable.
- BigtableReadSchemaTransformProvider.BigtableReadSchemaTransformConfiguration.Builder - Class in org.apache.beam.sdk.io.gcp.bigtable
-
- BigtableReadSchemaTransformProvider.BigtableRowToBeamRow - Class in org.apache.beam.sdk.io.gcp.bigtable
-
- BigtableResourceManager - Class in org.apache.beam.it.gcp.bigtable
-
Client for managing Bigtable resources.
- BigtableResourceManager.Builder - Class in org.apache.beam.it.gcp.bigtable
-
- BigtableResourceManagerClientFactory - Class in org.apache.beam.it.gcp.bigtable
-
Class for storing the 3 Bigtable clients used to manage the Instance(s), Table(s) and Data
mutations performed by the resource manager.
- BigtableResourceManagerClientFactory(BigtableInstanceAdminSettings, BigtableTableAdminSettings, BigtableDataSettings) - Constructor for class org.apache.beam.it.gcp.bigtable.BigtableResourceManagerClientFactory
-
- BigtableResourceManagerCluster - Class in org.apache.beam.it.gcp.bigtable
-
Class for storing the metadata of a Bigtable cluster object.
- BigtableResourceManagerCluster() - Constructor for class org.apache.beam.it.gcp.bigtable.BigtableResourceManagerCluster
-
- BigtableResourceManagerException - Exception in org.apache.beam.it.gcp.bigtable
-
- BigtableResourceManagerException(String) - Constructor for exception org.apache.beam.it.gcp.bigtable.BigtableResourceManagerException
-
- BigtableResourceManagerException(String, Throwable) - Constructor for exception org.apache.beam.it.gcp.bigtable.BigtableResourceManagerException
-
- BigtableResourceManagerUtils - Class in org.apache.beam.it.gcp.bigtable
-
- bigtableRowsToRecords(Iterable<Row>, String) - Static method in class org.apache.beam.it.gcp.bigtable.matchers.BigtableAsserts
-
Convert Bigtable Row
to a list of maps.
- BigtableRowToBeamRow() - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.BigtableReadSchemaTransformProvider.BigtableRowToBeamRow
-
- BigtableRowToBeamRow - Class in org.apache.beam.sdk.io.gcp.bigtable
-
- BigtableRowToBeamRow(Schema) - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.BigtableRowToBeamRow
-
- BigtableRowToBeamRowFlat - Class in org.apache.beam.sdk.io.gcp.bigtable
-
- BigtableRowToBeamRowFlat(Schema, Map<String, Set<String>>) - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.BigtableRowToBeamRowFlat
-
- BigtableTable - Class in org.apache.beam.sdk.extensions.sql.meta.provider.bigtable
-
- bigtableTableAdminClient() - Method in class org.apache.beam.it.gcp.bigtable.BigtableResourceManagerClientFactory
-
Returns the Table admin client for managing Bigtable tables.
- BigtableTableProvider - Class in org.apache.beam.sdk.extensions.sql.meta.provider.bigtable
-
- BigtableTableProvider() - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.bigtable.BigtableTableProvider
-
- BigtableTableSpec - Class in org.apache.beam.it.gcp.bigtable
-
- BigtableTableSpec() - Constructor for class org.apache.beam.it.gcp.bigtable.BigtableTableSpec
-
- BigtableUtils - Class in org.apache.beam.sdk.io.gcp.testing
-
- BigtableUtils() - Constructor for class org.apache.beam.sdk.io.gcp.testing.BigtableUtils
-
- BigtableWriteResult - Class in org.apache.beam.sdk.io.gcp.bigtable
-
The result of writing a batch of rows to Bigtable.
- BigtableWriteResult() - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.BigtableWriteResult
-
- BigtableWriteResultCoder - Class in org.apache.beam.sdk.io.gcp.bigtable
-
- BigtableWriteResultCoder() - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.BigtableWriteResultCoder
-
- BigtableWriteSchemaTransformConfiguration() - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.BigtableWriteSchemaTransformProvider.BigtableWriteSchemaTransformConfiguration
-
- BigtableWriteSchemaTransformProvider - Class in org.apache.beam.sdk.io.gcp.bigtable
-
- BigtableWriteSchemaTransformProvider() - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.BigtableWriteSchemaTransformProvider
-
- BigtableWriteSchemaTransformProvider.BigtableWriteSchemaTransformConfiguration - Class in org.apache.beam.sdk.io.gcp.bigtable
-
Configuration for writing to Bigtable.
- BigtableWriteSchemaTransformProvider.BigtableWriteSchemaTransformConfiguration.Builder - Class in org.apache.beam.sdk.io.gcp.bigtable
-
- BigtableWriteSchemaTransformProvider.GetMutationsFromBeamRow - Class in org.apache.beam.sdk.io.gcp.bigtable
-
- 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
-
- 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
-
- BIT_XOR - Static variable in class org.apache.beam.sdk.extensions.sql.zetasql.translation.SqlOperators
-
- BitSetCoder - Class in org.apache.beam.sdk.coders
-
Coder for BitSet
.
- BitXOr() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.transform.BeamBuiltinAggregations.BitXOr
-
- BlackholeOutput() - Constructor for class org.apache.beam.sdk.jmh.util.VarIntBenchmark.BlackholeOutput
-
- blob - Variable in class org.apache.beam.it.gcp.artifacts.GcsArtifact
-
- BlobstoreClientBuilderFactory - Interface in org.apache.beam.sdk.io.azure.options
-
Construct BlobServiceClientBuilder from Azure pipeline options.
- BlobstoreOptions - Interface in org.apache.beam.sdk.io.azure.options
-
Options used to configure Microsoft Azure Blob Storage.
- Block() - Constructor for class org.apache.beam.sdk.io.BlockBasedSource.Block
-
- BlockBasedReader(BlockBasedSource<T>) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
-
- BlockBasedSource<T> - Class in org.apache.beam.sdk.io
-
A
BlockBasedSource
is a
FileBasedSource
where a file consists of blocks of
records.
- BlockBasedSource(String, EmptyMatchTreatment, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
-
Creates a BlockBasedSource
based on a file name or pattern.
- BlockBasedSource(String, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
-
- BlockBasedSource(ValueProvider<String>, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
-
- BlockBasedSource(ValueProvider<String>, EmptyMatchTreatment, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
-
- BlockBasedSource(MatchResult.Metadata, long, long, long) - Constructor for class org.apache.beam.sdk.io.BlockBasedSource
-
Creates a BlockBasedSource
for a single file.
- BlockBasedSource.Block<T> - Class in org.apache.beam.sdk.io
-
A Block
represents a block of records that can be read.
- BlockBasedSource.BlockBasedReader<T> - Class in org.apache.beam.sdk.io
-
- BlockingCommitterImpl - Class in org.apache.beam.sdk.io.gcp.pubsublite.internal
-
- BlockTracker(OffsetRange, long, long) - Constructor for class org.apache.beam.sdk.io.parquet.ParquetIO.ReadFiles.BlockTracker
-
- BOOL - Static variable in class org.apache.beam.sdk.io.clickhouse.TableSchema.ColumnType
-
- BOOLEAN - Static variable in class org.apache.beam.sdk.extensions.sql.impl.utils.CalciteUtils
-
- 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
-
- BooleanCoder() - Constructor for class org.apache.beam.sdk.coders.BooleanCoder
-
- booleans() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
- booleanToByteArray(boolean) - Static method in class org.apache.beam.sdk.io.gcp.testing.BigtableUtils
-
- Bounded(SparkContext, BoundedSource<T>, SerializablePipelineOptions, String) - Constructor for class org.apache.beam.runners.spark.io.SourceRDD.Bounded
-
- BOUNDED_UNKNOWN - Static variable in class org.apache.beam.sdk.extensions.sql.impl.BeamTableStatistics
-
- BoundedDatasetFactory - Class in org.apache.beam.runners.spark.structuredstreaming.io
-
- BoundedReader() - Constructor for class org.apache.beam.sdk.io.BoundedSource.BoundedReader
-
- BoundedReadFromUnboundedSource<T> - Class in org.apache.beam.sdk.io
-
PTransform
that reads a bounded amount of data from an
UnboundedSource
, specified
as one or both of a maximum number of elements or a maximum period of time to read.
- BoundedSource<T> - Class in org.apache.beam.sdk.io
-
A
Source
that reads a finite amount of input and, because of that, supports some
additional operations.
- BoundedSource() - Constructor for class org.apache.beam.sdk.io.BoundedSource
-
- BoundedSource.BoundedReader<T> - Class in org.apache.beam.sdk.io
-
A Reader
that reads a bounded amount of input and supports some additional operations,
such as progress estimation and dynamic work rebalancing.
- BoundedSourceP<T> - Class in org.apache.beam.runners.jet.processors
-
Jet Processor
implementation for reading from a bounded Beam
source.
- BoundedWindow - Class in org.apache.beam.sdk.transforms.windowing
-
A
BoundedWindow
represents window information assigned to data elements.
- BoundedWindow() - Constructor for class org.apache.beam.sdk.transforms.windowing.BoundedWindow
-
- boxIfPrimitive(TypeDescriptor) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
-
- broadcast(T) - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.TransformTranslator.Context
-
- broadcast(JavaSparkContext) - Method in class org.apache.beam.runners.spark.util.SideInputBroadcast
-
- bucketAccessible(GcsPath) - Method in class org.apache.beam.sdk.extensions.gcp.util.GcsUtil
-
Returns whether the GCS bucket exists and is accessible.
- bucketOwner(GcsPath) - Method in class org.apache.beam.sdk.extensions.gcp.util.GcsUtil
-
Returns the project number of the project which owns this bucket.
- BufferedExternalSorter - Class in org.apache.beam.sdk.extensions.sorter
-
Sorter
that will use in memory sorting until the values can't fit into memory and will
then fall back to external sorting.
- BufferedExternalSorter.Options - Class in org.apache.beam.sdk.extensions.sorter
-
Contains configuration for the sorter.
- BufferingStreamObserver<T> - Class in org.apache.beam.sdk.fn.stream
-
A thread safe StreamObserver
which uses a bounded queue to pass elements to a processing
thread responsible for interacting with the underlying CallStreamObserver
.
- BufferingStreamObserver(Phaser, CallStreamObserver<T>, ExecutorService, int) - Constructor for class org.apache.beam.sdk.fn.stream.BufferingStreamObserver
-
- build() - Method in class org.apache.beam.io.debezium.DebeziumReadSchemaTransformProvider.DebeziumReadSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.io.requestresponse.Monitoring.Builder
-
- build() - Method in class org.apache.beam.it.cassandra.CassandraResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.elasticsearch.ElasticsearchResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.gcp.bigquery.BigQueryResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.gcp.bigquery.conditions.BigQueryRowsCheck.Builder
-
- build() - Method in class org.apache.beam.it.gcp.bigtable.BigtableResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.gcp.dataflow.ClassicTemplateClient.Builder
-
- build() - Method in class org.apache.beam.it.gcp.dataflow.DefaultPipelineLauncher.Builder
-
- build() - Method in class org.apache.beam.it.gcp.dataflow.DirectRunnerClient.Builder
-
- build() - Method in class org.apache.beam.it.gcp.dataflow.FlexTemplateClient.Builder
-
- build() - Method in class org.apache.beam.it.gcp.datagenerator.DataGenerator.Builder
-
- build() - Method in class org.apache.beam.it.gcp.datastore.DatastoreResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.gcp.datastream.DatastreamResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.gcp.datastream.JDBCSource.Builder
-
- build() - Method in class org.apache.beam.it.gcp.datastream.MySQLSource.Builder
-
- build() - Method in class org.apache.beam.it.gcp.datastream.OracleSource.Builder
-
- build() - Method in class org.apache.beam.it.gcp.datastream.PostgresqlSource.Builder
-
- build() - Method in class org.apache.beam.it.gcp.dlp.DlpResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.gcp.kms.KMSResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.gcp.LoadTestBase.MetricsConfiguration.Builder
-
- build() - Method in class org.apache.beam.it.gcp.monitoring.MonitoringClient.Builder
-
- build() - Method in class org.apache.beam.it.gcp.pubsub.conditions.PubsubMessagesCheck.Builder
-
- build() - Method in class org.apache.beam.it.gcp.pubsub.PubsubResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.gcp.secretmanager.SecretManagerResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.gcp.spanner.SpannerResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.gcp.storage.GcsResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.jdbc.MSSQLResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.jdbc.MySQLResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.jdbc.OracleResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.jdbc.PostgresResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.kafka.KafkaResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.mongodb.conditions.MongoDBDocumentsCheck.Builder
-
- build() - Method in class org.apache.beam.it.mongodb.MongoDBResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.neo4j.conditions.Neo4jQueryCheck.Builder
-
- build() - Method in class org.apache.beam.it.neo4j.Neo4jResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.splunk.conditions.SplunkEventsCheck.Builder
-
- build() - Method in class org.apache.beam.it.splunk.SplunkResourceManager.Builder
-
- build() - Method in class org.apache.beam.it.testcontainers.TestContainerResourceManager.Builder
-
Builds and returns a Resource Manager that extends TestContainerResourceManager.
- build() - Method in class org.apache.beam.sdk.expansion.service.WindowIntoTransformProvider.Configuration.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.gcp.storage.GcsCreateOptions.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.gcp.util.CustomHttpErrors.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.gcp.util.GcsUtil.CreateOptions.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.ml.AnnotateText.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.ml.DLPDeidentifyText.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.ml.DLPInspectText.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.ml.DLPReidentifyText.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.ordered.OrderedProcessingStatus.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.sbe.SbeSchema.IrOptions.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.sbe.UnsignedOptions.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlEnv.BeamSqlEnvBuilder
-
Build function to create an instance of BeamSqlEnv based on preset fields.
- build() - Method in class org.apache.beam.sdk.extensions.sql.impl.UdfImplReflectiveFunctionBase.ParameterListBuilder
-
- build() - Method in class org.apache.beam.sdk.extensions.sql.impl.utils.SerializableRexNode.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.sql.meta.Table.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.sql.zetasql.translation.UserFunctionDefinitions.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.zetasketch.ApproximateCountDistinct.Globally.Builder
-
- build() - Method in class org.apache.beam.sdk.extensions.zetasketch.ApproximateCountDistinct.PerKey.Builder
-
- build() - Method in class org.apache.beam.sdk.fn.test.TestStreams.Builder
-
- build() - Method in class org.apache.beam.sdk.io.aws.s3.S3FileSystemConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.aws2.common.ClientConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.aws2.common.HttpClientConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.aws2.common.RetryConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.aws2.kinesis.KinesisIO.RecordAggregation.Builder
-
- build() - Method in class org.apache.beam.sdk.io.aws2.s3.S3FileSystemConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.aws2.s3.SSECustomerKey.Builder
-
- build() - Method in class org.apache.beam.sdk.io.cdap.ConfigWrapper
-
- build() - Method in class org.apache.beam.sdk.io.cdap.Plugin.Builder
-
- build() - Method in class org.apache.beam.sdk.io.csv.providers.CsvWriteTransformProvider.CsvWriteConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.fileschematransform.FileReadSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.fileschematransform.FileWriteSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.fileschematransform.FileWriteSchemaTransformConfiguration.CsvConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.fileschematransform.FileWriteSchemaTransformConfiguration.ParquetConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.fileschematransform.FileWriteSchemaTransformConfiguration.XmlConfiguration.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.gcp.bigquery.BigQueryExportReadSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryFileLoadsWriteSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryUtils.ConversionOptions.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryUtils.SchemaConversionOptions.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryDirectReadSchemaTransformProvider.BigQueryDirectReadSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryStorageWriteApiSchemaTransformProvider.BigQueryStorageWriteApiSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryStorageWriteApiSchemaTransformProvider.BigQueryStorageWriteApiSchemaTransformConfiguration.ErrorHandling.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.bigquery.StorageApiWritePayload.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableReadSchemaTransformProvider.BigtableReadSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableWriteSchemaTransformProvider.BigtableWriteSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.BatchGetDocuments.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.BatchWriteWithDeadLetterQueue.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.BatchWriteWithSummary.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.ListCollectionIds.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.ListDocuments.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.PartitionQuery.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.RunQuery.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.firestore.RpcQosOptions.Builder
-
Create a new instance of
RpcQosOptions
from the current builder state.
- build() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubReadSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubReadSchemaTransformConfiguration.ErrorHandling.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubWriteSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubWriteSchemaTransformConfiguration.ErrorHandling.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.pubsublite.PublisherOptions.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.pubsublite.PubsubLiteReadSchemaTransformProvider.PubsubLiteReadSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.pubsublite.PubsubLiteWriteSchemaTransformProvider.PubsubLiteWriteSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.pubsublite.SubscriberOptions.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.pubsublite.UuidDeduplicationOptions.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.ChangeStreamRecordMetadata.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.PartitionMetadata.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.spanner.changestreams.SpannerChangestreamsReadSchemaTransformProvider.SpannerChangestreamsReadConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerConfig.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerIO.CreateTransaction.Builder
-
- build() - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerWriteSchemaTransformProvider.SpannerWriteSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.iceberg.IcebergCatalogConfig.Builder
-
- build() - Method in class org.apache.beam.sdk.io.iceberg.IcebergDestination.Builder
-
- build() - Method in class org.apache.beam.sdk.io.iceberg.IcebergReadSchemaTransformProvider.Config.Builder
-
- build() - Method in class org.apache.beam.sdk.io.iceberg.IcebergScanConfig.Builder
-
- build() - Method in class org.apache.beam.sdk.io.iceberg.IcebergSchemaTransformCatalogConfig.Builder
-
- build() - Method in class org.apache.beam.sdk.io.iceberg.IcebergTableCreateConfig.Builder
-
- build() - Method in class org.apache.beam.sdk.io.iceberg.IcebergWriteSchemaTransformProvider.Config.Builder
-
- build() - Method in class org.apache.beam.sdk.io.iceberg.SnapshotInfo.Builder
-
- build() - Method in class org.apache.beam.sdk.io.jdbc.JdbcReadSchemaTransformProvider.JdbcReadSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.jdbc.JdbcWriteSchemaTransformProvider.JdbcWriteSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.json.providers.JsonWriteTransformProvider.JsonWriteConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.kafka.KafkaReadSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.kafka.KafkaWriteSchemaTransformProvider.KafkaWriteSchemaTransformConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.singlestore.schematransform.SingleStoreSchemaTransformReadConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.singlestore.schematransform.SingleStoreSchemaTransformWriteConfiguration.Builder
-
- build() - Method in class org.apache.beam.sdk.io.sparkreceiver.ReceiverBuilder
-
- build() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
-
- build() - Method in class org.apache.beam.sdk.managed.testing.TestSchemaTransformProvider.Config.Builder
-
- build(String) - Method in class org.apache.beam.sdk.metrics.LabeledMetricNameUtils.MetricNameBuilder
-
- 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.values.Row.Builder
-
- build() - Method in class org.apache.beam.sdk.values.Row.FieldValueBuilder
-
- buildBeamSqlNullableSchema(Object...) - Static method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestTableUtils
-
- buildBeamSqlSchema(Object...) - Static method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestTableUtils
-
Create a RowsBuilder with the specified row type info.
- buildBeamSqlTable(Table) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTableProvider
-
- buildBeamSqlTable(Table) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.bigtable.BigtableTableProvider
-
- buildBeamSqlTable(Table) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.datacatalog.DataCatalogTableProvider
-
- buildBeamSqlTable(Table) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.KafkaTableProvider
-
- buildBeamSqlTable(Table) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.mongodb.MongoDbTableProvider
-
- buildBeamSqlTable(Table) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.parquet.ParquetTableProvider
-
- buildBeamSqlTable(Table) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.pubsublite.PubsubLiteTableProvider
-
- buildBeamSqlTable(Table) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.ReadOnlyTableProvider
-
- buildBeamSqlTable(Table) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.SchemaIOTableProviderWrapper
-
- buildBeamSqlTable(Table) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.seqgen.GenerateSequenceTableProvider
-
- buildBeamSqlTable(Table) - Method in interface org.apache.beam.sdk.extensions.sql.meta.provider.TableProvider
-
- buildBeamSqlTable(Table) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestTableProvider
-
- buildBeamSqlTable(Table) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.text.TextTableProvider
-
- buildBeamSqlTable(Table) - Method in class org.apache.beam.sdk.extensions.sql.meta.store.InMemoryMetaStore
-
- buildBQDestinationConfig(String, long, String) - Method in class org.apache.beam.it.gcp.datastream.DatastreamResourceManager
-
- buildClient(AwsOptions, BuilderT, ClientConfiguration) - Static method in interface org.apache.beam.sdk.io.aws2.common.ClientBuilderFactory
-
Utility to directly build a client of type ClientT
using builder of BuilderT
.
- buildConsumer(Deserializer<K>, Deserializer<V>) - Method in class org.apache.beam.it.kafka.KafkaResourceManager
-
Build a
KafkaConsumer
for the given serializer and deserializers.
- buildDatasource() - Method in class org.apache.beam.sdk.io.jdbc.JdbcIO.DataSourceConfiguration
-
- buildDatasource() - Method in class org.apache.beam.sdk.io.snowflake.SnowflakeIO.DataSourceConfiguration
-
Builds SnowflakeBasicDataSource
based on the current configuration.
- builder() - Static method in class org.apache.beam.io.debezium.DebeziumReadSchemaTransformProvider.DebeziumReadSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.io.debezium.DebeziumReadSchemaTransformProvider.DebeziumReadSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.io.requestresponse.Monitoring
-
- Builder() - Constructor for class org.apache.beam.io.requestresponse.Monitoring.Builder
-
- builder(String) - Static method in class org.apache.beam.it.cassandra.CassandraResourceManager
-
- builder(String) - Static method in class org.apache.beam.it.elasticsearch.ElasticsearchResourceManager
-
- builder(String, String, Credentials) - Static method in class org.apache.beam.it.gcp.bigquery.BigQueryResourceManager
-
- builder(BigQueryResourceManager, TableId) - Static method in class org.apache.beam.it.gcp.bigquery.conditions.BigQueryRowsCheck
-
- Builder() - Constructor for class org.apache.beam.it.gcp.bigquery.conditions.BigQueryRowsCheck.Builder
-
- builder(String, String, CredentialsProvider) - Static method in class org.apache.beam.it.gcp.bigtable.BigtableResourceManager
-
- builder(Credentials) - Static method in class org.apache.beam.it.gcp.dataflow.ClassicTemplateClient
-
- builder(Credentials) - Static method in class org.apache.beam.it.gcp.dataflow.DefaultPipelineLauncher
-
- builder(Class<?>) - Static method in class org.apache.beam.it.gcp.dataflow.DirectRunnerClient
-
- builder(Credentials) - Static method in class org.apache.beam.it.gcp.dataflow.FlexTemplateClient
-
- builder(String, String, Credentials) - Static method in class org.apache.beam.it.gcp.datastore.DatastoreResourceManager
-
- builder(String, String, CredentialsProvider) - Static method in class org.apache.beam.it.gcp.datastream.DatastreamResourceManager
-
- Builder(String, String, String, int, Map<String, List<String>>) - Constructor for class org.apache.beam.it.gcp.datastream.JDBCSource.Builder
-
- builder(String, String, String, int, Map<String, List<String>>) - Static method in class org.apache.beam.it.gcp.datastream.MySQLSource
-
- Builder(String, String, String, int, Map<String, List<String>>) - Constructor for class org.apache.beam.it.gcp.datastream.MySQLSource.Builder
-
- builder(String, String, String, int, Map<String, List<String>>) - Static method in class org.apache.beam.it.gcp.datastream.OracleSource
-
- Builder(String, String, String, int, Map<String, List<String>>) - Constructor for class org.apache.beam.it.gcp.datastream.OracleSource.Builder
-
- builder(String, String, String, int, Map<String, List<String>>, String, String, String) - Static method in class org.apache.beam.it.gcp.datastream.PostgresqlSource
-
- Builder(String, String, String, int, Map<String, List<String>>, String, String, String) - Constructor for class org.apache.beam.it.gcp.datastream.PostgresqlSource.Builder
-
- builder(String, CredentialsProvider) - Static method in class org.apache.beam.it.gcp.dlp.DlpResourceManager
-
Creates a new Builder for constructing a DlpResourceManager instance.
- Builder(String, CredentialsProvider) - Constructor for class org.apache.beam.it.gcp.dlp.DlpResourceManager.Builder
-
Constructs a new Builder with the specified project.
- builder(String, CredentialsProvider) - Static method in class org.apache.beam.it.gcp.kms.KMSResourceManager
-
- builder() - Static method in class org.apache.beam.it.gcp.LoadTestBase.MetricsConfiguration
-
- Builder() - Constructor for class org.apache.beam.it.gcp.LoadTestBase.MetricsConfiguration.Builder
-
- builder(CredentialsProvider) - Static method in class org.apache.beam.it.gcp.monitoring.MonitoringClient
-
- builder(PubsubResourceManager, SubscriptionName) - Static method in class org.apache.beam.it.gcp.pubsub.conditions.PubsubMessagesCheck
-
- Builder() - Constructor for class org.apache.beam.it.gcp.pubsub.conditions.PubsubMessagesCheck.Builder
-
- builder(String, String, CredentialsProvider) - Static method in class org.apache.beam.it.gcp.pubsub.PubsubResourceManager
-
- builder(String, CredentialsProvider) - Static method in class org.apache.beam.it.gcp.secretmanager.SecretManagerResourceManager
-
- builder(String, String, String) - Static method in class org.apache.beam.it.gcp.spanner.SpannerResourceManager
-
- builder(String, String, String, int) - Static method in class org.apache.beam.it.gcp.spanner.SpannerResourceManager
-
- builder(String, String, String, Dialect) - Static method in class org.apache.beam.it.gcp.spanner.SpannerResourceManager
-
- builder(String, String, Credentials) - Static method in class org.apache.beam.it.gcp.storage.GcsResourceManager
-
- Builder(String, String, String) - Constructor for class org.apache.beam.it.jdbc.AbstractJDBCResourceManager.Builder
-
- builder(String) - Static method in class org.apache.beam.it.jdbc.MSSQLResourceManager
-
- Builder(String) - Constructor for class org.apache.beam.it.jdbc.MSSQLResourceManager.Builder
-
- builder(String) - Static method in class org.apache.beam.it.jdbc.MySQLResourceManager
-
- Builder(String) - Constructor for class org.apache.beam.it.jdbc.MySQLResourceManager.Builder
-
- builder(String) - Static method in class org.apache.beam.it.jdbc.OracleResourceManager
-
- Builder(String) - Constructor for class org.apache.beam.it.jdbc.OracleResourceManager.Builder
-
- builder(String) - Static method in class org.apache.beam.it.jdbc.PostgresResourceManager
-
- Builder(String) - Constructor for class org.apache.beam.it.jdbc.PostgresResourceManager.Builder
-
- builder(String) - Static method in class org.apache.beam.it.kafka.KafkaResourceManager
-
- builder(MongoDBResourceManager, String) - Static method in class org.apache.beam.it.mongodb.conditions.MongoDBDocumentsCheck
-
- Builder() - Constructor for class org.apache.beam.it.mongodb.conditions.MongoDBDocumentsCheck.Builder
-
- builder(String) - Static method in class org.apache.beam.it.mongodb.MongoDBResourceManager
-
- builder(Neo4jResourceManager) - Static method in class org.apache.beam.it.neo4j.conditions.Neo4jQueryCheck
-
- Builder() - Constructor for class org.apache.beam.it.neo4j.conditions.Neo4jQueryCheck.Builder
-
- builder(String) - Static method in class org.apache.beam.it.neo4j.Neo4jResourceManager
-
- builder(SplunkResourceManager) - Static method in class org.apache.beam.it.splunk.conditions.SplunkEventsCheck
-
- Builder() - Constructor for class org.apache.beam.it.splunk.conditions.SplunkEventsCheck.Builder
-
- builder(String) - Static method in class org.apache.beam.it.splunk.SplunkResourceManager
-
- Builder(String, String, String) - Constructor for class org.apache.beam.it.testcontainers.TestContainerResourceManager.Builder
-
- builder() - Static method in class org.apache.beam.runners.jobsubmission.JobPreparation
-
- builder() - Static method in class org.apache.beam.sdk.expansion.service.WindowIntoTransformProvider.Configuration
-
- Builder() - Constructor for class org.apache.beam.sdk.expansion.service.WindowIntoTransformProvider.Configuration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.extensions.gcp.storage.GcsCreateOptions
-
- Builder() - Constructor for class org.apache.beam.sdk.extensions.gcp.storage.GcsCreateOptions.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.extensions.gcp.util.CustomHttpErrors.Builder
-
- builder() - Static method in class org.apache.beam.sdk.extensions.gcp.util.GcsUtil.CreateOptions
-
- Builder() - Constructor for class org.apache.beam.sdk.extensions.gcp.util.GcsUtil.CreateOptions.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.extensions.ml.AnnotateText.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.extensions.ml.DLPDeidentifyText.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.extensions.ml.DLPInspectText.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.extensions.ml.DLPReidentifyText.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.extensions.ordered.OrderedProcessingStatus.Builder
-
- builder() - Static method in class org.apache.beam.sdk.extensions.sbe.SbeSchema.IrOptions
-
- Builder() - Constructor for class org.apache.beam.sdk.extensions.sbe.SbeSchema.IrOptions.Builder
-
- builder() - Static method in class org.apache.beam.sdk.extensions.sbe.UnsignedOptions
-
- Builder() - Constructor for class org.apache.beam.sdk.extensions.sbe.UnsignedOptions.Builder
-
- builder(TableProvider) - Static method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlEnv
-
Creates a builder with the default schema backed by the table provider.
- builder() - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.JoinRelOptRuleCall
-
- builder() - Static method in class org.apache.beam.sdk.extensions.sql.impl.UdfImplReflectiveFunctionBase
-
Creates a ParameterListBuilder.
- builder(RexNode) - Static method in class org.apache.beam.sdk.extensions.sql.impl.utils.SerializableRexNode
-
- Builder(RexNode) - Constructor for class org.apache.beam.sdk.extensions.sql.impl.utils.SerializableRexNode.Builder
-
- builder() - Static method in class org.apache.beam.sdk.extensions.sql.meta.Table
-
- Builder() - Constructor for class org.apache.beam.sdk.extensions.sql.meta.Table.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.extensions.sql.zetasql.translation.UserFunctionDefinitions.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.extensions.zetasketch.ApproximateCountDistinct.Globally.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.extensions.zetasketch.ApproximateCountDistinct.PerKey.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.aws.s3.S3FileSystemConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.aws.s3.S3FileSystemConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.aws2.common.ClientConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.aws2.common.ClientConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.aws2.common.HttpClientConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.aws2.common.HttpClientConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.aws2.common.RetryConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.aws2.common.RetryConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.aws2.kinesis.KinesisIO.RecordAggregation
-
- Builder() - Constructor for class org.apache.beam.sdk.io.aws2.kinesis.KinesisIO.RecordAggregation.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.aws2.kinesis.WatermarkParameters
-
- builder() - Static method in class org.apache.beam.sdk.io.aws2.s3.S3FileSystemConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.aws2.s3.S3FileSystemConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.aws2.s3.SSECustomerKey
-
- builder() - Static method in class org.apache.beam.sdk.io.cdap.Plugin
-
Creates a plugin builder instance.
- Builder() - Constructor for class org.apache.beam.sdk.io.cdap.Plugin.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.clickhouse.TableSchema.ColumnType
-
- builder() - Static method in class org.apache.beam.sdk.io.csv.providers.CsvWriteTransformProvider.CsvWriteConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.csv.providers.CsvWriteTransformProvider.CsvWriteConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.fileschematransform.FileReadSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.fileschematransform.FileReadSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.fileschematransform.FileWriteSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.fileschematransform.FileWriteSchemaTransformConfiguration.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.io.fileschematransform.FileWriteSchemaTransformConfiguration.CsvConfiguration.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.io.fileschematransform.FileWriteSchemaTransformConfiguration.ParquetConfiguration.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.io.fileschematransform.FileWriteSchemaTransformConfiguration.XmlConfiguration.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.io.fs.CreateOptions.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.fs.CreateOptions.StandardCreateOptions
-
- Builder() - Constructor for class org.apache.beam.sdk.io.fs.CreateOptions.StandardCreateOptions.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata
-
- Builder() - Constructor for class org.apache.beam.sdk.io.fs.MatchResult.Metadata.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryExportReadSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryExportReadSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryFileLoadsWriteSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryFileLoadsWriteSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryUtils.ConversionOptions
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryUtils.ConversionOptions.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryUtils.SchemaConversionOptions
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.BigQueryUtils.SchemaConversionOptions.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryDirectReadSchemaTransformProvider.BigQueryDirectReadSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryDirectReadSchemaTransformProvider.BigQueryDirectReadSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryStorageWriteApiSchemaTransformProvider.BigQueryStorageWriteApiSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryStorageWriteApiSchemaTransformProvider.BigQueryStorageWriteApiSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryStorageWriteApiSchemaTransformProvider.BigQueryStorageWriteApiSchemaTransformConfiguration.ErrorHandling
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryStorageWriteApiSchemaTransformProvider.BigQueryStorageWriteApiSchemaTransformConfiguration.ErrorHandling.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.StorageApiWritePayload.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableReadSchemaTransformProvider.BigtableReadSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.BigtableReadSchemaTransformProvider.BigtableReadSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableWriteSchemaTransformProvider.BigtableWriteSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.BigtableWriteSchemaTransformProvider.BigtableWriteSchemaTransformConfiguration.Builder
-
- Builder(JodaClock, FirestoreStatefulComponentFactory, RpcQosOptions, Instant) - Constructor for class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.BatchGetDocuments.Builder
-
- Builder(JodaClock, FirestoreStatefulComponentFactory, RpcQosOptions, boolean, Instant) - Constructor for class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.PartitionQuery.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubReadSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubReadSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubReadSchemaTransformConfiguration.ErrorHandling
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubReadSchemaTransformConfiguration.ErrorHandling.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubWriteSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubWriteSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubWriteSchemaTransformConfiguration.ErrorHandling
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubWriteSchemaTransformConfiguration.ErrorHandling.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.pubsublite.PublisherOptions.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.pubsublite.PubsubLiteReadSchemaTransformProvider.PubsubLiteReadSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.pubsublite.PubsubLiteReadSchemaTransformProvider.PubsubLiteReadSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.pubsublite.PubsubLiteWriteSchemaTransformProvider.PubsubLiteWriteSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.pubsublite.PubsubLiteWriteSchemaTransformProvider.PubsubLiteWriteSchemaTransformConfiguration.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.pubsublite.SubscriberOptions.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.pubsublite.UuidDeduplicationOptions.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.ChangeStreamRecordMetadata.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.PartitionMetadata.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.spanner.changestreams.SpannerChangestreamsReadSchemaTransformProvider.SpannerChangestreamsReadConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.spanner.changestreams.SpannerChangestreamsReadSchemaTransformProvider.SpannerChangestreamsReadConfiguration.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.spanner.SpannerConfig.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.spanner.SpannerIO.CreateTransaction.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.spanner.SpannerSchema
-
- builder(Dialect) - Static method in class org.apache.beam.sdk.io.gcp.spanner.SpannerSchema
-
- builder() - Static method in class org.apache.beam.sdk.io.gcp.spanner.SpannerWriteSchemaTransformProvider.SpannerWriteSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.gcp.spanner.SpannerWriteSchemaTransformProvider.SpannerWriteSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.iceberg.IcebergCatalogConfig
-
- Builder() - Constructor for class org.apache.beam.sdk.io.iceberg.IcebergCatalogConfig.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.iceberg.IcebergDestination
-
- Builder() - Constructor for class org.apache.beam.sdk.io.iceberg.IcebergDestination.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.iceberg.IcebergReadSchemaTransformProvider.Config
-
- Builder() - Constructor for class org.apache.beam.sdk.io.iceberg.IcebergReadSchemaTransformProvider.Config.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.iceberg.IcebergScanConfig
-
- Builder() - Constructor for class org.apache.beam.sdk.io.iceberg.IcebergScanConfig.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.iceberg.IcebergSchemaTransformCatalogConfig
-
- Builder() - Constructor for class org.apache.beam.sdk.io.iceberg.IcebergSchemaTransformCatalogConfig.Builder
-
- builder() - Method in class org.apache.beam.sdk.io.iceberg.IcebergTableCreateConfig
-
- Builder() - Constructor for class org.apache.beam.sdk.io.iceberg.IcebergTableCreateConfig.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.iceberg.IcebergWriteSchemaTransformProvider.Config
-
- Builder() - Constructor for class org.apache.beam.sdk.io.iceberg.IcebergWriteSchemaTransformProvider.Config.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.iceberg.SnapshotInfo
-
- Builder() - Constructor for class org.apache.beam.sdk.io.iceberg.SnapshotInfo.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.jdbc.JdbcReadSchemaTransformProvider.JdbcReadSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.jdbc.JdbcReadSchemaTransformProvider.JdbcReadSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.jdbc.JdbcWriteSchemaTransformProvider.JdbcWriteSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.jdbc.JdbcWriteSchemaTransformProvider.JdbcWriteSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.json.providers.JsonWriteTransformProvider.JsonWriteConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.json.providers.JsonWriteTransformProvider.JsonWriteConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.kafka.KafkaReadSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.kafka.KafkaReadSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.kafka.KafkaWriteSchemaTransformProvider.KafkaWriteSchemaTransformConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.kafka.KafkaWriteSchemaTransformProvider.KafkaWriteSchemaTransformConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.kinesis.WatermarkParameters
-
- builder() - Static method in class org.apache.beam.sdk.io.singlestore.schematransform.SingleStoreSchemaTransformReadConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.singlestore.schematransform.SingleStoreSchemaTransformReadConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.singlestore.schematransform.SingleStoreSchemaTransformWriteConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.io.singlestore.schematransform.SingleStoreSchemaTransformWriteConfiguration.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.io.splunk.SplunkEvent.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.io.splunk.SplunkWriteError.Builder
-
- builder() - Static method in class org.apache.beam.sdk.io.TextRowCountEstimator
-
- Builder() - Constructor for class org.apache.beam.sdk.io.TextRowCountEstimator.Builder
-
- builder() - Static method in class org.apache.beam.sdk.managed.testing.TestSchemaTransformProvider.Config
-
- Builder() - Constructor for class org.apache.beam.sdk.managed.testing.TestSchemaTransformProvider.Config.Builder
-
- builder() - Static method in class org.apache.beam.sdk.metrics.MetricsFilter
-
- Builder() - Constructor for class org.apache.beam.sdk.metrics.MetricsFilter.Builder
-
- builder() - Static method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration
-
- Builder() - Constructor for class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate
-
- Builder() - Constructor for class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate.Builder
-
- builder() - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
-
- Builder() - Constructor for class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.schemas.FieldValueTypeInformation.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.schemas.io.Failure.Builder
-
- builder() - Static method in class org.apache.beam.sdk.schemas.Schema
-
- Builder() - Constructor for class org.apache.beam.sdk.schemas.Schema.Builder
-
- Builder() - Constructor for class org.apache.beam.sdk.schemas.Schema.Field.Builder
-
- builder() - Static method in class org.apache.beam.sdk.schemas.Schema.Options
-
- builder() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling
-
- Builder() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling.Builder
-
- builder() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.FlattenTransformProvider.Configuration
-
- Builder() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.FlattenTransformProvider.Configuration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider.Configuration
-
- Builder() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider.Configuration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider.Configuration
-
- Builder() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider.Configuration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration
-
- Builder() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.Configuration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration
-
- Builder() - Constructor for class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration.Builder
-
- builder() - Static method in class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider.Configuration
-
- 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() - Static method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord
-
- Builder() - Constructor for class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Builder
-
- builder() - Static method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Failure
-
- Builder() - Constructor for class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Failure.Builder
-
- builder() - Static method in class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record
-
- 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
-
- builderForType(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.extensions.zetasketch.ApproximateCountDistinct
-
- builderFrom(S3Options) - Static method in class org.apache.beam.sdk.io.aws2.s3.S3FileSystemConfiguration
-
- builderWithSchemaLocation(String, String) - Static method in class org.apache.beam.it.gcp.datagenerator.DataGenerator
-
- builderWithSchemaTemplate(String, String) - Static method in class org.apache.beam.it.gcp.datagenerator.DataGenerator
-
- buildExternal(DebeziumTransformRegistrar.ReadBuilder.Configuration) - Method in class org.apache.beam.io.debezium.DebeziumTransformRegistrar.ReadBuilder
-
- buildExternal(ExternalRead.Configuration) - Method in class org.apache.beam.sdk.io.gcp.pubsub.ExternalRead.ReadBuilder
-
- buildExternal(ExternalWrite.Configuration) - Method in class org.apache.beam.sdk.io.gcp.pubsub.ExternalWrite.WriteBuilder
-
- buildExternal(SpannerTransformRegistrar.ReadBuilder.Configuration) - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerTransformRegistrar.ReadBuilder
-
- buildExternal(KinesisTransformRegistrar.ReadDataBuilder.Configuration) - Method in class org.apache.beam.sdk.io.kinesis.KinesisTransformRegistrar.ReadDataBuilder
-
- buildExternal(KinesisTransformRegistrar.WriteBuilder.Configuration) - Method in class org.apache.beam.sdk.io.kinesis.KinesisTransformRegistrar.WriteBuilder
-
- buildExternal(ReadBuilder.Configuration) - Method in class org.apache.beam.sdk.io.snowflake.crosslanguage.ReadBuilder
-
- buildExternal(WriteBuilder.Configuration) - Method in class org.apache.beam.sdk.io.snowflake.crosslanguage.WriteBuilder
-
- buildExternal(ConfigT) - Method in interface org.apache.beam.sdk.transforms.ExternalTransformBuilder
-
Builds the transform after it has been configured.
- buildFrom(Descriptors.Descriptor) - Static method in class org.apache.beam.sdk.extensions.protobuf.ProtoDomain
-
- buildFrom(DescriptorProtos.FileDescriptorSet) - Static method in class org.apache.beam.sdk.extensions.protobuf.ProtoDomain
-
- buildFrom(Descriptors.FileDescriptor) - Static method in class org.apache.beam.sdk.extensions.protobuf.ProtoDomain
-
- buildFrom(InputStream) - Static method in class org.apache.beam.sdk.extensions.protobuf.ProtoDomain
-
- buildGCSDestinationConfig(String, String, DatastreamResourceManager.DestinationOutputFormat) - Method in class org.apache.beam.it.gcp.datastream.DatastreamResourceManager
-
- buildIOReader(PBegin) - Method in class org.apache.beam.sdk.extensions.sql.impl.schema.BeamPCollectionTable
-
- buildIOReader(PBegin, BeamSqlTableFilter, List<String>) - Method in class org.apache.beam.sdk.extensions.sql.meta.BaseBeamTable
-
- buildIOReader(PBegin) - Method in interface org.apache.beam.sdk.extensions.sql.meta.BeamSqlTable
-
create a PCollection<Row>
from source.
- buildIOReader(PBegin, BeamSqlTableFilter, List<String>) - Method in interface org.apache.beam.sdk.extensions.sql.meta.BeamSqlTable
-
create a PCollection<Row>
from source with predicate and/or project pushed-down.
- buildIOReader(PBegin) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.bigtable.BigtableTable
-
- buildIOReader(PBegin, BeamSqlTableFilter, List<String>) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.bigtable.BigtableTable
-
- buildIOReader(PBegin) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.hcatalog.HCatalogTable
-
- buildIOReader(PBegin) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaTable
-
- buildIOReader(PBegin) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.mongodb.MongoDbTable
-
- buildIOReader(PBegin, BeamSqlTableFilter, List<String>) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.mongodb.MongoDbTable
-
- buildIOReader(PBegin) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestBoundedTable
-
- buildIOReader(PBegin) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestUnboundedTable
-
- buildIOReader(PBegin) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.text.TextTable
-
- buildIOWriter(PCollection<Row>) - Method in class org.apache.beam.sdk.extensions.sql.impl.schema.BeamPCollectionTable
-
- buildIOWriter(PCollection<Row>) - Method in interface org.apache.beam.sdk.extensions.sql.meta.BeamSqlTable
-
create a IO.write()
instance to write to target.
- buildIOWriter(PCollection<Row>) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.bigtable.BigtableTable
-
- buildIOWriter(PCollection<Row>) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.hcatalog.HCatalogTable
-
- buildIOWriter(PCollection<Row>) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaTable
-
- buildIOWriter(PCollection<Row>) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.mongodb.MongoDbTable
-
- buildIOWriter(PCollection<Row>) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestBoundedTable
-
- buildIOWriter(PCollection<Row>) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestTable
-
- buildIOWriter(PCollection<Row>) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.text.TextTable
-
- buildProducer(Serializer<K>, Serializer<V>) - Method in class org.apache.beam.it.kafka.KafkaResourceManager
-
Build a
KafkaProducer
for the given serializer and deserializers.
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamAggregationRel
-
- buildPTransform(PTransform<PCollection<Row>, ? extends POutput>) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamCalcRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamCalcRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamCoGBKJoinRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamIntersectRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamIOSinkRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamIOSourceRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamMatchRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamMinusRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamPushDownIOSourceRel
-
- buildPTransform() - Method in interface org.apache.beam.sdk.extensions.sql.impl.rel.BeamRelNode
-
- buildPTransform(PTransform<PCollection<Row>, ? extends POutput>) - Method in interface org.apache.beam.sdk.extensions.sql.impl.rel.BeamRelNode
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSideInputJoinRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSideInputLookupJoinRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSortRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamTableFunctionScanRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamUncollectRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamUnionRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamUnnestRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamValuesRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamWindowRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.zetasql.BeamZetaSqlCalcRel
-
- buildPTransform(PTransform<PCollection<Row>, ? extends POutput>) - Method in class org.apache.beam.sdk.extensions.sql.zetasql.BeamZetaSqlCalcRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.zetasql.unnest.BeamZetaSqlUncollectRel
-
- buildPTransform() - Method in class org.apache.beam.sdk.extensions.sql.zetasql.unnest.BeamZetaSqlUnnestRel
-
- buildReader() - Method in class org.apache.beam.sdk.io.gcp.datastore.DataStoreV1SchemaIOProvider.DataStoreV1SchemaIO
-
- buildReader() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIO
-
Returns a schema aware reader.
- buildRows(Schema, List<?>) - Static method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestTableUtils
-
Convenient way to build a BeamSqlRow
s.
- buildSchemaWithAttributes(Schema, List<String>, String) - Static method in class org.apache.beam.sdk.io.gcp.pubsublite.PubsubLiteReadSchemaTransformProvider
-
Builds a new
Schema
by adding additional optional attributes and map field to the
provided schema.
- buildSourceConfig(String, JDBCSource) - Method in class org.apache.beam.it.gcp.datastream.DatastreamResourceManager
-
- 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.
- buildTransform(FileReadSchemaTransformConfiguration) - Method in class org.apache.beam.sdk.io.fileschematransform.AvroReadSchemaTransformFormatProvider
-
- buildTransform(FileWriteSchemaTransformConfiguration, Schema) - Method in class org.apache.beam.sdk.io.fileschematransform.AvroWriteSchemaTransformFormatProvider
-
- buildTransform(FileWriteSchemaTransformConfiguration, Schema) - Method in class org.apache.beam.sdk.io.fileschematransform.CsvWriteSchemaTransformFormatProvider
-
- buildTransform(FileReadSchemaTransformConfiguration) - Method in interface org.apache.beam.sdk.io.fileschematransform.FileReadSchemaTransformFormatProvider
-
- buildTransform(FileWriteSchemaTransformConfiguration, Schema) - Method in interface org.apache.beam.sdk.io.fileschematransform.FileWriteSchemaTransformFormatProvider
-
- buildTransform(FileReadSchemaTransformConfiguration) - Method in class org.apache.beam.sdk.io.fileschematransform.JsonReadSchemaTransformFormatProvider
-
- buildTransform(FileWriteSchemaTransformConfiguration, Schema) - Method in class org.apache.beam.sdk.io.fileschematransform.JsonWriteSchemaTransformFormatProvider
-
- buildTransform(FileReadSchemaTransformConfiguration) - Method in class org.apache.beam.sdk.io.fileschematransform.LineReadSchemaTransformFormatProvider
-
- buildTransform(FileReadSchemaTransformConfiguration) - Method in class org.apache.beam.sdk.io.fileschematransform.ParquetReadSchemaTransformFormatProvider
-
- buildTransform(FileWriteSchemaTransformConfiguration, Schema) - Method in class org.apache.beam.sdk.io.fileschematransform.ParquetWriteSchemaTransformFormatProvider
-
- buildTransform(FileWriteSchemaTransformConfiguration, Schema) - Method in class org.apache.beam.sdk.io.fileschematransform.XmlWriteSchemaTransformFormatProvider
-
- buildWriter() - Method in class org.apache.beam.sdk.io.gcp.datastore.DataStoreV1SchemaIOProvider.DataStoreV1SchemaIO
-
- buildWriter() - Method in interface org.apache.beam.sdk.schemas.io.SchemaIO
-
Returns a schema aware writer.
- BUILTIN_AGGREGATOR_FACTORIES - Static variable in class org.apache.beam.sdk.extensions.sql.impl.transform.BeamBuiltinAggregations
-
- BUILTIN_ANALYTIC_FACTORIES - Static variable in class org.apache.beam.sdk.extensions.sql.impl.transform.BeamBuiltinAnalyticFunctions
-
- BuiltinHashFunctions - Class in org.apache.beam.sdk.extensions.sql.impl.udf
-
Hash Functions.
- BuiltinHashFunctions() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.udf.BuiltinHashFunctions
-
- BuiltinStringFunctions - Class in org.apache.beam.sdk.extensions.sql.impl.udf
-
BuiltinStringFunctions.
- BuiltinStringFunctions() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.udf.BuiltinStringFunctions
-
- BuiltinTrigonometricFunctions - Class in org.apache.beam.sdk.extensions.sql.impl.udf
-
TrigonometricFunctions.
- BuiltinTrigonometricFunctions() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.udf.BuiltinTrigonometricFunctions
-
- bulkIO() - Static method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO
-
- BulkIO() - Constructor for class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.BulkIO
-
- Bundle<T,CollectionT> - Interface in org.apache.beam.runners.local
-
An immutable collection of elements which are part of a PCollection
.
- BundleCheckpointHandler - Interface in org.apache.beam.runners.fnexecution.control
-
A handler which is invoked when the SDK returns BeamFnApi.DelayedBundleApplication
s as
part of the bundle completion.
- BundleCheckpointHandlers - Class in org.apache.beam.runners.fnexecution.control
-
- BundleCheckpointHandlers() - Constructor for class org.apache.beam.runners.fnexecution.control.BundleCheckpointHandlers
-
- BundleCheckpointHandlers.StateAndTimerBundleCheckpointHandler<T> - Class in org.apache.beam.runners.fnexecution.control
-
- BundleFinalizationHandler - Interface in org.apache.beam.runners.fnexecution.control
-
A handler for the runner when a finalization request has been received.
- BundleFinalizationHandlers - Class in org.apache.beam.runners.fnexecution.control
-
- BundleFinalizationHandlers() - Constructor for class org.apache.beam.runners.fnexecution.control.BundleFinalizationHandlers
-
- BundleFinalizationHandlers.InMemoryFinalizer - Class in org.apache.beam.runners.fnexecution.control
-
- BundleProgressHandler - Interface in org.apache.beam.runners.fnexecution.control
-
A handler for bundle progress messages, both during bundle execution and on its completion.
- BundleSplitHandler - Interface in org.apache.beam.runners.fnexecution.control
-
A handler which is invoked whenever an active bundle is split.
- by(SerializableFunction<UserT, DestinationT>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
Specifies how to partition elements into groups ("destinations").
- by(Contextful<Contextful.Fn<UserT, DestinationT>>) - Method in class org.apache.beam.sdk.io.FileIO.Write
-
- By() - Constructor for class org.apache.beam.sdk.schemas.transforms.CoGroup.By
-
- by(PredicateT) - Static method in class org.apache.beam.sdk.transforms.Filter
-
Returns a PTransform
that takes an input PCollection<T>
and returns a PCollection<T>
with elements that satisfy the given predicate.
- by(PredicateT) - Static method in class org.apache.beam.sdk.transforms.Filter
-
- byFieldAccessDescriptor(FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
-
Returns a transform that groups all elements in the input
PCollection
keyed by the
fields specified.
- byFieldIds(Integer...) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
-
Returns a transform that groups all elements in the input
PCollection
keyed by the list
of fields specified.
- byFieldIds(Iterable<Integer>) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
-
- byFieldNames(String...) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
-
Returns a transform that groups all elements in the input
PCollection
keyed by the list
of fields specified.
- byFieldNames(Iterable<String>) - Static method in class org.apache.beam.sdk.schemas.transforms.Group
-
- ByFields() - Constructor for class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
- byId(int, int, RetryConfiguration, AsyncBatchWriteHandler.Stats, BiFunction<String, List<RecT>, CompletableFuture<List<ErrT>>>, Function<ErrT, String>, Function<RecT, String>, Function<ErrT, String>) - Static method in class org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandler
-
AsyncBatchWriteHandler that correlates records and results by id, all results are erroneous.
- byId(int, FluentBackoff, AsyncBatchWriteHandler.Stats, BiFunction<String, List<RecT>, CompletableFuture<List<ErrT>>>, Function<ErrT, String>, Function<RecT, String>, Function<ErrT, String>) - Static method in class org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandler
-
AsyncBatchWriteHandler that correlates records and results by id, all results are erroneous.
- byKey() - Static method in class org.apache.beam.sdk.transforms.Redistribute
-
- byPosition(int, int, RetryConfiguration, AsyncBatchWriteHandler.Stats, BiFunction<String, List<RecT>, CompletableFuture<List<ResT>>>, Function<ResT, String>) - Static method in class org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandler
-
AsyncBatchWriteHandler that correlates records and results by position in the respective list.
- byPosition(int, FluentBackoff, AsyncBatchWriteHandler.Stats, BiFunction<String, List<RecT>, CompletableFuture<List<ResT>>>, Function<ResT, String>) - Static method in class org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandler
-
AsyncBatchWriteHandler that correlates records and results by position in the respective list.
- BYTE - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
-
The type of byte fields.
- ByteArray - Class in org.apache.beam.runners.spark.util
-
Serializable byte array.
- ByteArray(byte[]) - Constructor for class org.apache.beam.runners.spark.util.ByteArray
-
- ByteArrayCoder - Class in org.apache.beam.sdk.coders
-
- ByteArrayKey(byte[]) - Constructor for class org.apache.beam.runners.jet.Utils.ByteArrayKey
-
- ByteBuddyUtils - Class in org.apache.beam.sdk.schemas.utils
-
- ByteBuddyUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils
-
- ByteBuddyUtils.ConvertType - Class in org.apache.beam.sdk.schemas.utils
-
Give a Java type, returns the Java type expected for use with Row.
- ByteBuddyUtils.ConvertValueForGetter - Class in org.apache.beam.sdk.schemas.utils
-
- 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
-
- ByteBufferBundle() - Constructor for class org.apache.beam.sdk.jmh.schemas.RowBundles.ByteBufferBundle
-
- ByteCoder - Class in org.apache.beam.sdk.coders
-
A
ByteCoder
encodes
Byte
values in 1 byte using Java serialization.
- ByteKey - Class in org.apache.beam.sdk.io.range
-
A class representing a key consisting of an array of bytes.
- ByteKeyRange - Class in org.apache.beam.sdk.io.range
-
A class representing a range of
ByteKeys
.
- ByteKeyRangeTracker - Class in org.apache.beam.sdk.io.range
-
- ByteKeyRangeTracker - Class in org.apache.beam.sdk.transforms.splittabledofn
-
- Bytes() - Constructor for class org.apache.beam.sdk.jmh.util.VarIntBenchmark.Bytes
-
- BYTES - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
-
The type of bytes fields.
- bytes() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
- BytesBundle() - Constructor for class org.apache.beam.sdk.jmh.schemas.RowBundles.BytesBundle
-
- 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.
- BytesThroughputEstimator<T> - Class in org.apache.beam.sdk.io.gcp.bigtable.changestreams.estimator
-
An estimator to provide an estimate on the byte throughput of the outputted elements.
- BytesThroughputEstimator(SizeEstimator<T>, Instant) - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.changestreams.estimator.BytesThroughputEstimator
-
- BytesThroughputEstimator(SizeEstimator<T>, int, Instant) - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.changestreams.estimator.BytesThroughputEstimator
-
- BytesThroughputEstimator<T> - Class in org.apache.beam.sdk.io.gcp.spanner.changestreams.estimator
-
An estimator to provide an estimate on the throughput of the outputted elements.
- BytesThroughputEstimator(int, SizeEstimator<T>) - Constructor for class org.apache.beam.sdk.io.gcp.spanner.changestreams.estimator.BytesThroughputEstimator
-
- bytesToRowFn(SchemaProvider, TypeDescriptor<T>, ProcessFunction<byte[], ? extends T>) - Static method in class org.apache.beam.sdk.schemas.RowMessages
-
- bytesToRowFn(SchemaProvider, TypeDescriptor<T>, Coder<? extends T>) - Static method in class org.apache.beam.sdk.schemas.RowMessages
-
- byteString(byte[]) - Static method in class org.apache.beam.sdk.io.gcp.bigtable.RowUtils
-
- byteString(byte[]) - Static method in class org.apache.beam.sdk.io.gcp.testing.BigtableUtils
-
- ByteStringCoder - Class in org.apache.beam.runners.fnexecution.wire
-
A duplicate of
ByteStringCoder
that uses the Apache Beam vendored protobuf.
- ByteStringCoder - Class in org.apache.beam.sdk.extensions.protobuf
-
A
Coder
for
ByteString
objects based on their encoded Protocol Buffer form.
- ByteStringOutput() - Constructor for class org.apache.beam.sdk.jmh.util.VarIntBenchmark.ByteStringOutput
-
- ByteStringOutputStreamBenchmark - Class in org.apache.beam.sdk.jmh.util
-
Benchmarks for ByteStringOutputStream
.
- ByteStringOutputStreamBenchmark() - Constructor for class org.apache.beam.sdk.jmh.util.ByteStringOutputStreamBenchmark
-
- ByteStringOutputStreamBenchmark.NewVsCopy - Class in org.apache.beam.sdk.jmh.util
-
These benchmarks below provide good details as to the cost of creating a new buffer vs copying
a subset of the existing one and re-using the larger one.
- ByteStringOutputStreamBenchmark.NewVsCopy.ArrayCopyState - Class in org.apache.beam.sdk.jmh.util
-
- ByteStringOutputStreamBenchmark.NewVsCopy.ArrayNewState - Class in org.apache.beam.sdk.jmh.util
-
- ByteStringOutputStreamBenchmark.ProtobufByteStringOutputStream - Class in org.apache.beam.sdk.jmh.util
-
- ByteStringOutputStreamBenchmark.SdkCoreByteStringOutputStream - Class in org.apache.beam.sdk.jmh.util
-
- ByteStringRangeHelper - Class in org.apache.beam.sdk.io.gcp.bigtable.changestreams
-
Helper functions to evaluate the completeness of collection of ByteStringRanges.
- ByteStringRangeHelper() - Constructor for class org.apache.beam.sdk.io.gcp.bigtable.changestreams.ByteStringRangeHelper
-
- byteStringUtf8(String) - Static method in class org.apache.beam.sdk.io.gcp.bigtable.RowUtils
-
- byteStringUtf8(String) - Static method in class org.apache.beam.sdk.io.gcp.testing.BigtableUtils
-
- bytesWritten() - Static method in class org.apache.beam.sdk.metrics.SinkMetrics
-
Counter of bytes written to a sink.
- ByteToElemFunction<V> - Class in org.apache.beam.runners.twister2.translators.functions
-
ByteToWindow function.
- ByteToElemFunction() - Constructor for class org.apache.beam.runners.twister2.translators.functions.ByteToElemFunction
-
- ByteToElemFunction(WindowedValue.WindowedValueCoder<V>) - Constructor for class org.apache.beam.runners.twister2.translators.functions.ByteToElemFunction
-
- ByteToWindowFunction<K,V> - Class in org.apache.beam.runners.twister2.translators.functions
-
ByteToWindow function.
- ByteToWindowFunction() - Constructor for class org.apache.beam.runners.twister2.translators.functions.ByteToWindowFunction
-
- ByteToWindowFunction(Coder<K>, WindowedValue.WindowedValueCoder<V>) - Constructor for class org.apache.beam.runners.twister2.translators.functions.ByteToWindowFunction
-
- ByteToWindowFunctionPrimitive<K,V> - Class in org.apache.beam.runners.twister2.translators.functions
-
ByteToWindow function.
- ByteToWindowFunctionPrimitive() - Constructor for class org.apache.beam.runners.twister2.translators.functions.ByteToWindowFunctionPrimitive
-
- ByteToWindowFunctionPrimitive(Coder<K>, WindowedValue.WindowedValueCoder<V>) - Constructor for class org.apache.beam.runners.twister2.translators.functions.ByteToWindowFunctionPrimitive
-