- Gauge - Interface in org.apache.beam.sdk.metrics
-
A metric that reports the latest value out of reported values.
- gauge(String, String) - Static method in class org.apache.beam.sdk.metrics.Metrics
-
Create a metric that can have its new value set, and is aggregated by taking the last reported
value.
- gauge(Class<?>, String) - Static method in class org.apache.beam.sdk.metrics.Metrics
-
Create a metric that can have its new value set, and is aggregated by taking the last reported
value.
- GaugeImpl - Class in org.apache.beam.runners.jet.metrics
-
- GaugeImpl(MetricName) - Constructor for class org.apache.beam.runners.jet.metrics.GaugeImpl
-
- GaugeResult - Class in org.apache.beam.sdk.metrics
-
The result of a
Gauge
metric.
- GaugeResult() - Constructor for class org.apache.beam.sdk.metrics.GaugeResult
-
- GaugeResult.EmptyGaugeResult - Class in org.apache.beam.sdk.metrics
-
- GcpCredentialFactory - Class in org.apache.beam.sdk.extensions.gcp.auth
-
Construct an oauth credential to be used by the SDK and the SDK workers.
- GcpCredentialFactory() - Constructor for class org.apache.beam.sdk.extensions.gcp.auth.GcpCredentialFactory
-
- GcpIoPipelineOptionsRegistrar - Class in org.apache.beam.sdk.io.gcp.common
-
A registrar containing the default GCP options.
- GcpIoPipelineOptionsRegistrar() - Constructor for class org.apache.beam.sdk.io.gcp.common.GcpIoPipelineOptionsRegistrar
-
- GcpOptions - Interface in org.apache.beam.sdk.extensions.gcp.options
-
Options used to configure Google Cloud Platform specific options such as the project and
credentials.
- GcpOptions.DefaultProjectFactory - Class in org.apache.beam.sdk.extensions.gcp.options
-
Attempts to infer the default project based upon the environment this application is executing
within.
- GcpOptions.EnableStreamingEngineFactory - Class in org.apache.beam.sdk.extensions.gcp.options
-
EneableStreamingEngine defaults to false unless one of the two experiments is set.
- GcpOptions.GcpTempLocationFactory - Class in org.apache.beam.sdk.extensions.gcp.options
-
- GcpOptions.GcpUserCredentialsFactory - Class in org.apache.beam.sdk.extensions.gcp.options
-
Attempts to load the GCP credentials.
- GcpPipelineOptionsRegistrar - Class in org.apache.beam.sdk.extensions.gcp.options
-
A registrar containing the default GCP options.
- GcpPipelineOptionsRegistrar() - Constructor for class org.apache.beam.sdk.extensions.gcp.options.GcpPipelineOptionsRegistrar
-
- GcpTempLocationFactory() - Constructor for class org.apache.beam.sdk.extensions.gcp.options.GcpOptions.GcpTempLocationFactory
-
- GcpUserCredentialsFactory() - Constructor for class org.apache.beam.sdk.extensions.gcp.options.GcpOptions.GcpUserCredentialsFactory
-
- GCS_URI - Static variable in class org.apache.beam.sdk.extensions.gcp.util.gcsfs.GcsPath
-
Pattern that is used to parse a GCS URL.
- GcsCreateOptions - Class in org.apache.beam.sdk.extensions.gcp.storage
-
An abstract class that contains common configuration options for creating resources.
- GcsCreateOptions() - Constructor for class org.apache.beam.sdk.extensions.gcp.storage.GcsCreateOptions
-
- GcsCreateOptions.Builder - Class in org.apache.beam.sdk.extensions.gcp.storage
-
- GcsFileSystemRegistrar - Class in org.apache.beam.sdk.extensions.gcp.storage
-
AutoService
registrar for the GcsFileSystem
.
- GcsFileSystemRegistrar() - Constructor for class org.apache.beam.sdk.extensions.gcp.storage.GcsFileSystemRegistrar
-
- GcsOptions - Interface in org.apache.beam.sdk.extensions.gcp.options
-
Options used to configure Google Cloud Storage.
- GcsOptions.ExecutorServiceFactory - Class in org.apache.beam.sdk.extensions.gcp.options
-
Returns the default ExecutorService
to use within the Apache Beam SDK.
- GcsOptions.PathValidatorFactory - Class in org.apache.beam.sdk.extensions.gcp.options
-
- GcsPath - Class in org.apache.beam.sdk.extensions.gcp.util.gcsfs
-
Implements the Java NIO Path
API for Google Cloud Storage paths.
- GcsPath(FileSystem, String, String) - Constructor for class org.apache.beam.sdk.extensions.gcp.util.gcsfs.GcsPath
-
Constructs a GcsPath.
- GcsPathValidator - Class in org.apache.beam.sdk.extensions.gcp.storage
-
- GcsResourceId - Class in org.apache.beam.sdk.extensions.gcp.storage
-
ResourceId
implementation for Google Cloud Storage.
- GcsStager - Class in org.apache.beam.runners.dataflow.util
-
Utility class for staging files to GCS.
- gcsUploadBufferSizeBytes() - Method in class org.apache.beam.sdk.extensions.gcp.storage.GcsCreateOptions
-
The buffer size (in bytes) to use when uploading files to GCS.
- GcsUtil - Class in org.apache.beam.sdk.extensions.gcp.util
-
Provides operations on GCS.
- GcsUtil.GcsUtilFactory - Class in org.apache.beam.sdk.extensions.gcp.util
-
- GcsUtil.StorageObjectOrIOException - Class in org.apache.beam.sdk.extensions.gcp.util
-
- GcsUtilFactory() - Constructor for class org.apache.beam.sdk.extensions.gcp.util.GcsUtil.GcsUtilFactory
-
- GearpumpPipelineOptions - Interface in org.apache.beam.runners.gearpump
-
Options that configure the Gearpump pipeline.
- GearpumpPipelineResult - Class in org.apache.beam.runners.gearpump
-
Result of executing a
Pipeline
with Gearpump.
- GearpumpPipelineResult(ClientContext, RunningApplication) - Constructor for class org.apache.beam.runners.gearpump.GearpumpPipelineResult
-
- GearpumpPipelineTranslator - Class in org.apache.beam.runners.gearpump.translators
-
- GearpumpPipelineTranslator(TranslationContext) - Constructor for class org.apache.beam.runners.gearpump.translators.GearpumpPipelineTranslator
-
- GearpumpRunner - Class in org.apache.beam.runners.gearpump
-
A
PipelineRunner
that executes the operations in the pipeline by first translating them
to Gearpump Stream DSL and then executing them on a Gearpump cluster.
- GearpumpRunner(GearpumpPipelineOptions) - Constructor for class org.apache.beam.runners.gearpump.GearpumpRunner
-
- GearpumpRunnerRegistrar - Class in org.apache.beam.runners.gearpump
-
- GearpumpRunnerRegistrar.Options - Class in org.apache.beam.runners.gearpump
-
- GearpumpRunnerRegistrar.Runner - Class in org.apache.beam.runners.gearpump
-
- GearpumpSource<T> - Class in org.apache.beam.runners.gearpump.translators.io
-
- GearpumpWindowFn(boolean) - Constructor for class org.apache.beam.runners.gearpump.translators.GroupByKeyTranslator.GearpumpWindowFn
-
- generate(Schema) - Static method in class org.apache.beam.sdk.coders.RowCoderGenerator
-
- GenerateSequence - Class in org.apache.beam.sdk.io
-
A
PTransform
that produces longs starting from the given value, and either up to the
given limit or until
Long.MAX_VALUE
/ until the given time elapses.
- GenerateSequence() - Constructor for class org.apache.beam.sdk.io.GenerateSequence
-
- GenerateSequence.External - Class in org.apache.beam.sdk.io
-
Exposes GenerateSequence as an external transform for cross-language usage.
- GenerateSequence.External.ExternalConfiguration - Class in org.apache.beam.sdk.io
-
Parameters class to expose the transform to an external SDK.
- GenerateSequenceTableProvider - Class in org.apache.beam.sdk.extensions.sql.meta.provider.seqgen
-
Sequence generator table provider.
- GenerateSequenceTableProvider() - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.seqgen.GenerateSequenceTableProvider
-
- generateStagingSessionToken(String, String) - Static method in class org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService
-
- GenericRecordReadConverter - Class in org.apache.beam.sdk.extensions.sql.meta.provider.parquet
-
- GenericRecordReadConverter() - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.parquet.GenericRecordReadConverter
-
- GenericRecordWriteConverter - Class in org.apache.beam.sdk.extensions.sql.meta.provider.avro
-
- GenericRecordWriteConverter() - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.avro.GenericRecordWriteConverter
-
- get(JobInfo) - Method in interface org.apache.beam.runners.fnexecution.control.ExecutableStageContext.Factory
-
- get(JobInfo) - Method in class org.apache.beam.runners.fnexecution.control.ReferenceCountingExecutableStageContextFactory
-
- get(K, W) - Method in interface org.apache.beam.runners.fnexecution.state.StateRequestHandlers.BagUserStateHandler
-
Returns an Iterable
of values representing the bag user state for the given key and
window.
- get(W) - Method in interface org.apache.beam.runners.fnexecution.state.StateRequestHandlers.IterableSideInputHandler
-
Returns an Iterable
of values representing the side input for the given window.
- get(W) - Method in interface org.apache.beam.runners.fnexecution.state.StateRequestHandlers.MultimapSideInputHandler
-
Returns an Iterable
of keys representing the side input for the given window.
- get(K, W) - Method in interface org.apache.beam.runners.fnexecution.state.StateRequestHandlers.MultimapSideInputHandler
-
Returns an Iterable
of values representing the side input for the given key and
window.
- get() - Method in class org.apache.beam.runners.portability.CloseableResource
-
Gets the underlying resource.
- get() - Static method in class org.apache.beam.runners.spark.io.EmptyCheckpointMark
-
- get(PCollectionView<T>, BoundedWindow) - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.batch.functions.SparkSideInputReader
-
- get(PCollectionView<T>, BoundedWindow) - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.utils.CachedSideInputReader
-
- get(PCollectionView<T>, BoundedWindow) - Method in class org.apache.beam.runners.spark.util.CachedSideInputReader
-
- get(Long) - Static method in class org.apache.beam.runners.spark.util.GlobalWatermarkHolder
-
- get(PCollectionView<T>, BoundedWindow) - Method in class org.apache.beam.runners.spark.util.SparkSideInputReader
-
- get(int) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamCalcRel.WrappedList
-
- get(Object) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamCalcRel.WrappedMap
-
- get(int) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamCalcRel.WrappedRow
-
- get() - Method in class org.apache.beam.sdk.io.hadoop.SerializableConfiguration
-
- get() - Method in interface org.apache.beam.sdk.options.ValueProvider
-
- get() - Method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
-
- get() - Method in class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
-
- get() - Method in class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
-
- get(Class<?>) - Method in class org.apache.beam.sdk.schemas.AutoValueSchema.AbstractGetterTypeSupplier
-
- get(ObjectT) - Method in interface org.apache.beam.sdk.schemas.FieldValueGetter
-
- get(Class<?>) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema.GetterTypeSupplier
-
- get(Class<?>) - Method in class org.apache.beam.sdk.schemas.JavaBeanSchema.SetterTypeSupplier
-
- get(Class<?>) - Method in class org.apache.beam.sdk.schemas.JavaFieldSchema.JavaFieldTypeSupplier
-
- get(Object) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
-
- get(Class<?>) - Method in interface org.apache.beam.sdk.schemas.utils.FieldValueTypeSupplier
-
Return all the FieldValueTypeInformations.
- get(Class<?>, Schema) - Method in interface org.apache.beam.sdk.schemas.utils.FieldValueTypeSupplier
-
Return all the FieldValueTypeInformations.
- get(K) - Method in interface org.apache.beam.sdk.state.MapState
-
A deferred lookup.
- get(String) - Method in interface org.apache.beam.sdk.state.TimerMap
-
- get() - Method in interface org.apache.beam.sdk.testing.SerializableMatchers.SerializableSupplier
-
- get(TupleTag<V>) - Method in class org.apache.beam.sdk.transforms.CombineFns.CoCombineResult
-
Returns the value represented by the given
TupleTag
.
- get(TupleTag<T>) - Method in interface org.apache.beam.sdk.transforms.DoFn.MultiOutputReceiver
-
- get() - Method in interface org.apache.beam.sdk.transforms.Materializations.IterableView
-
Returns an iterable for all values.
- get() - Method in interface org.apache.beam.sdk.transforms.Materializations.MultimapView
-
Returns an iterable of all keys.
- get(K) - Method in interface org.apache.beam.sdk.transforms.Materializations.MultimapView
-
Returns an iterable of all the values for the specified key.
- get(int) - Method in class org.apache.beam.sdk.values.PCollectionList
-
Returns the
PCollection
at the given index (origin zero).
- get(TupleTag<T>) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
- get(String) - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
- get(int) - Method in class org.apache.beam.sdk.values.TupleTagList
-
Returns the
TupleTag
at the given index (origin zero).
- getAccum() - Method in interface org.apache.beam.sdk.state.CombiningState
-
Read the merged accumulator for this state cell.
- getAccumulatorCoder(CoderRegistry, Coder) - Method in class org.apache.beam.sdk.extensions.sketching.SketchFrequencies.CountMinSketchFn
-
- getAccumulatorCoder(CoderRegistry, Coder) - Method in class org.apache.beam.sdk.extensions.sketching.TDigestQuantiles.TDigestQuantilesFn
-
- getAccumulatorCoder(CoderRegistry, Coder<Row>) - Method in class org.apache.beam.sdk.extensions.sql.impl.transform.agg.CovarianceFn
-
- getAccumulatorCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.extensions.sql.impl.transform.agg.VarianceFn
-
- getAccumulatorCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
-
- getAccumulatorCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
-
- getAccumulatorCoder(CoderRegistry, Coder<Double>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
-
- getAccumulatorCoder(CoderRegistry, Coder<V>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
-
- getAccumulatorCoder(CoderRegistry, Coder<Integer>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
-
- getAccumulatorCoder(CoderRegistry, Coder<Long>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
-
- getAccumulatorCoder(CoderRegistry, Coder<InputT>) - Method in interface org.apache.beam.sdk.transforms.CombineFnBase.GlobalCombineFn
-
Returns the Coder
to use for accumulator AccumT
values, or null if it is not
able to be inferred.
- getAccumulatorCoder(CoderRegistry, Coder<DataT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
-
- getAccumulatorCoder(CoderRegistry, Coder<DataT>) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
-
- getAccumulatorCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
-
- getAccumulatorCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.Top.TopCombineFn
-
- getAdditionalInputs() - Method in class org.apache.beam.runners.dataflow.PrimitiveParDoSingleFactory.ParDoSingle
-
- getAdditionalInputs() - Method in class org.apache.beam.sdk.io.WriteFiles
-
- getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
- getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
-
- getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
-
- getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
-
- getAdditionalInputs() - Method in class org.apache.beam.sdk.transforms.PTransform
-
- getAdditionalOutputTags() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
-
- getAddresses() - Method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.ConnectionConfiguration
-
- getAlgorithm() - Method in enum org.apache.beam.runners.dataflow.options.DataflowPipelineWorkerPoolOptions.AutoscalingAlgorithmType
-
Returns the string representation of this type.
- getAll(TupleTag<V>) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
Returns the values from the table represented by the given TupleTag<V>
as an Iterable<V>
(which may be empty if there are no results).
- getAll(String) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
- getAll() - Method in class org.apache.beam.sdk.values.PCollectionList
-
- getAll() - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
- getAll() - Method in class org.apache.beam.sdk.values.TupleTagList
-
- getAllFields() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
If true, all fields are being accessed.
- getAllIds(String, String, String) - Method in class org.apache.beam.sdk.io.gcp.testing.FakeDatasetService
-
- getAllJobs() - Method in class org.apache.beam.sdk.io.gcp.testing.FakeJobService
-
- getAllowedLateness() - Method in class org.apache.beam.sdk.values.WindowingStrategy
-
- getAllowedTimestampSkew() - Method in class org.apache.beam.sdk.transforms.DoFn
-
- getAllowedTimestampSkew() - Method in class org.apache.beam.sdk.transforms.WithTimestamps
-
- getAllowNonRestoredState() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getAllRows(String, String, String) - Method in class org.apache.beam.sdk.io.gcp.testing.FakeDatasetService
-
- getAllWorkerStatuses(long, TimeUnit) - Method in class org.apache.beam.runners.fnexecution.status.BeamWorkerStatusGrpcService
-
Get all the statuses from all connected SDK harnesses within specified timeout.
- getAnnotatedConstructor(Class) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
-
- getAnnotatedCreateMethod(Class) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
-
- getApexDAG() - Method in class org.apache.beam.runners.apex.ApexRunnerResult
-
Return the DAG executed by the pipeline.
- getApexLauncher() - Method in class org.apache.beam.runners.apex.ApexYarnLauncher.LaunchParams
-
- getApiRootUrl() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineDebugOptions
-
The root URL for the Dataflow API.
- getApiServiceDescriptor() - Method in class org.apache.beam.runners.fnexecution.GrpcFnServer
-
Get an
Endpoints.ApiServiceDescriptor
describing the endpoint this
GrpcFnServer
is bound
to.
- getApplicationName() - Method in interface org.apache.beam.runners.apex.ApexPipelineOptions
-
- getApplicationName() - Method in interface org.apache.beam.runners.gearpump.GearpumpPipelineOptions
-
- getApplicationName() - Method in class org.apache.beam.sdk.io.gcp.testing.BigqueryMatcher.TableAndQuery
-
- getAppliedFn(CoderRegistry, Coder<? extends KV<K, ? extends Iterable<InputT>>>, WindowingStrategy<?, ?>) - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
-
- getAppName() - Method in interface org.apache.beam.sdk.options.ApplicationNameOptions
-
Name of application, for display purposes.
- getApproximateArrivalTimestamp() - Method in class org.apache.beam.sdk.io.kinesis.KinesisRecord
-
- getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
-
- getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
-
- getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
- getArgument() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
-
- getArgument() - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
-
An optional argument to configure the type.
- getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
-
- getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
-
- getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
- getArgumentType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
-
- getArgumentType() - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
-
A schema type representing how to interpret the argument.
- getArgumentTypes(Method) - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns a list of argument types for the given method, which must be a part of the class.
- getArray(String) - Method in class org.apache.beam.sdk.values.Row
-
Get an array value by field name, IllegalStateException
is thrown if schema doesn't
match.
- getArray(int) - Method in class org.apache.beam.sdk.values.Row
-
Get an array value by field index, IllegalStateException
is thrown if schema doesn't
match.
- getArtifact(ArtifactApi.GetArtifactRequest, StreamObserver<ArtifactApi.ArtifactChunk>) - Method in class org.apache.beam.runners.fnexecution.artifact.AbstractArtifactRetrievalService
-
- getArtifactManifestUri(String) - Static method in class org.apache.beam.runners.fnexecution.jobsubmission.PortablePipelineJarUtils
-
- getArtifactPort() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobServerDriver.ServerConfiguration
-
- getArtifactStagingPath() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobServerDriver.ServerConfiguration
-
- getArtifactUri(String, String) - Method in class org.apache.beam.runners.fnexecution.artifact.AbstractArtifactStagingService
-
- getArtifactUri(String, String) - Method in class org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService
-
- getArtifactUri(String, String) - Method in class org.apache.beam.runners.fnexecution.artifact.JavaFilesystemArtifactStagingService
-
- getATN() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
-
- getATN() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
-
- getAttempted() - Method in class org.apache.beam.sdk.metrics.MetricResult
-
Return the value of this metric across all attempts of executing all parts of the pipeline.
- getAttribute(String) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessage
-
Returns the given attribute value.
- getAttributeMap() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessage
-
Returns the full map of attributes.
- getAutoCommit() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- getAutoscalingAlgorithm() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineWorkerPoolOptions
-
[Experimental] The autoscaling algorithm to use for the workerpool.
- getAutoWatermarkInterval() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getAwsCredentialsProvider() - Method in interface org.apache.beam.sdk.io.aws.options.AwsOptions
-
The credential instance that should be used to authenticate against AWS services.
- getAwsCredentialsProvider() - Method in interface org.apache.beam.sdk.io.aws2.options.AwsOptions
-
The credential instance that should be used to authenticate against AWS services.
- getAwsRegion() - Method in interface org.apache.beam.sdk.io.aws.options.AwsOptions
-
AWS region used by the AWS client.
- getAwsServiceEndpoint() - Method in interface org.apache.beam.sdk.io.aws.options.AwsOptions
-
The AWS service endpoint used by the AWS client.
- getBacklogCheckTime() - Method in class org.apache.beam.sdk.io.kafka.TimestampPolicy.PartitionContext
-
The time at which latest offset for the partition was fetched in order to calculate backlog.
- getBagUserStateSpecs() - Method in class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors.ExecutableProcessBundleDescriptor
-
Get a mapping from PTransform id to user state input id to
bag user
states
that are used during execution.
- getBaseAutoValueClass(Class<?>) - Static method in class org.apache.beam.sdk.schemas.utils.AutoValueUtils
-
- getBasePath() - Method in class org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService.StagingSessionToken
-
Access is public for json conversion.
- getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
-
- getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
-
- getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
- getBaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
-
- getBaseType() - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
-
- getBatchDuration() - Method in class org.apache.beam.runners.spark.io.CreateStream
-
- getBatches() - Method in class org.apache.beam.runners.spark.io.CreateStream
-
Get the underlying queue representing the mock stream of micro-batches.
- getBatchIntervalMillis() - Method in interface org.apache.beam.runners.spark.SparkPipelineOptions
-
- getBatchSize() - Method in class org.apache.beam.sdk.transforms.GroupIntoBatches
-
Returns the size of the batch.
- getBeamRelInput(RelNode) - Static method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSqlRelUtils
-
- getBeamSqlTable() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamIOSourceRel
-
- getBeamSqlUdfs() - Method in interface org.apache.beam.sdk.extensions.sql.meta.provider.UdfUdafProvider
-
- getBigtableOptions() - Method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableIO.Read
-
- getBigtableOptions() - Method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableIO.Write
-
- getBoolean(Map<String, Object>, String) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getBoolean(Map<String, Object>, String, Boolean) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getBoolean(String) - Method in class org.apache.beam.sdk.values.Row
-
- getBoolean(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a Boolean
value by field index, ClassCastException
is thrown if schema
doesn't match.
- getBootstrapServers() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaTable
-
- getBoundednessOfRelNode(RelNode) - Static method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamJoinRel
-
This method returns the Boundedness of a RelNode.
- getBroadcastSizeEstimate() - Method in class org.apache.beam.runners.spark.util.SideInputBroadcast
-
- getBroadcastValue(String) - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.helpers.SideInputBroadcast
-
- getBucket() - Method in class org.apache.beam.sdk.extensions.gcp.util.gcsfs.GcsPath
-
Returns the bucket name associated with this GCS path, or an empty string if this is a relative
path component.
- getBufferSize() - Method in class org.apache.beam.sdk.fn.stream.BufferingStreamObserver
-
- getBuilderCreator(Class<?>, Schema, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.AutoValueUtils
-
Try to find an accessible builder class for creating an AutoValue class.
- getBuiltinMethods() - Method in class org.apache.beam.sdk.extensions.sql.impl.udf.BeamBuiltinFunctionProvider
-
- getBundle(OutputReceiverFactory, StateRequestHandler, BundleProgressHandler) - Method in interface org.apache.beam.runners.fnexecution.control.StageBundleFactory
-
Get a new
bundle
for processing the data in an executable stage.
- getBundleSize() - Method in interface org.apache.beam.runners.spark.SparkPipelineOptions
-
- getByte(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.BYTE
value by field name,
IllegalStateException
is thrown if
schema doesn't match.
- getByte(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.BYTE
value by field index,
ClassCastException
is thrown if
schema doesn't match.
- getBytes(Map<String, Object>, String) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getBytes(Map<String, Object>, String, byte[]) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getBytes() - Method in class org.apache.beam.sdk.io.range.ByteKey
-
Returns a newly-allocated
byte[]
representing this
ByteKey
.
- getBytes(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.BYTES
value by field name,
IllegalStateException
is thrown if
schema doesn't match.
- getBytes(int) - Method in class org.apache.beam.sdk.values.Row
-
- getBytesPerOffset() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
-
Returns approximately how many bytes of data correspond to a single offset in this source.
- getCacheToken() - Method in interface org.apache.beam.runners.fnexecution.state.StateRequestHandlers.BagUserStateHandler
-
Returns the currently valid cache token.
- getCacheTokens() - Method in interface org.apache.beam.runners.fnexecution.state.StateRequestHandler
-
Retrieves a list of valid cache tokens.
- getCaseEnumType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
- getCaseType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
-
Returns the enumeration that specified which OneOf field is set.
- getCastSpec(RelDataType) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BeamBigQuerySqlDialect
-
- getCatalog() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- getCause() - Method in class org.apache.beam.runners.jet.FailedRunningPipelineResults
-
- getCause() - Method in class org.apache.beam.sdk.transforms.windowing.InvalidWindows
-
Returns the reason that this
WindowFn
is invalid.
- getChannelFactory() - Method in class org.apache.beam.sdk.io.CompressedSource
-
- getChannelNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
-
- getCheckpointDir() - Method in interface org.apache.beam.runners.spark.SparkCommonPipelineOptions
-
- getCheckpointDurationMillis() - Method in interface org.apache.beam.runners.spark.SparkPipelineOptions
-
- getCheckpointingInterval() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getCheckpointingMode() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getCheckpointMark() - Method in class org.apache.beam.runners.spark.io.MicrobatchSource.Reader
-
- getCheckpointMark() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
-
- getCheckpointMarkCoder() - Method in class org.apache.beam.runners.gearpump.translators.io.ValuesSource
-
- getCheckpointMarkCoder() - Method in class org.apache.beam.runners.spark.io.MicrobatchSource
-
- getCheckpointMarkCoder() - Method in class org.apache.beam.sdk.io.UnboundedSource
-
Returns a
Coder
for encoding and decoding the checkpoints for this source.
- getCheckpointTimeoutMillis() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getChildRels(RelNode) - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.JoinRelOptRuleCall
-
- getClasses() - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns a set of
TypeDescriptor
s, one for each superclass (including this class).
- getClassName() - Method in class org.apache.beam.runners.dataflow.util.CloudObject
-
Gets the name of the Java class that this CloudObject represents.
- getClazz() - Method in class org.apache.beam.sdk.schemas.utils.ReflectUtils.ClassWithSchema
-
- getClient(String) - Static method in class org.apache.beam.sdk.io.gcp.testing.BigqueryClient
-
- getClientConfiguration() - Method in interface org.apache.beam.sdk.io.aws.options.AwsOptions
-
The client configuration instance that should be used to configure AWS service clients.
- getClientContext() - Method in interface org.apache.beam.runners.gearpump.GearpumpPipelineOptions
-
- getClientContext() - Method in class org.apache.beam.runners.gearpump.GearpumpPipelineResult
-
- getClientInfo(String) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- getClientInfo() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- getCloningBehavior() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- getClosingBehavior() - Method in class org.apache.beam.sdk.values.WindowingStrategy
-
- getClosure() - Method in class org.apache.beam.sdk.transforms.Contextful
-
Returns the closure.
- getCloudWatchClient() - Method in interface org.apache.beam.sdk.io.aws.dynamodb.AwsClientsProvider
-
- getCloudWatchClient() - Method in class org.apache.beam.sdk.io.aws.dynamodb.BasicDynamoDBProvider
-
- getCloudWatchClient() - Method in interface org.apache.beam.sdk.io.aws.sns.AwsClientsProvider
-
- getCloudWatchClient() - Method in interface org.apache.beam.sdk.io.kinesis.AWSClientsProvider
-
- getClustering() - Method in class org.apache.beam.sdk.io.gcp.bigquery.TableDestination
-
- getCmd() - Method in class org.apache.beam.runners.apex.ApexYarnLauncher.LaunchParams
-
- getCodec(DestinationT) - Method in class org.apache.beam.sdk.io.DynamicAvroDestinations
-
Return an AVRO codec for a given destination.
- getCodeJarPathname() - Method in interface org.apache.beam.runners.jet.JetPipelineOptions
-
- getCoder() - Method in class org.apache.beam.runners.fnexecution.control.RemoteOutputReceiver
-
- getCoder() - Method in class org.apache.beam.runners.fnexecution.data.RemoteInputDestination
-
- getCoder(String) - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.helpers.SideInputBroadcast
-
- getCoder(Class<T>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
-
Returns the
Coder
to use for values of the given class.
- getCoder(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
-
Returns the
Coder
to use for values of the given type.
- getCoder(TypeDescriptor<OutputT>, TypeDescriptor<InputT>, Coder<InputT>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
-
- getCoder(Class<? extends T>, Class<T>, Map<Type, ? extends Coder<?>>, TypeVariable<?>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
-
- getCoder() - Method in class org.apache.beam.sdk.coders.DelegateCoder
-
Returns the coder used to encode/decode the intermediate values produced/consumed by the coding
functions of this DelegateCoder
.
- getCoder(CoderRegistry) - Method in class org.apache.beam.sdk.io.kafka.ConfluentSchemaRegistryDeserializerProvider
-
- getCoder() - Static method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
-
- getCoder() - Method in class org.apache.beam.sdk.values.PCollection
-
Returns the
Coder
used by this
PCollection
to encode and decode the values
stored in it.
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.AtomicCoder
-
If this is a
Coder
for a parameterized type, returns the list of
Coder
s being
used for each of the parameters in the same order they appear within the parameterized type's
type signature.
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.Coder
-
If this is a
Coder
for a parameterized type, returns the list of
Coder
s being
used for each of the parameters in the same order they appear within the parameterized type's
type signature.
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.CustomCoder
-
If this is a
Coder
for a parameterized type, returns the list of
Coder
s being
used for each of the parameters in the same order they appear within the parameterized type's
type signature.
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.KvCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.MapCoder
-
If this is a
Coder
for a parameterized type, returns the list of
Coder
s being
used for each of the parameters in the same order they appear within the parameterized type's
type signature.
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.NullableCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.ShardedKeyCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.SnappyCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.coders.VarLongCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.io.aws.sns.PublishResultCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResultCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.io.hadoop.WritableCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.io.kafka.KafkaRecordCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.io.kafka.ProducerRecordCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.testing.TestStream.TestStreamCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindow.Coder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
-
- getCoderArguments() - Method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
-
- getCoderInternal() - Method in interface org.apache.beam.sdk.values.PCollectionView
-
- getCoderInternal() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
-
- getCoderProvider() - Static method in class org.apache.beam.sdk.coders.AvroCoder
-
- getCoderProvider() - Static method in class org.apache.beam.sdk.coders.SerializableCoder
-
- getCoderProvider() - Static method in class org.apache.beam.sdk.extensions.protobuf.DynamicProtoCoder
-
- getCoderProvider() - Static method in class org.apache.beam.sdk.extensions.protobuf.ProtoCoder
-
- getCoderProvider() - Static method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableWriteResultCoder
-
- getCoderProvider() - Static method in class org.apache.beam.sdk.io.hadoop.WritableCoder
-
- getCoderProviders() - Method in interface org.apache.beam.sdk.coders.CoderProviderRegistrar
-
- getCoderProviders() - Method in class org.apache.beam.sdk.coders.DefaultCoder.DefaultCoderProviderRegistrar
-
- getCoderProviders() - Method in class org.apache.beam.sdk.coders.SerializableCoder.SerializableCoderProviderRegistrar
-
- getCoderProviders() - Method in class org.apache.beam.sdk.extensions.protobuf.ProtobufCoderProviderRegistrar
-
- getCoderProviders() - Method in class org.apache.beam.sdk.io.amqp.AmqpMessageCoderProviderRegistrar
-
- getCoderProviders() - Method in class org.apache.beam.sdk.io.aws.dynamodb.AttributeValueCoderProviderRegistrar
-
- getCoderProviders() - Method in class org.apache.beam.sdk.io.aws.sns.SnsCoderProviderRegistrar
-
- getCoderProviders() - Method in class org.apache.beam.sdk.io.aws2.sns.SnsCoderProviderRegistrar
-
- getCoderProviders() - Method in class org.apache.beam.sdk.io.aws2.sqs.MessageCoderRegistrar
-
- getCoderProviders() - Method in class org.apache.beam.sdk.io.aws2.sqs.SendMessageRequestCoderRegistrar
-
- getCoderProviders() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryCoderProviderRegistrar
-
- getCoderProviders() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubCoderProviderRegistrar
-
- getCoderProviders() - Method in class org.apache.beam.sdk.io.hadoop.WritableCoder.WritableCoderProviderRegistrar
-
- getCoderProviders() - Method in class org.apache.beam.sdk.io.hbase.HBaseCoderProviderRegistrar
-
- getCoderRegistry() - Method in class org.apache.beam.sdk.Pipeline
-
- getCoGbkResultSchema() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
- getCollations() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamTableStatistics
-
- getCollection() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple.TaggedKeyedPCollection
-
Returns the underlying PCollection of this TaggedKeyedPCollection.
- getCollectionElementType() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
- getColumns() - Method in class org.apache.beam.sdk.io.gcp.spanner.ReadOperation
-
- getCombineFn() - Method in interface org.apache.beam.runners.spark.aggregators.NamedAggregators.State
-
- getCombineFn() - Method in interface org.apache.beam.runners.spark.structuredstreaming.aggregators.NamedAggregators.State
-
- getCombineFn() - Method in class org.apache.beam.sdk.extensions.sql.impl.UdafImpl
-
- getCombineFn() - Method in class org.apache.beam.sdk.transforms.Combine.GloballyAsSingletonView
-
- getComment() - Method in class org.apache.beam.sdk.extensions.sql.meta.Table
-
- getCommitDeadline() - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerConfig
-
- getCommitted() - Method in class org.apache.beam.sdk.metrics.MetricResult
-
Return the value of this metric across all successfully completed parts of the pipeline.
- getCommittedOrNull() - Method in class org.apache.beam.sdk.metrics.MetricResult
-
Return the value of this metric across all attempts of executing all parts of the pipeline.
- getCompletedTimers() - Method in class org.apache.beam.runners.direct.WatermarkManager.TimerUpdate
-
- getComponents() - Method in class org.apache.beam.sdk.coders.AtomicCoder
-
Returns the list of
Coders
that are components of this
Coder
.
- getComponents() - Method in class org.apache.beam.sdk.coders.StructuredCoder
-
Returns the list of
Coders
that are components of this
Coder
.
- getComponents() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Path
-
Hierarchy list of component paths making up the full path, starting with the top-level child
component path.
- getComponents() - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
-
- getComponents() - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
-
- getComponents() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
-
- getComponentType() - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns the component type if this type is an array type, otherwise returns null
.
- getCompression() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
-
- getCompression() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
-
- getComputeNumShards() - Method in class org.apache.beam.sdk.io.WriteFiles
-
- getConfigFile() - Method in interface org.apache.beam.runners.apex.ApexPipelineOptions
-
- getConfigPropertiesAsMap(HiveConf) - Static method in class org.apache.beam.sdk.io.hcatalog.test.HCatalogIOTestUtils
-
Returns config params for the test datastore as a Map.
- getConfiguration() - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.HadoopInputFormatBoundedSource
-
- getConfiguration() - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.Read
-
- getConfiguration() - Method in class org.apache.beam.sdk.io.hbase.HBaseIO.Read
-
- getConfiguration() - Method in class org.apache.beam.sdk.io.hbase.HBaseIO.Write
-
- getConnectStringPrefix() - Method in class org.apache.beam.sdk.extensions.sql.impl.JdbcDriver
-
- getConnectTimeout() - Method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.ConnectionConfiguration
-
- getConstructorCreator(Class<?>, Schema, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.AutoValueUtils
-
Try to find an accessible constructor for creating an AutoValue class.
- getConstructorCreator(Class, Constructor, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
-
- getConstructorCreator(Class, Constructor, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
-
- getContainerVersion() - Method in class org.apache.beam.runners.dataflow.DataflowRunnerInfo
-
Provides the container version that will be used for constructing harness image paths.
- getContent() - Method in class org.apache.beam.sdk.io.tika.ParseResult
-
Returns the extracted text.
- getContext() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlEnv
-
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterAll
-
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterEach
-
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterFirst
-
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
-
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
-
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
-
- getContinuationTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
-
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
-
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
-
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
-
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.Never.NeverTrigger
-
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
-
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
-
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.ReshuffleTrigger
-
Deprecated.
- getContinuationTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
-
Return a trigger to use after a
GroupByKey
to preserve the intention of this trigger.
- getContinuationTrigger(List<Trigger>) - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
-
- getContinuationTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.Trigger.OnceTrigger
-
- getConversionOptions(JSONObject) - Static method in class org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTableProvider
-
- getConvertedSchemaInformation(Schema, TypeDescriptor<T>, SchemaRegistry) - Static method in class org.apache.beam.sdk.schemas.utils.ConvertHelpers
-
Get the coder used for converting from an inputSchema to a given type.
- getConvertedType() - Method in class org.apache.beam.sdk.coders.AvroCoder.JodaTimestampConversion
-
- getConvertPrimitive(Schema.FieldType, TypeDescriptor<?>, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.ConvertHelpers
-
Returns a function to convert a Row into a primitive type.
- getCount() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSortRel
-
- getCount() - Method in class org.apache.beam.sdk.metrics.DistributionResult
-
- getCount() - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
-
- getCounter(MetricName) - Method in class org.apache.beam.runners.jet.metrics.JetMetricsContainer
-
- getCounter(MetricName) - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
-
Return the
Counter
that should be used for implementing the given
metricName
in
this container.
- getCounters(MetricFilter) - Method in class org.apache.beam.runners.spark.metrics.WithMetricsSupport
-
- getCounters(MetricFilter) - Method in class org.apache.beam.runners.spark.structuredstreaming.metrics.WithMetricsSupport
-
- getCounters() - Method in class org.apache.beam.sdk.metrics.MetricQueryResults
-
Return the metric results for the counters that matched the filter.
- getCountryOfResidence() - Method in class org.apache.beam.sdk.extensions.sql.example.model.Customer
-
- getCpu() - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamCostModel
-
- getCpuRate() - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamCostModel
-
- getCreateFromSnapshot() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineOptions
-
If set, the snapshot from which the job should be created.
- getCreator(Class<T>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
-
Get an object creator for an AVRO-generated SpecificRecord.
- getCredential() - Method in interface org.apache.beam.sdk.extensions.gcp.auth.CredentialFactory
-
- getCredential() - Method in class org.apache.beam.sdk.extensions.gcp.auth.GcpCredentialFactory
-
Returns a default GCP
Credentials
or null when it fails.
- getCredential() - Method in class org.apache.beam.sdk.extensions.gcp.auth.NoopCredentialFactory
-
- getCredentialFactoryClass() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcpOptions
-
The class of the credential factory that should be created and used to create credentials.
- getCsvFormat() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.text.TextTableProvider.CsvToRow
-
- getCurrent() - Method in class org.apache.beam.runners.spark.io.MicrobatchSource.Reader
-
- getCurrent() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
-
- getCurrent() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
-
Gets the current record from the delegate reader.
- getCurrent() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageStreamSource.BigQueryStorageStreamReader
-
- getCurrent() - Method in class org.apache.beam.sdk.io.Source.Reader
-
- getCurrentBlock() - Method in class org.apache.beam.sdk.io.AvroSource.AvroReader
-
- getCurrentBlock() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
-
- getCurrentBlockOffset() - Method in class org.apache.beam.sdk.io.AvroSource.AvroReader
-
- getCurrentBlockOffset() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
-
Returns the largest offset such that starting to read from that offset includes the current
block.
- getCurrentBlockSize() - Method in class org.apache.beam.sdk.io.AvroSource.AvroReader
-
- getCurrentBlockSize() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
-
Returns the size of the current block in bytes as it is represented in the underlying file,
if possible.
- getCurrentContainer() - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
-
- getCurrentDirectory() - Method in class org.apache.beam.sdk.extensions.gcp.storage.GcsResourceId
-
- getCurrentDirectory() - Method in interface org.apache.beam.sdk.io.fs.ResourceId
-
Returns the ResourceId
that represents the current directory of this ResourceId
.
- getCurrentOffset() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
-
- getCurrentOffset() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
-
- getCurrentOffset() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
-
- getCurrentParent() - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.TranslationContext
-
Gets the parent composite transform to the current transform, if one exists.
- getCurrentRecord() - Method in class org.apache.beam.sdk.io.BlockBasedSource.Block
-
Returns the current record.
- getCurrentRecordId() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
-
Returns a unique identifier for the current record.
- getCurrentSchemaPlus() - Method in class org.apache.beam.sdk.extensions.sql.impl.JdbcConnection
-
Calcite-created SchemaPlus
wrapper for the current schema.
- getCurrentSource() - Method in class org.apache.beam.runners.spark.io.MicrobatchSource.Reader
-
- getCurrentSource() - Method in class org.apache.beam.sdk.io.AvroSource.AvroReader
-
- getCurrentSource() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
-
Returns a Source
describing the same input that this Reader
currently reads
(including items already read).
- getCurrentSource() - Method in class org.apache.beam.sdk.io.FileBasedSource.FileBasedReader
-
- getCurrentSource() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageStreamSource.BigQueryStorageStreamReader
-
- getCurrentSource() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
-
- getCurrentSource() - Method in class org.apache.beam.sdk.io.Source.Reader
-
Returns a Source
describing the same input that this Reader
currently reads
(including items already read).
- getCurrentSource() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
-
- getCurrentTimestamp() - Method in class org.apache.beam.runners.spark.io.MicrobatchSource.Reader
-
- getCurrentTimestamp() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
-
By default, returns the minimum possible timestamp.
- getCurrentTimestamp() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
-
- getCurrentTimestamp() - Method in class org.apache.beam.sdk.io.Source.Reader
-
Returns the timestamp associated with the current data item.
- getCurrentTransform() - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.TranslationContext
-
- getCurrentTransform() - Method in class org.apache.beam.runners.gearpump.translators.TranslationContext
-
- getCurrentTransform() - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.TranslationContext
-
- getCustomerId() - Method in class org.apache.beam.sdk.extensions.sql.example.model.Order
-
- getCustomError(HttpRequestWrapper, HttpResponseWrapper) - Method in class org.apache.beam.sdk.extensions.gcp.util.CustomHttpErrors
-
- getCustomError() - Method in class org.apache.beam.sdk.extensions.gcp.util.CustomHttpErrors.MatcherAndError
-
- getDanglingDataSets() - Method in class org.apache.beam.runners.flink.FlinkBatchPortablePipelineTranslator.BatchTranslationContext
-
- getData() - Method in class org.apache.beam.sdk.io.kinesis.KinesisRecord
-
- getDataAsBytes() - Method in class org.apache.beam.sdk.io.kinesis.KinesisRecord
-
- getDatabaseId() - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerConfig
-
- getDataCatalogEndpoint() - Method in interface org.apache.beam.sdk.extensions.sql.meta.provider.datacatalog.DataCatalogPipelineOptions
-
DataCatalog endpoint.
- getDataCoder() - Method in class org.apache.beam.runners.dataflow.DataflowRunner.StreamingPCollectionViewWriterFn
-
- getDataflowClient() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineDebugOptions
-
An instance of the Dataflow client.
- getDataflowEndpoint() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineDebugOptions
-
Dataflow endpoint to use.
- getDataflowJobFile() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineDebugOptions
-
The path to write the translated Dataflow job specification out to at job submission time.
- getDataflowKmsKey() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcpOptions
-
GCP
Cloud KMS key for Dataflow pipelines and
buckets created by GcpTempLocationFactory.
- getDataflowOptions() - Method in class org.apache.beam.runners.dataflow.DataflowPipelineJob
-
- getDataflowRunnerInfo() - Static method in class org.apache.beam.runners.dataflow.DataflowRunnerInfo
-
- getDataflowWorkerJar() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineOptions
-
- getDataset(PValue) - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.TranslationContext
-
- getDataset(String, String) - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryServices.DatasetService
-
Gets the specified
Dataset
resource by dataset ID.
- getDataset(String, String) - Method in class org.apache.beam.sdk.io.gcp.testing.FakeDatasetService
-
- getDataSetOrThrow(String) - Method in class org.apache.beam.runners.flink.FlinkBatchPortablePipelineTranslator.BatchTranslationContext
-
- getDatasetService(BigQueryOptions) - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryServices
-
- getDatasetService(BigQueryOptions) - Method in class org.apache.beam.sdk.io.gcp.testing.FakeBigQueryServices
-
- getDataStreamOrThrow(String) - Method in class org.apache.beam.runners.flink.FlinkStreamingPortablePipelineTranslator.StreamingTranslationContext
-
- getDateTime(String) - Method in class org.apache.beam.sdk.values.Row
-
- getDateTime(int) - Method in class org.apache.beam.sdk.values.Row
-
- getDayOfMonth() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
-
- getDayOfMonth() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
-
- getDebuggee() - Method in interface org.apache.beam.runners.dataflow.options.CloudDebuggerOptions
-
The Cloud Debugger debuggee to associate with.
- getDecimal(String) - Method in class org.apache.beam.sdk.values.Row
-
- getDecimal(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a BigDecimal
value by field index, ClassCastException
is thrown if schema
doesn't match.
- getDef() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner.NonCumulativeCostImpl
-
- getDef() - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.RelMdNodeStats
-
- getDefault() - Static method in class org.apache.beam.runners.fnexecution.logging.Slf4jLogWriter
-
- getDefaultCoder(TypeDescriptor<?>, CoderRegistry) - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.Read
-
Returns the default coder for a given type descriptor.
- getDefaultDestination() - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
-
Returns the default destination.
- getDefaultEnvironmentConfig() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
-
- getDefaultEnvironmentType() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
-
- getDefaultJobName() - Static method in class org.apache.beam.runners.fnexecution.jobsubmission.PortablePipelineJarUtils
-
- getDefaultOutputCoder() - Method in class org.apache.beam.runners.gearpump.translators.io.ValuesSource
-
- getDefaultOutputCoder(CoderRegistry, Coder) - Method in class org.apache.beam.sdk.extensions.sketching.TDigestQuantiles.TDigestQuantilesFn
-
- getDefaultOutputCoder() - Method in class org.apache.beam.sdk.io.Source
-
- getDefaultOutputCoder(CoderRegistry, Coder<Double>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
-
- getDefaultOutputCoder(CoderRegistry, Coder<V>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
-
- getDefaultOutputCoder(CoderRegistry, Coder<Integer>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
-
- getDefaultOutputCoder(CoderRegistry, Coder<Long>) - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
-
- getDefaultOutputCoder(CoderRegistry, Coder<InputT>) - Method in interface org.apache.beam.sdk.transforms.CombineFnBase.GlobalCombineFn
-
Returns the Coder
to use by default for output OutputT
values, or null if it
is not able to be inferred.
- getDefaultOutputCoder() - Method in class org.apache.beam.sdk.transforms.PTransform
-
- getDefaultOutputCoder(InputT) - Method in class org.apache.beam.sdk.transforms.PTransform
-
- getDefaultOutputCoder(InputT, PCollection<T>) - Method in class org.apache.beam.sdk.transforms.PTransform
-
- getDefaultOutputCoder(CoderRegistry, Coder<T>) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
-
- getDefaultSdkHarnessLogLevel() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
-
This option controls the default log level of all loggers without a log level override.
- getDefaultValue() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
-
Returns the default value that was specified.
- getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
-
- getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.InvalidWindows
-
- getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn
-
- getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
-
- getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
-
Return a
WindowMappingFn
that returns the earliest window that contains the end of the
main-input window.
- getDefaultWindowMappingFn() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
Returns the default
WindowMappingFn
to use to map main input windows to side input
windows.
- getDefaultWorkerLogLevel() - Method in interface org.apache.beam.runners.dataflow.options.DataflowWorkerLoggingOptions
-
Deprecated.
This option controls the default log level of all loggers without a log level override.
- getDelay() - Method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform.Delay
-
- getDeletedTimers() - Method in class org.apache.beam.runners.direct.WatermarkManager.TimerUpdate
-
- getDelimiters() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
-
- getDescription() - Method in class org.apache.beam.sdk.schemas.Schema.Field
-
Returns the field's description.
- getDescriptor(String) - Method in class org.apache.beam.sdk.extensions.protobuf.ProtoDomain
-
- getDeserializer(Map<String, ?>, boolean) - Method in class org.apache.beam.sdk.io.kafka.ConfluentSchemaRegistryDeserializerProvider
-
- getDestination(UserT) - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
-
Returns an object that represents at a high level the destination being written to.
- getDestination() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
-
- getDestination() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
-
Return the user destination object for this writer.
- getDestination(ValueInSingleWindow<T>) - Method in class org.apache.beam.sdk.io.gcp.bigquery.DynamicDestinations
-
Returns an object that represents at a high level which table is being written to.
- getDestinationCoder() - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
-
Returns the coder for DestinationT
.
- getDestinationCoder() - Method in class org.apache.beam.sdk.io.gcp.bigquery.DynamicDestinations
-
Returns the coder for DestinationT
.
- getDestinationFile(boolean, FileBasedSink.DynamicDestinations<?, DestinationT, ?>, int, FileBasedSink.OutputFileHints) - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
-
- getDictionary(Map<String, Object>, String) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getDictionary(Map<String, Object>, String, Map<String, Object>) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getDirectoryTreatment() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
-
- getDisableMetrics() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getDiskSizeGb() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineWorkerPoolOptions
-
Remote worker disk size, in gigabytes, or 0 to use the default size.
- getDistribution(MetricName) - Method in class org.apache.beam.runners.jet.metrics.JetMetricsContainer
-
- getDistribution() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamTableStatistics
-
- getDistribution(MetricName) - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
-
Return the
Distribution
that should be used for implementing the given
metricName
in this container.
- getDistributions() - Method in class org.apache.beam.sdk.metrics.MetricQueryResults
-
Return the metric results for the distributions that matched the filter.
- getDocumentCount() - Method in class org.apache.beam.sdk.io.mongodb.MongoDbIO.Read
-
- getDoFnRunner(PipelineOptions, DoFn<InputT, OutputT>, SideInputReader, AbstractParDoP.JetOutputManager, TupleTag<OutputT>, List<TupleTag<?>>, Coder<InputT>, Map<TupleTag<?>, Coder<?>>, WindowingStrategy<?, ?>, DoFnSchemaInformation, Map<String, PCollectionView<?>>) - Method in class org.apache.beam.runners.jet.processors.ParDoP
-
- getDoFnRunner(PipelineOptions, DoFn<KV<?, ?>, OutputT>, SideInputReader, AbstractParDoP.JetOutputManager, TupleTag<OutputT>, List<TupleTag<?>>, Coder<KV<?, ?>>, Map<TupleTag<?>, Coder<?>>, WindowingStrategy<?, ?>, DoFnSchemaInformation, Map<String, PCollectionView<?>>) - Method in class org.apache.beam.runners.jet.processors.StatefulParDoP
-
- getDoFnSchemaInformation(DoFn<?, ?>, PCollection<?>) - Static method in class org.apache.beam.sdk.transforms.ParDo
-
Extract information on how the DoFn uses schemas.
- getDouble(String) - Method in class org.apache.beam.sdk.values.Row
-
- getDouble(int) - Method in class org.apache.beam.sdk.values.Row
-
- getDumpHeapOnOOM() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineDebugOptions
-
If true, save a heap dump before killing a thread or process which is GC thrashing
or out of memory.
- getDynamicDestinations() - Method in class org.apache.beam.sdk.io.FileBasedSink
-
- getDynamoDbClient() - Method in class org.apache.beam.sdk.io.aws2.dynamodb.BasicDynamoDbClientProvider
-
- getDynamoDbClient() - Method in interface org.apache.beam.sdk.io.aws2.dynamodb.DynamoDbClientProvider
-
- getEarlyTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
-
- getElemCoder() - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
-
- getElement() - Method in class org.apache.beam.sdk.io.gcp.bigquery.AvroWriteRequest
-
- getElementCoders() - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
-
- getElementConverters() - Method in class org.apache.beam.sdk.transforms.DoFnSchemaInformation
-
The schema of the @Element parameter.
- getElementCount() - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
-
The number of elements after which this trigger may fire.
- getElements() - Method in class org.apache.beam.sdk.testing.TestStream.ElementEvent
-
- getElements() - Method in class org.apache.beam.sdk.transforms.Create.Values
-
- getElementType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
If the field is a container type, returns the element type.
- getEmptyMatchTreatment() - Method in class org.apache.beam.sdk.io.FileBasedSource
-
- getEmptyMatchTreatment() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
-
- getEmptyTraitSet() - Method in class org.apache.beam.sdk.extensions.sql.zetasql.ZetaSQLPlannerImpl
-
- getEnableCloudDebugger() - Method in interface org.apache.beam.runners.dataflow.options.CloudDebuggerOptions
-
Whether to enable the Cloud Debugger snapshot agent for the current job.
- getEnableSparkMetricSinks() - Method in interface org.apache.beam.runners.spark.SparkCommonPipelineOptions
-
- getEncodedElementByteSize(RandomAccessData) - Method in class org.apache.beam.runners.dataflow.util.RandomAccessData.RandomAccessDataCoder
-
- getEncodedElementByteSize(BigDecimal) - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Integer) - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Long) - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Short) - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(BigInteger) - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Boolean) - Method in class org.apache.beam.sdk.coders.BooleanCoder
-
- getEncodedElementByteSize(byte[]) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
-
- getEncodedElementByteSize(Byte) - Method in class org.apache.beam.sdk.coders.ByteCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(T) - Method in class org.apache.beam.sdk.coders.Coder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Double) - Method in class org.apache.beam.sdk.coders.DoubleCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Float) - Method in class org.apache.beam.sdk.coders.FloatCoder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Instant) - Method in class org.apache.beam.sdk.coders.InstantCoder
-
- getEncodedElementByteSize(T) - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
-
Overridden to short-circuit the default StructuredCoder
behavior of encoding and
counting the bytes.
- getEncodedElementByteSize(T) - Method in class org.apache.beam.sdk.coders.NullableCoder
-
Overridden to short-circuit the default StructuredCoder
behavior of encoding and
counting the bytes.
- getEncodedElementByteSize(String) - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
-
Returns the size in bytes of the encoded value using this coder.
- getEncodedElementByteSize(Integer) - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
-
- getEncodedElementByteSize(Integer) - Method in class org.apache.beam.sdk.coders.VarIntCoder
-
- getEncodedElementByteSize(Long) - Method in class org.apache.beam.sdk.coders.VarLongCoder
-
- getEncodedElementByteSize(Void) - Method in class org.apache.beam.sdk.coders.VoidCoder
-
- getEncodedElementByteSize(ByteString) - Method in class org.apache.beam.sdk.extensions.protobuf.ByteStringCoder
-
- getEncodedElementByteSize(HyperLogLogPlus) - Method in class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct.HyperLogLogPlusCoder
-
- getEncodedElementByteSize(EncodedBoundedWindow) - Method in class org.apache.beam.sdk.fn.windowing.EncodedBoundedWindow.Coder
-
- getEncodedElementByteSize(BigQueryInsertError) - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryInsertErrorCoder
-
- getEncodedElementByteSize(TableRow) - Method in class org.apache.beam.sdk.io.gcp.bigquery.TableRowJsonCoder
-
- getEncodedElementByteSize(OffsetRange) - Method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.AvroCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.ByteCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.Coder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.CollectionCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.DelegateCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.DoubleCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.DurationCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.FloatCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.InstantCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.IterableCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.KvCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.ListCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.MapCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.NullableCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.SerializableCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.SetCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.StringDelegateCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.StringUtf8Coder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.TextualIntegerCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.VarIntCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.VarLongCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.coders.VoidCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.extensions.protobuf.ByteStringCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryInsertErrorCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.io.gcp.bigquery.TableRowJsonCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.io.xml.JAXBCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
-
- getEncodedTypeDescriptor() - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
-
- getEncodedWindow() - Method in class org.apache.beam.sdk.fn.windowing.EncodedBoundedWindow
-
- getEncodingPositions() - Method in class org.apache.beam.sdk.schemas.Schema
-
Gets the encoding positions for this schema.
- getEndKey() - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
-
- getEndOffset() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
-
Returns the specified ending offset of the source.
- getEndpoint() - Method in interface org.apache.beam.sdk.io.aws2.options.AwsOptions
-
The AWS service endpoint used by the AWS client.
- getEnv() - Method in class org.apache.beam.runners.apex.ApexYarnLauncher.LaunchParams
-
- getEnvironment() - Method in class org.apache.beam.runners.fnexecution.environment.ProcessEnvironment
-
- getEnvironment() - Method in interface org.apache.beam.runners.fnexecution.environment.RemoteEnvironment
-
Return the environment that the remote handles.
- getEnvironment() - Method in class org.apache.beam.runners.fnexecution.environment.RemoteEnvironment.SimpleRemoteEnvironment
-
- getEnvironment() - Method in class org.apache.beam.runners.fnexecution.environment.StaticRemoteEnvironment
-
- getEnvironmentCacheMillis() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
-
- getEnvironmentExpirationMillis() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
-
- getEquivalentFieldType(TableSchema.ColumnType) - Static method in class org.apache.beam.sdk.io.clickhouse.TableSchema
-
Returns Beam equivalent of ClickHouse column type.
- getEquivalentSchema(TableSchema) - Static method in class org.apache.beam.sdk.io.clickhouse.TableSchema
-
Returns Beam equivalent of ClickHouse schema.
- getError() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryInsertError
-
- getError() - Method in class org.apache.beam.sdk.io.tika.ParseResult
-
Returns the parse error, if the file was parsed unsuccessfully.
- getErrorAsString() - Method in class org.apache.beam.sdk.io.tika.ParseResult
-
- getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.BoundedSource
-
An estimate of the total size (in bytes) of the data that would be read from this source.
- getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.BoundedElasticsearchSource
-
- getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSource
-
- getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageQuerySource
-
- getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageStreamSource
-
- getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageTableSource
-
- getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.HadoopInputFormatBoundedSource
-
- getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.mongodb.MongoDbGridFSIO.Read.BoundedGridFSSource
-
- getEstimatedSizeBytes(PipelineOptions) - Method in class org.apache.beam.sdk.io.OffsetBasedSource
-
- getEvents() - Method in class org.apache.beam.sdk.testing.TestStream
-
- getEx() - Method in class org.apache.beam.runners.jet.processors.FlattenP.Supplier
-
- getExecutable() - Method in class org.apache.beam.runners.direct.WatermarkManager.FiredTimers
-
- getExecutables() - Method in interface org.apache.beam.runners.direct.ExecutableGraph
-
- getExecutionEnvironment() - Method in class org.apache.beam.runners.flink.FlinkBatchPortablePipelineTranslator.BatchTranslationContext
-
- getExecutionEnvironment() - Method in class org.apache.beam.runners.flink.FlinkStreamingPortablePipelineTranslator.StreamingTranslationContext
-
- getExecutionModeForBatch() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getExecutionRetryDelay() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getExecutorService() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcsOptions
-
The ExecutorService instance to use to create threads, can be overridden to specify an
ExecutorService that is compatible with the user's environment.
- getExpansionPort() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobServerDriver.ServerConfiguration
-
- getExpectedAssertions() - Method in interface org.apache.beam.runners.spark.TestSparkPipelineOptions
-
- getExpectedRecords(int) - Static method in class org.apache.beam.sdk.io.hcatalog.test.HCatalogIOTestUtils
-
Returns a list of strings containing 'expected' test data for verification.
- getExpectedRecordsAsKV(int) - Static method in class org.apache.beam.sdk.io.hcatalog.test.HCatalogIOTestUtils
-
Returns a list of KV<String, Integer> containing 'expected' test data for verification.
- getExperiments() - Method in interface org.apache.beam.sdk.options.ExperimentalOptions
-
- getExperimentValue(PipelineOptions, String) - Static method in interface org.apache.beam.sdk.options.ExperimentalOptions
-
Return the value for the specified experiment or null if not present.
- getExplicitHashKey(byte[]) - Method in interface org.apache.beam.sdk.io.kinesis.KinesisPartitioner
-
- getExpression(SchemaPlus, String) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteSchema
-
- getExtendedSequenceNumber() - Method in class org.apache.beam.sdk.io.kinesis.KinesisRecord
-
- getExtensionHosts() - Method in class org.apache.beam.sdk.extensions.protobuf.ProtoCoder
-
- getExtensionRegistry() - Method in class org.apache.beam.sdk.extensions.protobuf.ProtoCoder
-
- getExternalSorterType() - Method in class org.apache.beam.sdk.extensions.sorter.BufferedExternalSorter.Options
-
Returns the external sorter type.
- getFactory() - Method in class org.apache.beam.sdk.schemas.utils.AvroUtils.AvroConvertValueForGetter
-
- getFactory() - Method in class org.apache.beam.sdk.schemas.utils.AvroUtils.AvroConvertValueForSetter
-
- getFactory() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForGetter
-
- getFactory() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.ConvertValueForSetter
-
- getFailedInserts() - Method in class org.apache.beam.sdk.io.gcp.bigquery.WriteResult
-
- getFailedInsertsWithErr() - Method in class org.apache.beam.sdk.io.gcp.bigquery.WriteResult
-
- getFailedMutations() - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerWriteResult
-
- getFailOnCheckpointingErrors() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getFanout() - Method in class org.apache.beam.sdk.transforms.Combine.GloballyAsSingletonView
-
- getField() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
- getField(int) - Method in class org.apache.beam.sdk.schemas.Schema
-
Return a field by index.
- getField(String) - Method in class org.apache.beam.sdk.schemas.Schema
-
- getFieldCount() - Method in class org.apache.beam.sdk.schemas.Schema
-
Return the count of fields.
- getFieldCount() - Method in class org.apache.beam.sdk.values.Row
-
Return the size of data fields.
- getFieldCount() - Method in class org.apache.beam.sdk.values.RowWithGetters
-
- getFieldCount() - Method in class org.apache.beam.sdk.values.RowWithStorage
-
- getFieldId() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
-
- getFieldInsertionOrder() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
- getFieldName() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
-
- getFieldNames() - Method in class org.apache.beam.sdk.schemas.Schema
-
Return the list of all field names.
- getFieldOptionById(int) - Method in class org.apache.beam.sdk.extensions.protobuf.ProtoDomain
-
- getFieldRename() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
-
- getFields() - Method in class org.apache.beam.sdk.schemas.Schema
-
- getFields(Class<?>) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
-
- getFieldsAccessed() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
- getFieldType() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
-
Return the type of this union field.
- getFieldTypes(Class<T>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
-
Get field types for an AVRO-generated SpecificRecord or a POJO.
- getFieldTypes(Class<?>, Schema, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
-
- getFieldTypes(Class<?>, Schema, FieldValueTypeSupplier) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
-
- getFileDescriptor(String) - Method in class org.apache.beam.sdk.extensions.protobuf.ProtoDomain
-
- getFileLocation() - Method in class org.apache.beam.sdk.io.tika.ParseResult
-
Returns the absolute path to the input file.
- getFilename() - Method in class org.apache.beam.sdk.extensions.gcp.storage.GcsResourceId
-
- getFileName() - Method in class org.apache.beam.sdk.extensions.gcp.util.gcsfs.GcsPath
-
- getFilename(BoundedWindow, PaneInfo, int, int, Compression) - Method in interface org.apache.beam.sdk.io.FileIO.Write.FileNaming
-
Generates the filename.
- getFilename() - Method in interface org.apache.beam.sdk.io.fs.ResourceId
-
Returns the name of the file or directory denoted by this ResourceId
.
- getFilenamePolicy(DestinationT) - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
-
- getFileOrPatternSpec() - Method in class org.apache.beam.sdk.io.FileBasedSource
-
- getFileOrPatternSpecProvider() - Method in class org.apache.beam.sdk.io.FileBasedSource
-
- getFilePattern() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.text.TextTable
-
- getFilePattern() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
-
- getFilesToStage() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineWorkerPoolOptions
-
List of local files to make available to workers.
- getFilesToStage() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
List of local files to make available to workers.
- getFilesToStage() - Method in interface org.apache.beam.runners.spark.SparkCommonPipelineOptions
-
List of local files to make available to workers.
- getFilesToStage() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
-
List of local files to make available to workers.
- getFileSystem() - Method in class org.apache.beam.sdk.extensions.gcp.util.gcsfs.GcsPath
-
- getFlatJsonRows(Schema) - Method in class org.apache.beam.sdk.io.gcp.bigquery.TestBigQuery
-
Loads rows from BigQuery into
Rows
with given
Schema
.
- getFlexRSGoal() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineOptions
-
This option controls Flexible Resource Scheduling mode.
- getFlinkMaster() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
The url of the Flink JobManager on which to execute pipelines.
- getFloat(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.FLOAT
value by field name,
IllegalStateException
is thrown if
schema doesn't match.
- getFloat(int) - Method in class org.apache.beam.sdk.values.Row
-
- getFn() - Method in class org.apache.beam.runners.dataflow.PrimitiveParDoSingleFactory.ParDoSingle
-
- getFn() - Method in class org.apache.beam.runners.flink.metrics.DoFnRunnerWithMetricsUpdate
-
- getFn() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
- getFn() - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
-
- getFn() - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
-
- getFn() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
-
- getFn() - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
-
- getFnApiEnvironmentMajorVersion() - Method in class org.apache.beam.runners.dataflow.DataflowRunnerInfo
-
Provides the FnAPI environment's major version number.
- getFractionConsumed() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
-
- getFractionConsumed() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
-
Returns a value in [0, 1] representing approximately what fraction of the
current source
this reader has read so far, or
null
if such an
estimate is not available.
- getFractionConsumed() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageStreamSource.BigQueryStorageStreamReader
-
- getFractionConsumed() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
-
- getFractionConsumed() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
-
- getFractionConsumed() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
-
- getFractionConsumed() - Method in interface org.apache.beam.sdk.io.range.RangeTracker
-
- getFractionOfBlockConsumed() - Method in class org.apache.beam.sdk.io.BlockBasedSource.Block
-
Returns the fraction of the block already consumed, if possible, as a value in [0,
1]
.
- getFrom() - Method in class org.apache.beam.sdk.io.range.OffsetRange
-
- getFromRowFunction() - Method in class org.apache.beam.sdk.extensions.protobuf.ProtoDynamicMessageSchema
-
- getFromRowFunction() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
-
Returns the toRow conversion function.
- getFromRowFunction(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Retrieve the function that converts a
Row
object to the specified type.
- getFromRowFunction(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Retrieve the function that converts a
Row
object to the specified type.
- getFromRowFunction(Class<T>) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
-
- getFromRowFunction() - Method in class org.apache.beam.sdk.values.PCollection
-
Returns the attached schema's fromRowFunction.
- getFullName(PTransform<?, ?>) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.TranslationContext
-
Returns the full name of the currently being translated transform.
- getFunctionNames() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteSchema
-
- getFunctions(String) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteSchema
-
- getGapDuration() - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
-
- getGauge(MetricName) - Method in class org.apache.beam.runners.jet.metrics.JetMetricsContainer
-
- getGauge(MetricName) - Method in interface org.apache.beam.sdk.metrics.MetricsContainer
-
Return the
Gauge
that should be used for implementing the given
metricName
in
this container.
- getGauges(MetricFilter) - Method in class org.apache.beam.runners.spark.metrics.WithMetricsSupport
-
- getGauges(MetricFilter) - Method in class org.apache.beam.runners.spark.structuredstreaming.metrics.WithMetricsSupport
-
- getGauges() - Method in class org.apache.beam.sdk.metrics.MetricQueryResults
-
Return the metric results for the gauges that matched the filter.
- getGcloudCancelCommand(DataflowPipelineOptions, String) - Static method in class org.apache.beam.runners.dataflow.util.MonitoringUtil
-
- getGcpCredential() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcpOptions
-
The credential instance that should be used to authenticate against GCP services.
- getGcpTempLocation() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcpOptions
-
A GCS path for storing temporary files in GCP.
- getGcsEndpoint() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcsOptions
-
GCS endpoint to use.
- getGcsPerformanceMetrics() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcsOptions
-
If true, reports metrics of certain operations, such as batch copies.
- getGcsUploadBufferSizeBytes() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcsOptions
-
The buffer size (in bytes) to use when uploading files to GCS.
- getGcsUtil() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcsOptions
-
The GcsUtil instance that should be used to communicate with Google Cloud Storage.
- getGenericRecordToRowFunction(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
-
- getGetters(Class<T>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
-
Get generated getters for an AVRO-generated SpecificRecord or a POJO.
- getGetters(Class<?>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
-
- getGetters(Class<?>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
-
- getGetters() - Method in class org.apache.beam.sdk.values.RowWithGetters
-
- getGetterTarget() - Method in class org.apache.beam.sdk.values.RowWithGetters
-
- getGoogleApiTrace() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GoogleApiDebugOptions
-
This option enables tracing of API calls to Google services used within the Apache Beam SDK.
- getGrammarFileName() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
-
- getGrammarFileName() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
-
- getHdfsConfiguration() - Method in interface org.apache.beam.sdk.io.hdfs.HadoopFileSystemOptions
-
- getHeaderAccessor() - Static method in class org.apache.beam.runners.fnexecution.GrpcContextHeaderAccessorProvider
-
- getHeaders() - Method in class org.apache.beam.sdk.io.kafka.KafkaRecord
-
- getHighWatermark() - Method in class org.apache.beam.runners.spark.util.GlobalWatermarkHolder.SparkWatermarks
-
- getHistograms(MetricFilter) - Method in class org.apache.beam.runners.spark.metrics.WithMetricsSupport
-
- getHistograms(MetricFilter) - Method in class org.apache.beam.runners.spark.structuredstreaming.metrics.WithMetricsSupport
-
- getHiveConf() - Method in class org.apache.beam.sdk.io.hcatalog.test.EmbeddedMetastoreService
-
Returns the HiveConf object for the embedded metastore.
- getHiveConfAsMap() - Method in class org.apache.beam.sdk.io.hcatalog.test.EmbeddedMetastoreService
-
- getHoldability() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- getHost() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobServerDriver.ServerConfiguration
-
- getHost() - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerConfig
-
- getHTTPWriteTimeout() - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryOptions
-
- getId() - Method in interface org.apache.beam.runners.fnexecution.control.RemoteBundle
-
Get an id used to represent this bundle.
- getId() - Method in class org.apache.beam.runners.fnexecution.control.SdkHarnessClient.BundleProcessor.ActiveBundle
-
Returns an id used to represent this bundle.
- getId() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobInvocation
-
- getId() - Method in class org.apache.beam.runners.spark.io.MicrobatchSource
-
- getId() - Method in class org.apache.beam.sdk.extensions.sql.example.model.Customer
-
- getId() - Method in class org.apache.beam.sdk.extensions.sql.example.model.Order
-
- getId() - Method in interface org.apache.beam.sdk.fn.IdGenerator
-
- getId() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.ProjectPath
-
- getId() - Method in class org.apache.beam.sdk.values.TupleTag
-
Returns the id of this TupleTag
.
- getId() - Method in class org.apache.beam.sdk.values.ValueWithRecordId
-
- getIdAttribute() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSink
-
Get the id attribute.
- getIdAttribute() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSource
-
Get the id attribute.
- getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
-
- getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
-
- getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
- getIdentifier() - Method in class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
-
- getIdentifier() - Method in interface org.apache.beam.sdk.schemas.Schema.LogicalType
-
The unique identifier for this type.
- getImplementor() - Method in class org.apache.beam.sdk.extensions.sql.impl.ScalarFunctionImpl
-
- getImplementor(boolean) - Method in class org.apache.beam.sdk.extensions.sql.impl.UdafImpl
-
- getImplementor() - Method in class org.apache.beam.sdk.extensions.sql.zetasql.ZetaSQLCastFunctionImpl
-
- getInboundObserver() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer
-
- getIncompatibleGlobalWindowErrorMessage() - Method in interface org.apache.beam.sdk.transforms.CombineFnBase.GlobalCombineFn
-
Returns the error message for not supported default values in Combine.globally().
- getIncompatibleGlobalWindowErrorMessage() - Method in class org.apache.beam.sdk.transforms.Top.TopCombineFn
-
- getIndex() - Method in class org.apache.beam.sdk.extensions.sql.impl.utils.SerializableRexInputRef
-
- getIndex() - Method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.ConnectionConfiguration
-
- getIndex() - Method in class org.apache.beam.sdk.io.gcp.spanner.ReadOperation
-
- getIndex(TupleTag<?>) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
-
Returns the index for the given tuple tag, if the tag is present in this schema, -1 if it
isn't.
- getIndex() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
The zero-based index of this trigger firing that produced this pane.
- getIndexes() - Method in class org.apache.beam.sdk.extensions.sql.impl.utils.SerializableRexFieldAccess
-
- getInput(PTransform<InputT, ?>) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.TranslationContext
-
- getInput() - Method in class org.apache.beam.runners.gearpump.translators.TranslationContext
-
- getInput() - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.TranslationContext
-
- getInput(RelNode) - Static method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSqlRelUtils
-
- getInputFile() - Method in interface org.apache.beam.runners.spark.structuredstreaming.examples.WordCount.WordCountOptions
-
- getinputFormatClass() - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.Read
-
- getinputFormatKeyClass() - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.Read
-
- getinputFormatValueClass() - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.Read
-
- getInputReceivers() - Method in interface org.apache.beam.runners.fnexecution.control.RemoteBundle
-
Get a map of PCollection ids to
receiver
s which consume input elements,
forwarding them to the remote environment.
- getInputReceivers() - Method in class org.apache.beam.runners.fnexecution.control.SdkHarnessClient.BundleProcessor.ActiveBundle
-
Get a map of PCollection ids to
receiver
s which consume input
elements, forwarding them to the remote environment.
- getInputs(PTransform<InputT, ?>) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.TranslationContext
-
Returns the input of the currently being translated transform.
- getInputs() - Method in class org.apache.beam.runners.gearpump.translators.TranslationContext
-
- getInputs() - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.TranslationContext
-
- getInputStream(PValue) - Method in class org.apache.beam.runners.gearpump.translators.TranslationContext
-
- getInputType() - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
-
Returns a
TypeDescriptor
capturing what is known statically about the input type of
this
CombineFn
instance's most-derived class.
- getInputTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.DoFn
-
Returns a
TypeDescriptor
capturing what is known statically about the input type of
this
DoFn
instance's most-derived class.
- getInputTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.InferableFunction
-
- getInputValueCoder(Coder<KV<K, V>>) - Static method in class org.apache.beam.sdk.transforms.GroupByKey
-
Returns the Coder
of the values of the input to this transform.
- getInputWatermark() - Method in class org.apache.beam.runners.direct.WatermarkManager.TransformWatermarks
-
Returns the input watermark of the AppliedPTransform
.
- getInsertBundleParallelism() - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryOptions
-
- getInsertDefault() - Method in class org.apache.beam.sdk.transforms.Combine.GloballyAsSingletonView
-
- getInstance() - Static method in class org.apache.beam.runners.spark.aggregators.AggregatorsAccumulator
-
- getInstance() - Static method in class org.apache.beam.runners.spark.metrics.MetricsAccumulator
-
- getInstance() - Static method in class org.apache.beam.runners.spark.structuredstreaming.aggregators.AggregatorsAccumulator
-
- getInstance() - Static method in class org.apache.beam.runners.spark.structuredstreaming.metrics.MetricsAccumulator
-
- getInstanceId() - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerConfig
-
- getInstructionId() - Method in class org.apache.beam.sdk.fn.data.LogicalEndpoint
-
- getInstructionRequestHandler() - Method in class org.apache.beam.runners.fnexecution.environment.ProcessEnvironment
-
- getInstructionRequestHandler() - Method in interface org.apache.beam.runners.fnexecution.environment.RemoteEnvironment
-
- getInstructionRequestHandler() - Method in class org.apache.beam.runners.fnexecution.environment.RemoteEnvironment.SimpleRemoteEnvironment
-
- getInstructionRequestHandler() - Method in class org.apache.beam.runners.fnexecution.environment.StaticRemoteEnvironment
-
- getInt(Map<String, Object>, String) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getInt(Map<String, Object>, String, Integer) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getInt16(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.INT16
value by field name,
IllegalStateException
is thrown if
schema doesn't match.
- getInt16(int) - Method in class org.apache.beam.sdk.values.Row
-
- getInt32(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.INT32
value by field name,
IllegalStateException
is thrown if
schema doesn't match.
- getInt32(int) - Method in class org.apache.beam.sdk.values.Row
-
- getInt64(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.INT64
value by field name,
IllegalStateException
is thrown if
schema doesn't match.
- getInt64(int) - Method in class org.apache.beam.sdk.values.Row
-
- getInterface() - Method in enum org.apache.beam.sdk.extensions.sql.impl.rel.BeamLogicalConvention
-
- getInterfaces() - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns a set of
TypeDescriptor
s, one for each interface implemented by this class.
- getIo() - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamCostModel
-
- getIterable(String) - Method in class org.apache.beam.sdk.values.Row
-
Get an iterable value by field name, IllegalStateException
is thrown if schema doesn't
match.
- getIterable(int) - Method in class org.apache.beam.sdk.values.Row
-
Get an iterable value by field index, IllegalStateException
is thrown if schema doesn't
match.
- getIterableComponentType(TypeDescriptor) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
-
For an array T[] or a subclass of Iterable, return a TypeDescriptor describing T.
- getJavaClass(RelDataType) - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamJavaTypeFactory
-
- getJAXBClass() - Method in class org.apache.beam.sdk.io.xml.JAXBCoder
-
- getJetDefaultParallelism() - Method in interface org.apache.beam.runners.jet.JetPipelineOptions
-
- getJetGroupName() - Method in interface org.apache.beam.runners.jet.JetPipelineOptions
-
- getJetLocalMode() - Method in interface org.apache.beam.runners.jet.JetPipelineOptions
-
- getJetProcessorsCooperative() - Method in interface org.apache.beam.runners.jet.JetPipelineOptions
-
- getJetServers() - Method in interface org.apache.beam.runners.jet.JetPipelineOptions
-
- getJmsCorrelationID() - Method in class org.apache.beam.sdk.io.jms.JmsRecord
-
- getJmsDeliveryMode() - Method in class org.apache.beam.sdk.io.jms.JmsRecord
-
- getJmsDestination() - Method in class org.apache.beam.sdk.io.jms.JmsRecord
-
- getJmsExpiration() - Method in class org.apache.beam.sdk.io.jms.JmsRecord
-
- getJmsMessageID() - Method in class org.apache.beam.sdk.io.jms.JmsRecord
-
- getJmsPriority() - Method in class org.apache.beam.sdk.io.jms.JmsRecord
-
- getJmsRedelivered() - Method in class org.apache.beam.sdk.io.jms.JmsRecord
-
- getJmsReplyTo() - Method in class org.apache.beam.sdk.io.jms.JmsRecord
-
- getJmsTimestamp() - Method in class org.apache.beam.sdk.io.jms.JmsRecord
-
- getJmsType() - Method in class org.apache.beam.sdk.io.jms.JmsRecord
-
- getJob(String) - Method in class org.apache.beam.runners.dataflow.DataflowClient
-
Gets the Dataflow
Job
with the given
jobId
.
- getJob() - Method in exception org.apache.beam.runners.dataflow.DataflowJobException
-
Returns the failed job.
- getJob() - Method in class org.apache.beam.runners.dataflow.DataflowPipelineTranslator.JobSpecification
-
- getJob(JobReference) - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryServices.JobService
-
- getJob(JobReference) - Method in class org.apache.beam.sdk.io.gcp.testing.FakeJobService
-
- getJobEndpoint() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
-
- getJobId() - Method in class org.apache.beam.runners.dataflow.DataflowPipelineJob
-
Get the id of this job.
- getJobId() - Method in interface org.apache.beam.runners.dataflow.options.DataflowWorkerHarnessOptions
-
The identity of the Dataflow job.
- getJobId() - Method in class org.apache.beam.runners.dataflow.util.DataflowTemplateJob
-
- getJobInfo() - Method in class org.apache.beam.runners.flink.FlinkBatchPortablePipelineTranslator.BatchTranslationContext
-
- getJobInfo() - Method in interface org.apache.beam.runners.flink.FlinkPortablePipelineTranslator.TranslationContext
-
- getJobInfo() - Method in class org.apache.beam.runners.flink.FlinkStreamingPortablePipelineTranslator.StreamingTranslationContext
-
- getJobMessages(String, long) - Method in class org.apache.beam.runners.dataflow.util.MonitoringUtil
-
Return job messages sorted in ascending order by timestamp.
- getJobMetrics(String) - Method in class org.apache.beam.runners.dataflow.DataflowClient
-
- getJobMetrics(JobApi.GetJobMetricsRequest, StreamObserver<JobApi.GetJobMetricsResponse>) - Method in class org.apache.beam.runners.fnexecution.jobsubmission.InMemoryJobService
-
- getJobMetrics(JobApi.GetJobMetricsRequest, StreamObserver<JobApi.GetJobMetricsResponse>) - Method in class org.apache.beam.runners.portability.testing.TestJobService
-
- getJobMonitoringPageURL(String, String) - Static method in class org.apache.beam.runners.dataflow.util.MonitoringUtil
-
- getJobMonitoringPageURL(String, String, String) - Static method in class org.apache.beam.runners.dataflow.util.MonitoringUtil
-
- getJobName() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
- getJobs(JobApi.GetJobsRequest, StreamObserver<JobApi.GetJobsResponse>) - Method in class org.apache.beam.runners.fnexecution.jobsubmission.InMemoryJobService
-
- getJobServerConfig() - Method in interface org.apache.beam.runners.portability.testing.TestPortablePipelineOptions
-
- getJobServerDriver() - Method in interface org.apache.beam.runners.portability.testing.TestPortablePipelineOptions
-
- getJobServerUrl() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobServerDriver
-
- getJobService(BigQueryOptions) - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryServices
-
- getJobService(BigQueryOptions) - Method in class org.apache.beam.sdk.io.gcp.testing.FakeBigQueryServices
-
- getJsonClustering() - Method in class org.apache.beam.sdk.io.gcp.bigquery.TableDestination
-
- getJsonFactory() - Static method in class org.apache.beam.sdk.extensions.gcp.util.Transport
-
- getJsonTimePartitioning() - Method in class org.apache.beam.sdk.io.gcp.bigquery.TableDestination
-
- getKey() - Method in class org.apache.beam.runners.direct.WatermarkManager.FiredTimers
-
- getKey() - Method in interface org.apache.beam.runners.local.Bundle
-
Returns the key that was output in the most recent GroupByKey
in the execution of this
bundle.
- getKey() - Method in class org.apache.beam.runners.local.StructuralKey
-
- getKey() - Method in class org.apache.beam.sdk.metrics.MetricResult
-
- getKey() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
-
- getKey() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
The key for the display item.
- getKey() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
The key for the display item.
- getKey() - Method in class org.apache.beam.sdk.values.KV
-
Returns the key of this
KV
.
- getKey() - Method in class org.apache.beam.sdk.values.ShardedKey
-
- getKeyCoder() - Method in class org.apache.beam.sdk.coders.KvCoder
-
- getKeyCoder() - Method in class org.apache.beam.sdk.coders.MapCoder
-
- getKeyCoder(Coder<KV<K, V>>) - Static method in class org.apache.beam.sdk.transforms.GroupByKey
-
Returns the Coder
of the keys of the input to this transform, which is also used as the
Coder
of the keys of the output of this transform.
- getKeyCoder() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
- getKeyedCollections() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
- getKeyRange() - Method in class org.apache.beam.sdk.io.hbase.HBaseIO.Read
-
Returns the range of keys that will be read from the table.
- getKeyRanges() - Method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableIO.Read
-
Returns the range of keys that will be read from the table.
- getKeySet() - Method in class org.apache.beam.sdk.io.gcp.spanner.ReadOperation
-
- getKeystorePassword() - Method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.ConnectionConfiguration
-
- getKeystorePath() - Method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.ConnectionConfiguration
-
- getKeyTranslationFunction() - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.Read
-
- getKeyTypeDescriptor() - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.Read
-
- getKind() - Method in class org.apache.beam.sdk.extensions.sql.impl.QueryPlanner.QueryParameters
-
- getKind() - Method in interface org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.PubsubClientFactory
-
Return the display name for this factory.
- getKind() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
-
- getKindString() - Method in class org.apache.beam.sdk.io.BoundedReadFromUnboundedSource
-
- getKindString() - Method in class org.apache.beam.sdk.io.Read.Bounded
-
- getKindString() - Method in class org.apache.beam.sdk.io.Read.Unbounded
-
- getKindString() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
- getKindString() - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
-
- getKindString() - Method in class org.apache.beam.sdk.transforms.Combine.PerKeyWithHotKeyFanout
-
- getKindString() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
-
- getKindString() - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
-
- getKindString() - Method in class org.apache.beam.sdk.transforms.PTransform
-
Returns the name to use by default for this PTransform
(not including the names of any
enclosing PTransform
s).
- getKindString() - Method in class org.apache.beam.sdk.transforms.windowing.Window
-
- getKindString() - Method in class org.apache.beam.sdk.values.PValueBase
-
Returns a
String
capturing the kind of this
PValueBase
.
- getKinesisClient() - Method in interface org.apache.beam.sdk.io.kinesis.AWSClientsProvider
-
- getKV() - Method in class org.apache.beam.sdk.io.kafka.KafkaRecord
-
- getLabel() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
Retrieve the optional label for an item.
- getLabel() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
The optional label for an item.
- getLabels() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineOptions
-
Labels that will be applied to the billing records for this job.
- getLanguageOptions() - Static method in class org.apache.beam.sdk.extensions.sql.zetasql.ZetaSQLPlannerImpl
-
- getLastEmitted() - Method in class org.apache.beam.sdk.io.CountingSource.CounterMark
-
Returns the last value emitted by the reader.
- getLastFieldId() - Method in class org.apache.beam.sdk.schemas.Schema.Builder
-
- getLastWatermarkedBatchTime() - Static method in class org.apache.beam.runners.spark.util.GlobalWatermarkHolder
-
- getLatencyTrackingInterval() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getLateTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
-
- getLegacyEnvironmentMajorVersion() - Method in class org.apache.beam.runners.dataflow.DataflowRunnerInfo
-
Provides the legacy environment's major version number.
- getLength() - Method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
-
- getLimitCountOfSortRel() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.AbstractBeamCalcRel
-
- getLinkUrl() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
Retrieve the optional link URL for an item.
- getLinkUrl() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
The optional link URL for an item.
- getList() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
-
- getListeners() - Method in interface org.apache.beam.runners.spark.SparkContextOptions
-
- getListOfMaps(Map<String, Object>, String, List<Map<String, Object>>) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getLiteralGqlQuery() - Method in class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.Read
-
- getLoadBalanceBundles() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
-
- getLocalhost() - Method in class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.Read
-
- getLocalValue() - Method in class org.apache.beam.runners.flink.metrics.MetricsAccumulator
-
- getLocation() - Method in class org.apache.beam.sdk.extensions.sql.meta.Table
-
- getLogicalType() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
- getLogicalType(Class<LogicalTypeT>) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Helper function for retrieving the concrete logical type subclass.
- getLogicalTypeName() - Method in class org.apache.beam.sdk.coders.AvroCoder.JodaTimestampConversion
-
- getLogicalTypeValue(String, Class<T>) - Method in class org.apache.beam.sdk.values.Row
-
Returns the Logical Type input type for this field.
- getLogicalTypeValue(int, Class<T>) - Method in class org.apache.beam.sdk.values.Row
-
Returns the Logical Type input type for this field.
- getLong(Map<String, Object>, String) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getLong(Map<String, Object>, String, Long) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getLowWatermark() - Method in class org.apache.beam.runners.spark.util.GlobalWatermarkHolder.SparkWatermarks
-
- getMainOutputTag() - Method in class org.apache.beam.runners.dataflow.PrimitiveParDoSingleFactory.ParDoSingle
-
- getMainOutputTag() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- getMainOutputTag() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
-
- getMainTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
-
The main trigger, which will continue firing until the "until" trigger fires.
- getManifest(ArtifactApi.GetManifestRequest, StreamObserver<ArtifactApi.GetManifestResponse>) - Method in class org.apache.beam.runners.fnexecution.artifact.AbstractArtifactRetrievalService
-
- getManifestProxy(String) - Method in class org.apache.beam.runners.fnexecution.artifact.AbstractArtifactRetrievalService
-
- getMap() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
-
- getMap(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a MAP value by field name, IllegalStateException
is thrown if schema doesn't match.
- getMap(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a MAP value by field index, IllegalStateException
is thrown if schema doesn't
match.
- getMapKeyType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
If the field is a map type, returns the key type.
- getMapKeyType() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
- getMapType(TypeDescriptor, int) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
-
- getMapValueType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
If the field is a map type, returns the key type.
- getMapValueType() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
- getMatcher() - Method in class org.apache.beam.sdk.extensions.gcp.util.CustomHttpErrors.MatcherAndError
-
- getMaterialization() - Method in class org.apache.beam.sdk.transforms.ViewFn
-
Gets the materialization of this
ViewFn
.
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn
-
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.ListViewFn
-
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.MapViewFn
-
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn
-
- getMaterialization() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
-
- getMax() - Method in class org.apache.beam.sdk.metrics.DistributionResult
-
- getMaxBundleSize() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getMaxBundleTimeMills() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getMaxConditionCost() - Method in interface org.apache.beam.runners.dataflow.options.CloudDebuggerOptions
-
The maximum cost (as a ratio of CPU time) allowed for evaluating conditional snapshots.
- getMaxCumulativeBackoff() - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerConfig
-
- getMaxEndOffset(PipelineOptions) - Method in class org.apache.beam.sdk.io.FileBasedSource
-
- getMaxEndOffset(PipelineOptions) - Method in class org.apache.beam.sdk.io.OffsetBasedSource
-
Returns the actual ending offset of the current source.
- getMaxInvocationHistory() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobServerDriver.ServerConfiguration
-
- getMaxNumericPrecision() - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamRelDataTypeSystem
-
- getMaxNumericScale() - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamRelDataTypeSystem
-
- getMaxNumWorkers() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineWorkerPoolOptions
-
The maximum number of workers to use for the workerpool.
- getMaxParallelism() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getMaxRecordsPerBatch() - Method in interface org.apache.beam.runners.spark.SparkPipelineOptions
-
- getMaxStreamingBatchSize() - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryOptions
-
- getMaxStreamingRowsToBatch() - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryOptions
-
- getMean() - Method in class org.apache.beam.sdk.metrics.DistributionResult
-
- getMean() - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
-
- getMemoryMB() - Method in class org.apache.beam.sdk.extensions.sorter.BufferedExternalSorter.Options
-
Returns the configured size of the memory buffer.
- getMemoryMB() - Method in class org.apache.beam.sdk.extensions.sorter.ExternalSorter.Options
-
Returns the configured size of the memory buffer.
- getMessage() - Method in exception org.apache.beam.sdk.coders.Coder.NonDeterministicException
-
- getMessage() - Method in exception org.apache.beam.sdk.transforms.windowing.IncompatibleWindowException
-
- getMessageBacklog() - Method in class org.apache.beam.sdk.io.kafka.TimestampPolicy.PartitionContext
-
Current backlog in messages (latest offset of the partition - last processed record offset).
- getMessageId() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessage
-
Returns the messageId of the message populated by Cloud Pub/Sub.
- getMessageStream(JobApi.JobMessagesRequest, StreamObserver<JobApi.JobMessagesResponse>) - Method in class org.apache.beam.runners.fnexecution.jobsubmission.InMemoryJobService
-
- getMessageType() - Method in class org.apache.beam.sdk.extensions.protobuf.ProtoCoder
-
- getMetaData() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- getMetadata(DestinationT) - Method in class org.apache.beam.sdk.io.DynamicAvroDestinations
-
Return AVRO file metadata for a given destination.
- getMetadata() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
-
Returns the MatchResult.Metadata
of the file.
- getMetadata() - Method in class org.apache.beam.sdk.io.tika.ParseResult
-
Returns the extracted metadata.
- getMetadata() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
Returns optional extra metadata.
- getMetadata(String) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
- getMetadataQuery() - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.JoinRelOptRuleCall
-
- getMetadataString(String) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
- getMetaStore() - Method in class org.apache.beam.sdk.extensions.sql.BeamSqlCli
-
- getMeters(MetricFilter) - Method in class org.apache.beam.runners.spark.metrics.WithMetricsSupport
-
- getMeters(MetricFilter) - Method in class org.apache.beam.runners.spark.structuredstreaming.metrics.WithMetricsSupport
-
- getMethod() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
- getMethods(Class) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
-
Returns the list of non private/protected, non-static methods in the class, caching the
results.
- getMethodsMap(Class) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
-
- getMetrics() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobInvocation
-
- getMetricsContainer(String) - Method in class org.apache.beam.runners.flink.metrics.FlinkMetricContainer
-
- getMetricsGraphiteHost() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
-
- getMetricsGraphitePort() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
-
- getMetricsHttpSinkUrl() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
-
- getMetricsMapName(long) - Static method in class org.apache.beam.runners.jet.metrics.JetMetricsContainer
-
- getMetricsPushPeriod() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
-
- getMetricsSink() - Method in interface org.apache.beam.sdk.metrics.MetricsOptions
-
- getMimeType() - Method in enum org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.
- getMimeType() - Method in interface org.apache.beam.sdk.io.FileBasedSink.OutputFileHints
-
Returns the MIME type that should be used for the files that will hold the output data.
- getMin() - Method in class org.apache.beam.sdk.metrics.DistributionResult
-
- getMinBundleSize() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
-
Returns the minimum bundle size that should be used when splitting the source into sub-sources.
- getMinCpuPlatform() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineWorkerPoolOptions
-
Specifies a Minimum CPU platform for VM instances.
- getMinimumTimestamp() - Method in interface org.apache.beam.runners.local.Bundle
-
Return the minimum timestamp among elements in this bundle.
- getMinPauseBetweenCheckpoints() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getMinReadTimeMillis() - Method in interface org.apache.beam.runners.spark.SparkPipelineOptions
-
- getMode() - Method in class org.apache.beam.sdk.io.FileBasedSource
-
- getMode() - Method in class org.apache.beam.sdk.values.WindowingStrategy
-
- getModeNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
-
- getModifiableCollection() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteTable
-
- getMonthOfYear() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
-
- getMutableOutput(TupleTag<T>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- getName(int) - Method in class org.apache.beam.sdk.extensions.gcp.util.gcsfs.GcsPath
-
- getName() - Method in class org.apache.beam.sdk.extensions.sql.example.model.Customer
-
- getName() - Method in enum org.apache.beam.sdk.extensions.sql.impl.rel.BeamLogicalConvention
-
- getName() - Method in class org.apache.beam.sdk.extensions.sql.meta.Table
-
- getName() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.SubscriptionPath
-
- getName() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.TopicPath
-
- getName() - Method in class org.apache.beam.sdk.metrics.DelegatingCounter
-
- getName() - Method in interface org.apache.beam.sdk.metrics.Metric
-
- getName() - Method in class org.apache.beam.sdk.metrics.MetricName
-
The name of this metric.
- getName() - Method in class org.apache.beam.sdk.metrics.MetricNameFilter
-
- getName() - Method in class org.apache.beam.sdk.metrics.MetricResult
-
Return the name of the metric.
- getName() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
Returns the field name.
- getName() - Method in class org.apache.beam.sdk.schemas.Schema.Field
-
Returns the field name.
- getName() - Method in class org.apache.beam.sdk.transforms.PTransform
-
Returns the transform name.
- getName() - Method in class org.apache.beam.sdk.values.PCollection
-
- getName() - Method in interface org.apache.beam.sdk.values.PValue
-
Returns the name of this
PValue
.
- getName() - Method in class org.apache.beam.sdk.values.PValueBase
-
- getNameCount() - Method in class org.apache.beam.sdk.extensions.gcp.util.gcsfs.GcsPath
-
- getNameOverride() - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
-
- getNameOverride() - Method in class org.apache.beam.sdk.transforms.Top.TopCombineFn
-
- getNamespace() - Method in class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.Read
-
- getNamespace() - Method in class org.apache.beam.sdk.metrics.MetricName
-
The namespace associated with this metric.
- getNamespace() - Method in class org.apache.beam.sdk.metrics.MetricNameFilter
-
- getNamespace() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
-
- getNamespace() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
The namespace for the display item.
- getNamespace() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
The namespace for the display item.
- getNeedsAttributes() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSource
-
- getNeedsMessageId() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSource
-
- getNestedFieldsAccessed() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor
-
- getNetwork() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineWorkerPoolOptions
-
- getNetworkTimeout() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- getNewBigquerryClient(String) - Static method in class org.apache.beam.sdk.io.gcp.testing.BigqueryClient
-
- getNextOffset() - Method in class org.apache.beam.sdk.io.kafka.KafkaCheckpointMark.PartitionMark
-
- getNodeStats() - Method in interface org.apache.beam.sdk.extensions.sql.impl.planner.NodeStatsMetadata
-
- getNodeStats(RelNode, RelMetadataQuery) - Method in interface org.apache.beam.sdk.extensions.sql.impl.planner.NodeStatsMetadata.Handler
-
- getNodeStats(RelNode, RelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.RelMdNodeStats
-
- getNodeStats(RelNode, RelMetadataQuery) - Static method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSqlRelUtils
-
- getNonCumulativeCost(RelNode, RelMetadataQuery) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner.NonCumulativeCostImpl
-
- getNonSpeculativeIndex() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
The zero-based index of this trigger firing among non-speculative panes.
- getNonWildcardPrefix(String) - Static method in class org.apache.beam.sdk.extensions.gcp.util.GcsUtil
-
Returns the prefix portion of the glob that doesn't contain wildcards.
- getNotSupported() - Method in interface org.apache.beam.sdk.extensions.sql.meta.BeamSqlTableFilter
-
Identify parts of a predicate that are not supported by the IO push-down capabilities to be
preserved in a Calc
following BeamIOSourceRel
.
- getNotSupported() - Method in class org.apache.beam.sdk.extensions.sql.meta.DefaultTableFilter
-
Since predicate push-down is assumed not to be supported by default - return an unchanged list
of filters to be preserved.
- getNotSupported() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryFilter
-
- getNotSupported() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestTableFilter
-
- getNullable() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
- getNum() - Method in class org.apache.beam.runners.spark.io.ConsoleIO.Write.Unbound
-
- getNumber() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
-
- getNumber() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
-
- getNumber() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
-
- getNumberOfExecutionRetries() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getNumberOfWorkerHarnessThreads() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineDebugOptions
-
Number of threads to use on the Dataflow worker harness.
- getNumEntities(PipelineOptions, String, String) - Method in class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.Read
-
Returns Number of entities available for reading.
- getNumExtractJobCalls() - Method in class org.apache.beam.sdk.io.gcp.testing.FakeJobService
-
- getNumQuerySplits() - Method in class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.Read
-
- getNumRows(BigQueryOptions, TableReference) - Static method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryHelpers
-
It returns the number of rows for a given table.
- getNumSampledBytesPerFile() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
-
- getNumShardsProvider() - Method in class org.apache.beam.sdk.io.WriteFiles
-
- getNumStreamingKeys() - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryOptions
-
- getNumWorkers() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineWorkerPoolOptions
-
Number of workers to use when executing the Dataflow job.
- getObject(Map<String, Object>, String) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getObject(Map<String, Object>, String, Map<String, Object>) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getObject() - Method in class org.apache.beam.sdk.extensions.gcp.util.gcsfs.GcsPath
-
Returns the object name associated with this GCS path, or an empty string if no object is
specified.
- getObject(GcsPath) - Method in class org.apache.beam.sdk.extensions.gcp.util.GcsUtil
-
- getObjectReuse() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getObjects(List<GcsPath>) - Method in class org.apache.beam.sdk.extensions.gcp.util.GcsUtil
-
- getOffset() - Method in class org.apache.beam.sdk.io.kafka.KafkaRecord
-
- getOffset() - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
-
- getOffset() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
-
- getOffset() - Method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform.AlignTo
-
- getOnCreateMatcher() - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
-
- getOneOfSchema() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
Returns the schema of the underlying
Row
that is used to represent the union.
- getOneOfTypes() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
- getOnly(TupleTag<V>) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
If there is a singleton value for the given tag, returns it.
- getOnly(String) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
- getOnly(TupleTag<V>, V) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
If there is a singleton value for the given tag, returns it.
- getOnly(String, V) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
- getOnSuccessMatcher() - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
-
- getOnTimeBehavior() - Method in class org.apache.beam.sdk.values.WindowingStrategy
-
- getOperand0() - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.JoinRelOptRuleCall
-
- getOperandList() - Method in class org.apache.beam.sdk.extensions.sql.impl.parser.SqlCheckConstraint
-
- getOperandList() - Method in class org.apache.beam.sdk.extensions.sql.impl.parser.SqlColumnDeclaration
-
- getOperandList() - Method in class org.apache.beam.sdk.extensions.sql.impl.parser.SqlCreateExternalTable
-
- getOperator() - Method in class org.apache.beam.sdk.extensions.sql.impl.parser.SqlCheckConstraint
-
- getOperator() - Method in class org.apache.beam.sdk.extensions.sql.impl.parser.SqlColumnDeclaration
-
- getOptions() - Method in class org.apache.beam.sdk.Pipeline
-
- getOptions() - Method in class org.apache.beam.sdk.testing.TestPipeline
-
- getOptionsId() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
Provides a process wide unique ID for this
PipelineOptions
object, assigned at graph
construction time.
- getOrCreateReader(PipelineOptions, CheckpointMarkT) - Method in class org.apache.beam.runners.spark.io.MicrobatchSource
-
- getOriginalWindowFn() - Method in class org.apache.beam.sdk.transforms.windowing.InvalidWindows
-
Returns the original windowFn that this InvalidWindows replaced.
- getOutboundObserver() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer
-
- getOutName(int) - Method in class org.apache.beam.sdk.values.TupleTag
-
If this TupleTag
is tagging output outputIndex
of a PTransform
, returns
the name that should be used by default for the output.
- getOutput(PTransform<?, OutputT>) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.TranslationContext
-
- getOutput() - Method in class org.apache.beam.runners.gearpump.translators.TranslationContext
-
- getOutput() - Method in interface org.apache.beam.runners.spark.structuredstreaming.examples.WordCount.WordCountOptions
-
- getOutput() - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.TranslationContext
-
- getOutput() - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerWriteResult
-
- getOutputCoder() - Method in class org.apache.beam.runners.spark.io.MicrobatchSource
-
- getOutputCoder(SerializableFunction<InputT, OutputT>, Coder<InputT>) - Method in class org.apache.beam.sdk.coders.CoderRegistry
-
- getOutputCoder() - Method in class org.apache.beam.sdk.io.AvroSource
-
- getOutputCoder() - Method in class org.apache.beam.sdk.io.CompressedSource
-
Returns the delegate source's output coder.
- getOutputCoder() - Method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.BoundedElasticsearchSource
-
- getOutputCoder() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageStreamSource
-
- getOutputCoder() - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.HadoopInputFormatBoundedSource
-
- getOutputCoder() - Method in class org.apache.beam.sdk.io.mongodb.MongoDbGridFSIO.Read.BoundedGridFSSource
-
- getOutputCoder() - Method in class org.apache.beam.sdk.io.Source
-
Returns the Coder
to use for the data read from this source.
- getOutputCoder() - Method in class org.apache.beam.sdk.io.xml.XmlSource
-
- getOutputCoders() - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.TranslationContext
-
- getOutputExecutablePath() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
-
- getOutputFile() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
-
- getOutputFilePrefix() - Method in interface org.apache.beam.sdk.extensions.sql.example.BeamSqlDataCatalogExample.DCExamplePipelineOptions
-
Output file prefix.
- getOutputKvCoder(Coder<KV<K, V>>) - Static method in class org.apache.beam.sdk.transforms.GroupByKey
-
Returns the Coder
of the output of this transform.
- getOutputs(PTransform<?, OutputT>) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.TranslationContext
-
Returns the output of the currently being translated transform.
- getOutputs() - Method in class org.apache.beam.runners.gearpump.translators.TranslationContext
-
- getOutputs() - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.TranslationContext
-
- getOutputSchema(Schema, FieldAccessDescriptor) - Static method in class org.apache.beam.sdk.schemas.utils.SelectHelpers
-
- getOutputStrategyInternal(WindowingStrategy<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.Window
-
- getOutputTime(Instant, GlobalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
-
- getOutputTime(Instant, W) - Method in class org.apache.beam.sdk.transforms.windowing.InvalidWindows
-
- getOutputTime(Instant, W) - Method in class org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn
-
- getOutputTime(Instant, IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
-
Ensures that later sliding windows have an output time that is past the end of earlier windows.
- getOutputTime(Instant, W) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
Returns the output timestamp to use for data depending on the given inputTimestamp
in
the specified window
.
- getOutputType() - Method in class org.apache.beam.sdk.transforms.Combine.CombineFn
-
Returns a
TypeDescriptor
capturing what is known statically about the output type of
this
CombineFn
instance's most-derived class.
- getOutputTypeDescriptor() - Method in class org.apache.beam.runners.dataflow.BatchStatefulParDoOverrides.BatchStatefulDoFn
-
- getOutputTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.DoFn
-
Returns a
TypeDescriptor
capturing what is known statically about the output type of
this
DoFn
instance's most-derived class.
- getOutputTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.InferableFunction
-
- getOutputWatermark() - Method in class org.apache.beam.runners.direct.WatermarkManager.TransformWatermarks
-
Returns the output watermark of the AppliedPTransform
.
- getOverrides() - Method in class org.apache.beam.runners.apex.ApexRunner
-
- getOverrideWindmillBinary() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineDebugOptions
-
Custom windmill_main binary to use with the streaming runner.
- getPane() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
-
Returns the pane of this ValueInSingleWindow
in its window.
- getPaneInfo() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
-
- getParallelism() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getParallelism() - Method in interface org.apache.beam.runners.gearpump.GearpumpPipelineOptions
-
- getParameters() - Method in class org.apache.beam.sdk.extensions.sql.impl.UdafImpl
-
- getParameters() - Method in class org.apache.beam.sdk.extensions.sql.impl.UdfImplReflectiveFunctionBase
-
Returns the parameters of this function.
- getParameters() - Method in class org.apache.beam.sdk.extensions.sql.zetasql.ZetaSQLCastFunctionImpl
-
- getParent() - Method in class org.apache.beam.sdk.extensions.gcp.util.gcsfs.GcsPath
-
Returns the parent path, or null
if this path does not have a parent.
- getParents() - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.JoinRelOptRuleCall
-
- getParser() - Method in class org.apache.beam.sdk.extensions.protobuf.DynamicProtoCoder
-
Get the memoized
Parser
, possibly initializing it lazily.
- getParser() - Method in class org.apache.beam.sdk.extensions.protobuf.ProtoCoder
-
Get the memoized
Parser
, possibly initializing it lazily.
- getPartition() - Method in class org.apache.beam.sdk.io.kafka.KafkaCheckpointMark.PartitionMark
-
- getPartition() - Method in class org.apache.beam.sdk.io.kafka.KafkaRecord
-
- getPartitionKey(byte[]) - Method in interface org.apache.beam.sdk.io.kinesis.KinesisPartitioner
-
- getPartitionKey() - Method in class org.apache.beam.sdk.io.kinesis.KinesisRecord
-
- getPartitions() - Method in class org.apache.beam.runners.spark.io.SourceRDD.Bounded
-
- getPartitions() - Method in class org.apache.beam.runners.spark.io.SourceRDD.Unbounded
-
- getPartitions() - Method in class org.apache.beam.sdk.io.kafka.KafkaCheckpointMark
-
- getPassword() - Method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.ConnectionConfiguration
-
- getPath() - Method in class org.apache.beam.sdk.extensions.sql.impl.TableName
-
Table path up to the leaf table name.
- getPath() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.ProjectPath
-
- getPath() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.SubscriptionPath
-
- getPath() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.TopicPath
-
- getPath() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
-
- getPath() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
The path for the display item within a component hierarchy.
- getPathValidator() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcsOptions
-
The path validator instance that should be used to validate paths.
- getPathValidatorClass() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcsOptions
-
The class of the validator that should be created and used to validate paths.
- getPayload() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessage
-
Returns the main PubSub message.
- getPayload() - Method in class org.apache.beam.sdk.io.jms.JmsRecord
-
- getPCollection() - Method in interface org.apache.beam.runners.local.Bundle
-
Returns the PCollection that the elements of this bundle belong to.
- getPCollection() - Method in interface org.apache.beam.sdk.values.PCollectionView
-
For internal use only.
- getPCollection() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
-
- getPCollectionInputs() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamJoinRel
-
- getPCollectionInputs() - Method in interface org.apache.beam.sdk.extensions.sql.impl.rel.BeamRelNode
-
- getPerDestinationOutputFilenames() - Method in class org.apache.beam.sdk.io.WriteFilesResult
-
Returns a
PCollection
of all output filenames generated by this
WriteFiles
organized by user destination type.
- getPerElementConsumers(CollectionT) - Method in interface org.apache.beam.runners.direct.ExecutableGraph
-
- getPerElementInputs(ExecutableT) - Method in interface org.apache.beam.runners.direct.ExecutableGraph
-
- getPeriod() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
-
- getPeriod() - Method in class org.apache.beam.sdk.transforms.windowing.TimestampTransform.AlignTo
-
- getPipeline(JobApi.GetJobPipelineRequest, StreamObserver<JobApi.GetJobPipelineResponse>) - Method in class org.apache.beam.runners.fnexecution.jobsubmission.InMemoryJobService
-
- getPipeline() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobInvocation
-
Retrieve the job's pipeline.
- getPipeline() - Method in class org.apache.beam.sdk.io.gcp.bigquery.WriteResult
-
- getPipeline() - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerWriteResult
-
- getPipeline() - Method in class org.apache.beam.sdk.io.WriteFilesResult
-
- getPipeline() - Method in class org.apache.beam.sdk.Pipeline.PipelineVisitor.Defaults
-
- getPipeline() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
- getPipeline() - Method in class org.apache.beam.sdk.transforms.WithFailures.Result
-
- getPipeline() - Method in class org.apache.beam.sdk.values.PBegin
-
- getPipeline() - Method in class org.apache.beam.sdk.values.PCollectionList
-
- getPipeline() - Method in class org.apache.beam.sdk.values.PCollectionTuple
-
- getPipeline() - Method in class org.apache.beam.sdk.values.PDone
-
- getPipeline() - Method in interface org.apache.beam.sdk.values.PInput
-
- getPipeline() - Method in interface org.apache.beam.sdk.values.POutput
-
- getPipeline() - Method in class org.apache.beam.sdk.values.PValueBase
-
- getPipelineFromClasspath(String) - Static method in class org.apache.beam.runners.fnexecution.jobsubmission.PortablePipelineJarUtils
-
- getPipelineOptions() - Method in class org.apache.beam.runners.apex.ApexRunnerRegistrar.Options
-
- getPipelineOptions() - Method in class org.apache.beam.runners.dataflow.DataflowPipelineRegistrar.Options
-
- getPipelineOptions() - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.TranslationContext
-
Returns the configured pipeline options.
- getPipelineOptions() - Method in class org.apache.beam.runners.direct.DirectRegistrar.Options
-
- getPipelineOptions() - Method in class org.apache.beam.runners.flink.FlinkBatchPortablePipelineTranslator.BatchTranslationContext
-
- getPipelineOptions() - Method in interface org.apache.beam.runners.flink.FlinkPortablePipelineTranslator.TranslationContext
-
- getPipelineOptions() - Method in class org.apache.beam.runners.flink.FlinkRunner
-
For testing.
- getPipelineOptions() - Method in class org.apache.beam.runners.flink.FlinkRunnerRegistrar.Options
-
- getPipelineOptions() - Method in class org.apache.beam.runners.flink.FlinkStreamingPortablePipelineTranslator.StreamingTranslationContext
-
- getPipelineOptions() - Method in class org.apache.beam.runners.flink.TestFlinkRunner
-
- getPipelineOptions() - Method in class org.apache.beam.runners.gearpump.GearpumpRunnerRegistrar.Options
-
- getPipelineOptions() - Method in class org.apache.beam.runners.gearpump.translators.TranslationContext
-
- getPipelineOptions() - Method in class org.apache.beam.runners.jet.JetRunnerRegistrar.Options
-
- getPipelineOptions() - Method in class org.apache.beam.runners.portability.testing.TestPortablePipelineOptions.TestPortablePipelineOptionsRegistrar
-
- getPipelineOptions() - Method in class org.apache.beam.runners.spark.SparkRunnerRegistrar.Options
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.extensions.gcp.options.GcpPipelineOptionsRegistrar
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteSchema
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlEnv
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlPipelineOptionsRegistrar
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.extensions.sql.impl.JdbcConnection
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamIOSinkRel
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamIOSourceRel
-
- getPipelineOptions() - Method in interface org.apache.beam.sdk.extensions.sql.impl.rel.BeamRelNode
-
Perform a DFS(Depth-First-Search) to find the PipelineOptions config.
- getPipelineOptions() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamValuesRel
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.datacatalog.DataCatalogPipelineOptionsRegistrar
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.io.aws.options.AwsPipelineOptionsRegistrar
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.io.aws2.options.AwsPipelineOptionsRegistrar
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.io.gcp.common.GcpIoPipelineOptionsRegistrar
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.io.hdfs.HadoopFileSystemOptionsRegistrar
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.options.DefaultPipelineOptionsRegistrar
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.options.ManualDockerEnvironmentOptions.Options
-
- getPipelineOptions() - Method in interface org.apache.beam.sdk.options.PipelineOptionsRegistrar
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.options.RemoteEnvironmentOptions.Options
-
- getPipelineOptions() - Method in interface org.apache.beam.sdk.state.StateContext
-
- getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.CombineWithContext.Context
-
Returns the
PipelineOptions
specified with the
PipelineRunner
invoking this
KeyedCombineFn
.
- getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.DoFn.FinishBundleContext
-
Returns the
PipelineOptions
specified with the
PipelineRunner
invoking this
DoFn
.
- getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.DoFn.StartBundleContext
-
Returns the
PipelineOptions
specified with the
PipelineRunner
invoking this
DoFn
.
- getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
-
Returns the
PipelineOptions
specified with the
PipelineRunner
invoking this
DoFn
.
- getPipelineOptions() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- getPipelineOptionsFromClasspath(String) - Static method in class org.apache.beam.runners.fnexecution.jobsubmission.PortablePipelineJarUtils
-
- getPipelineProto() - Method in class org.apache.beam.runners.dataflow.DataflowPipelineTranslator.JobSpecification
-
- getPipelineRunners() - Method in class org.apache.beam.runners.apex.ApexRunnerRegistrar.Runner
-
- getPipelineRunners() - Method in class org.apache.beam.runners.dataflow.DataflowPipelineRegistrar.Runner
-
- getPipelineRunners() - Method in class org.apache.beam.runners.direct.DirectRegistrar.Runner
-
- getPipelineRunners() - Method in class org.apache.beam.runners.flink.FlinkRunnerRegistrar.Runner
-
- getPipelineRunners() - Method in class org.apache.beam.runners.gearpump.GearpumpRunnerRegistrar.Runner
-
- getPipelineRunners() - Method in class org.apache.beam.runners.jet.JetRunnerRegistrar.Runner
-
- getPipelineRunners() - Method in class org.apache.beam.runners.portability.PortableRunnerRegistrar
-
- getPipelineRunners() - Method in class org.apache.beam.runners.spark.SparkRunnerRegistrar.Runner
-
- getPipelineUrl() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineOptions
-
The URL of the staged portable pipeline.
- getPlanner() - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.JoinRelOptRuleCall
-
- getPlannerName() - Method in interface org.apache.beam.sdk.extensions.sql.impl.BeamSqlPipelineOptions
-
- getPort() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobServerDriver.ServerConfiguration
-
- getPort() - Method in class org.apache.beam.sdk.fn.data.RemoteGrpcPortRead
-
- getPort() - Method in class org.apache.beam.sdk.fn.data.RemoteGrpcPortWrite
-
- getPositionForFractionConsumed(double) - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
-
Returns a position P
such that the range [start, P)
represents approximately
the given fraction of the range [start, end)
.
- getPrefix() - Method in class org.apache.beam.sdk.extensions.sql.impl.TableName
-
First element in the path.
- getPrimary() - Method in class org.apache.beam.sdk.transforms.splittabledofn.SplitResult
-
Returns the primary restriction.
- getProcessBundleDescriptor() - Method in class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors.ExecutableProcessBundleDescriptor
-
- getProcessBundleDescriptor() - Method in interface org.apache.beam.runners.fnexecution.control.StageBundleFactory
-
- getProcessingTimeAdvance() - Method in class org.apache.beam.sdk.testing.TestStream.ProcessingTimeEvent
-
- getProcessor(BeamFnApi.ProcessBundleDescriptor, Map<String, RemoteInputDestination>) - Method in class org.apache.beam.runners.fnexecution.control.SdkHarnessClient
-
Provides
SdkHarnessClient.BundleProcessor
that is capable of processing bundles not containing any state
accesses such as:
Side inputs
User state
Remote references
- getProcessor(BeamFnApi.ProcessBundleDescriptor, Map<String, RemoteInputDestination>, StateDelegator) - Method in class org.apache.beam.runners.fnexecution.control.SdkHarnessClient
-
- getProduced(ExecutableT) - Method in interface org.apache.beam.runners.direct.ExecutableGraph
-
- getProducer(PValue) - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.TranslationContext
-
Get the
AppliedPTransform
that produced the provided
PValue
.
- getProducer(CollectionT) - Method in interface org.apache.beam.runners.direct.ExecutableGraph
-
- getProfilingAgentConfiguration() - Method in interface org.apache.beam.runners.dataflow.options.DataflowProfilingOptions
-
- getProject() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineOptions
-
- getProject() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcpOptions
-
Project id to use when launching jobs.
- getProject() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSource
-
Get the project path.
- getProjectId() - Method in class org.apache.beam.runners.dataflow.DataflowPipelineJob
-
Get the project this job exists in.
- getProjectId() - Method in class org.apache.beam.runners.dataflow.util.DataflowTemplateJob
-
- getProjectId() - Method in class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.Read
-
- getProjectId() - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerConfig
-
- getProjectId() - Method in class org.apache.beam.sdk.io.gcp.testing.BigqueryMatcher.TableAndQuery
-
- getProperties() - Method in class org.apache.beam.runners.dataflow.DataflowRunnerInfo
-
- getProperties() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- getProperties() - Method in class org.apache.beam.sdk.extensions.sql.meta.Table
-
- getProperties() - Method in class org.apache.beam.sdk.io.jms.JmsRecord
-
- getProvidedSparkContext() - Method in interface org.apache.beam.runners.spark.SparkContextOptions
-
- getProviderRuntimeValues() - Method in interface org.apache.beam.sdk.testing.TestPipeline.TestValueProviderOptions
-
- getProvisionInfo(ProvisionApi.GetProvisionInfoRequest, StreamObserver<ProvisionApi.GetProvisionInfoResponse>) - Method in class org.apache.beam.runners.fnexecution.provisioning.StaticGrpcProvisionService
-
- getProxyConfiguration() - Method in interface org.apache.beam.sdk.io.aws2.options.AwsOptions
-
The client configuration instance that should be used to configure AWS service clients.
- getPTransformForInput() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaCSVTable
-
- getPTransformForInput() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaTable
-
- getPTransformForOutput() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaCSVTable
-
- getPTransformForOutput() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaTable
-
- getPTransformId() - Method in class org.apache.beam.runners.fnexecution.data.RemoteInputDestination
-
- getPubsubRootUrl() - Method in interface org.apache.beam.sdk.io.gcp.pubsub.PubsubOptions
-
Root URL for use with the Google Cloud Pub/Sub API.
- getQualifiers() - Method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
-
- getQuery() - Method in class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.Read
-
- getQuery() - Method in class org.apache.beam.sdk.io.gcp.spanner.ReadOperation
-
- getQuery() - Method in class org.apache.beam.sdk.io.gcp.testing.BigqueryMatcher.TableAndQuery
-
- getQueryString() - Method in interface org.apache.beam.sdk.extensions.sql.example.BeamSqlDataCatalogExample.DCExamplePipelineOptions
-
SQL Query.
- getRange() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
-
Returns the current range.
- getRate() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamTableStatistics
-
- getRate() - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.NodeStats
-
- getRawType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
Returns the raw class type.
- getRawType() - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns the
Class
underlying the
Type
represented by this
TypeDescriptor
.
- getReaderContext(Map<String, String>) - Static method in class org.apache.beam.sdk.io.hcatalog.test.HCatalogIOTestUtils
-
Returns a ReaderContext instance for the passed datastore config params.
- getReadTime() - Method in class org.apache.beam.sdk.io.kinesis.KinesisRecord
-
- getReadTimePercentage() - Method in interface org.apache.beam.runners.spark.SparkPipelineOptions
-
- getReason() - Method in exception org.apache.beam.sdk.coders.CannotProvideCoderException
-
- getReasons() - Method in exception org.apache.beam.sdk.coders.Coder.NonDeterministicException
-
- getReceiver() - Method in class org.apache.beam.runners.fnexecution.control.RemoteOutputReceiver
-
- getRecord() - Method in class org.apache.beam.sdk.io.gcp.bigquery.SchemaAndRecord
-
- getRecordType() - Method in class org.apache.beam.sdk.coders.SerializableCoder
-
- getReferentialConstraints() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamTableStatistics
-
- getRegion() - Method in class org.apache.beam.runners.dataflow.DataflowPipelineJob
-
Get the region this job exists in.
- getRegion() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineOptions
-
The Google Compute Engine
region for
creating Dataflow jobs.
- getRegion() - Method in interface org.apache.beam.sdk.io.aws2.options.AwsOptions
-
AWS region used by the AWS client.
- getRegisteredOptions() - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
-
- getRegistrationFuture() - Method in class org.apache.beam.runners.fnexecution.control.SdkHarnessClient.BundleProcessor
-
- getRelList() - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.JoinRelOptRuleCall
-
- getRemote() - Method in interface org.apache.beam.runners.gearpump.GearpumpPipelineOptions
-
- getRemoteInputDestinations() - Method in class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors.ExecutableProcessBundleDescriptor
-
- getRemoteOutputCoders() - Method in class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors.ExecutableProcessBundleDescriptor
-
- getRepeatedTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
-
- getReplacedByJob() - Method in class org.apache.beam.runners.dataflow.DataflowPipelineJob
-
- getReplacedByJob() - Method in class org.apache.beam.runners.dataflow.util.DataflowTemplateJob
-
- getReplacementTransform(AppliedPTransform<PCollection<? extends InputT>, PCollection<OutputT>, ParDo.SingleOutput<InputT, OutputT>>) - Method in class org.apache.beam.runners.dataflow.PrimitiveParDoSingleFactory
-
- getReplacementTransform(AppliedPTransform<PCollection<? extends InputT>, PCollectionTuple, PTransform<PCollection<? extends InputT>, PCollectionTuple>>) - Method in class org.apache.beam.runners.direct.ParDoMultiOverrideFactory
-
- getRequirements() - Method in class org.apache.beam.sdk.transforms.Contextful
-
Returns the requirements needed to run the closure.
- getResidual() - Method in class org.apache.beam.sdk.transforms.splittabledofn.SplitResult
-
Returns the residual restriction.
- getRetainDockerContainers() - Method in interface org.apache.beam.sdk.options.ManualDockerEnvironmentOptions
-
- getRetainExternalizedCheckpointsOnCancellation() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getRetrievalServiceType() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
-
- getRetrievalToken(String) - Method in class org.apache.beam.runners.fnexecution.artifact.AbstractArtifactStagingService
-
- getRetrievalToken(String) - Method in class org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService
-
- getRetrievalToken(String) - Method in class org.apache.beam.runners.fnexecution.artifact.JavaFilesystemArtifactStagingService
-
- getReturnType(RelDataTypeFactory) - Method in class org.apache.beam.sdk.extensions.sql.impl.ScalarFunctionImpl
-
- getReturnType(RelDataTypeFactory, SqlOperatorBinding) - Method in class org.apache.beam.sdk.extensions.sql.impl.ScalarFunctionImpl
-
- getReturnType(RelDataTypeFactory) - Method in class org.apache.beam.sdk.extensions.sql.impl.UdafImpl
-
- getRoot() - Method in class org.apache.beam.sdk.extensions.gcp.util.gcsfs.GcsPath
-
- getRootCause() - Method in exception org.apache.beam.sdk.coders.CannotProvideCoderException
-
- getRootSchema() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- getRootTransforms() - Method in interface org.apache.beam.runners.direct.ExecutableGraph
-
- getRow() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryInsertError
-
- getRow(String) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Schema.TypeName.ROW
value by field name,
IllegalStateException
is thrown if
schema doesn't match.
- getRow(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a
Row
value by field index,
IllegalStateException
is thrown if schema
doesn't match.
- getRowCount() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamTableStatistics
-
- getRowCount() - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.NodeStats
-
- getRowReceiver(TupleTag<T>) - Method in interface org.apache.beam.sdk.transforms.DoFn.MultiOutputReceiver
-
- getRows() - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamCostModel
-
- getRows() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestTableProvider.TableWithRows
-
- getRowSchema() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
- getRowsWritten() - Method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableWriteResult
-
The number of rows written in this batch.
- getRowToGenericRecordFunction(Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
-
- getRowType(RelDataTypeFactory) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteTable
-
- getRule() - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.JoinRelOptRuleCall
-
- getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.ArrayQualifierContext
-
- getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionComponentContext
-
- getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.DotExpressionContext
-
- getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.FieldSpecifierContext
-
- getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.MapQualifierContext
-
- getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
-
- getRuleIndex() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifierListContext
-
- getRuleNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
-
- getRuleNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
-
- getRuleSets() - Static method in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamRuleSets
-
- getRunMillis() - Method in interface org.apache.beam.runners.apex.ApexPipelineOptions
-
- getRunner() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
The pipeline runner that will be used to execute the pipeline.
- getS3ClientFactoryClass() - Method in interface org.apache.beam.sdk.io.aws.options.S3Options
-
- getS3StorageClass() - Method in interface org.apache.beam.sdk.io.aws.options.S3Options
-
- getS3ThreadPoolSize() - Method in interface org.apache.beam.sdk.io.aws.options.S3Options
-
- getS3UploadBufferSizeBytes() - Method in interface org.apache.beam.sdk.io.aws.options.S3Options
-
- getSamplingStrategy() - Method in class org.apache.beam.sdk.io.TextRowCountEstimator
-
- getSaveHeapDumpsToGcsPath() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineDebugOptions
-
CAUTION: This option implies dumpHeapOnOOM, and has similar caveats.
- getSavepointPath() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- getSaveProfilesToGcs() - Method in interface org.apache.beam.runners.dataflow.options.DataflowProfilingOptions
-
- getScan() - Method in class org.apache.beam.sdk.io.hbase.HBaseIO.Read
-
- getScan() - Method in class org.apache.beam.sdk.io.hbase.HBaseQuery
-
- getSchema() - Method in class org.apache.beam.sdk.coders.AvroCoder
-
Returns the schema used by this coder.
- getSchema() - Method in class org.apache.beam.sdk.extensions.protobuf.ProtoDynamicMessageSchema
-
- getSchema() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- getSchema() - Method in interface org.apache.beam.sdk.extensions.sql.meta.BeamSqlTable
-
Get the schema info of the table.
- getSchema() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.hcatalog.HCatalogTable
-
- getSchema() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.pubsub.PubsubJsonTableProvider.PubsubIOTableConfiguration
-
Table schema, describes Pubsub message schema.
- getSchema() - Method in class org.apache.beam.sdk.extensions.sql.meta.SchemaBaseBeamTable
-
- getSchema() - Method in class org.apache.beam.sdk.extensions.sql.meta.Table
-
- getSchema(DestinationT) - Method in class org.apache.beam.sdk.io.DynamicAvroDestinations
-
Return an AVRO schema for a given destination.
- getSchema() - Method in class org.apache.beam.sdk.io.gcp.bigquery.AvroWriteRequest
-
- getSchema(DestinationT) - Method in class org.apache.beam.sdk.io.gcp.bigquery.DynamicDestinations
-
Returns the table schema for the destination.
- getSchema() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
-
Returns the schema associated with this type.
- getSchema(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Get a schema for a given Class
type.
- getSchema(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
- getSchema(Class<T>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
-
- getSchema() - Method in class org.apache.beam.sdk.schemas.utils.ReflectUtils.ClassWithSchema
-
- getSchema() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
-
- getSchema() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
- getSchema() - Method in class org.apache.beam.sdk.values.PCollection
-
Returns the attached schema.
- getSchema() - Method in class org.apache.beam.sdk.values.Row.Builder
-
- getSchema() - Method in class org.apache.beam.sdk.values.Row
-
Return
Schema
which describes the fields.
- getSchemaProviders() - Method in class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProviderRegistrar
-
- getSchemaProviders() - Method in interface org.apache.beam.sdk.schemas.SchemaProviderRegistrar
-
- getSchemaRegistry() - Method in class org.apache.beam.sdk.Pipeline
-
- getScheme() - Method in class org.apache.beam.sdk.extensions.gcp.storage.GcsResourceId
-
- getScheme() - Method in class org.apache.beam.sdk.io.FileSystem
-
Get the URI scheme which defines the namespace of the
FileSystem
.
- getScheme() - Method in interface org.apache.beam.sdk.io.fs.ResourceId
-
Get the scheme which defines the namespace of the
ResourceId
.
- getSdkComponents() - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.TranslationContext
-
- getSdkHarnessLogLevelOverrides() - Method in interface org.apache.beam.sdk.options.SdkHarnessOptions
-
This option controls the log levels for specifically named loggers.
- getSdkWorkerId() - Method in interface org.apache.beam.runners.fnexecution.HeaderAccessor
-
This method should be called from the request method.
- getSdkWorkerParallelism() - Method in interface org.apache.beam.sdk.options.PortablePipelineOptions
-
- getSemiPersistDir() - Method in interface org.apache.beam.sdk.options.RemoteEnvironmentOptions
-
- getSequenceNumber() - Method in class org.apache.beam.sdk.io.kinesis.KinesisRecord
-
- getSerializableFunctionUdfs() - Method in interface org.apache.beam.sdk.extensions.sql.meta.provider.UdfUdafProvider
-
- getSerializableOptions() - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.TranslationContext
-
- getSerializedATN() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
-
- getSerializedATN() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
-
- getSerializers() - Method in interface org.apache.beam.runners.gearpump.GearpumpPipelineOptions
-
- getServer() - Method in class org.apache.beam.runners.fnexecution.GrpcFnServer
-
- getServerFactory() - Method in class org.apache.beam.runners.fnexecution.environment.DockerEnvironmentFactory.Provider
-
- getServerFactory() - Method in class org.apache.beam.runners.fnexecution.environment.EmbeddedEnvironmentFactory.Provider
-
- getServerFactory() - Method in interface org.apache.beam.runners.fnexecution.environment.EnvironmentFactory.Provider
-
- getServerFactory() - Method in class org.apache.beam.runners.fnexecution.environment.ExternalEnvironmentFactory.Provider
-
- getService() - Method in class org.apache.beam.runners.fnexecution.GrpcFnServer
-
- getServiceAccount() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineOptions
-
Run the job as a specific service account, instead of the default GCE robot.
- getSessionId() - Method in class org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService.StagingSessionToken
-
Access is public for json conversion.
- getSetFieldCreator(Class<T>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
-
- getSetters(Class<?>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
-
- getSetters(Class<?>, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
-
- getSetTimers() - Method in class org.apache.beam.runners.direct.WatermarkManager.TimerUpdate
-
- getShard() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
-
- getShardId() - Method in class org.apache.beam.sdk.io.kinesis.KinesisRecord
-
- getShardingFunction() - Method in class org.apache.beam.sdk.io.WriteFiles
-
- getShardNumber() - Method in class org.apache.beam.sdk.values.ShardedKey
-
- getShortValue() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
Return the optional short value for an item, or null if none is provided.
- getShortValue() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
The optional short value for an item, or null
if none is provided.
- getSideInput(String) - Method in interface org.apache.beam.runners.fnexecution.translation.BatchSideInputHandlerFactory.SideInputGetter
-
- getSideInputDataSet(PCollectionView<?>) - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.TranslationContext
-
- getSideInputs() - Method in class org.apache.beam.runners.dataflow.PrimitiveParDoSingleFactory.ParDoSingle
-
- getSideInputs(ExecutableStage) - Static method in class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors
-
- getSideInputs() - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
-
Override to specify that this object needs access to one or more side inputs.
- getSideInputs() - Method in class org.apache.beam.sdk.io.gcp.bigquery.DynamicDestinations
-
Specifies that this object needs access to one or more side inputs.
- getSideInputs() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
Returns the side inputs used by this Combine operation.
- getSideInputs() - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
-
- getSideInputs() - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
-
Returns the side inputs used by this Combine operation.
- getSideInputs() - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
-
- getSideInputs() - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
-
- getSideInputs() - Method in class org.apache.beam.sdk.transforms.Requirements
-
The side inputs that this
Contextful
needs access to.
- getSideInputSpecs() - Method in class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors.ExecutableProcessBundleDescriptor
-
Get a mapping from PTransform id to side input id to
side inputs
that
are used during execution.
- getSideInputWindow(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.WindowMappingFn
-
Returns the window of the side input corresponding to the given window of the main input.
- getSingleFileMetadata() - Method in class org.apache.beam.sdk.io.FileBasedSource
-
Returns the information about the single file that this source is reading from.
- getSingleWorkerStatus(String, long, TimeUnit) - Method in class org.apache.beam.runners.fnexecution.status.BeamWorkerStatusGrpcService
-
Get the latest SDK worker status from the client's corresponding SDK harness.
- getSink() - Method in interface org.apache.beam.runners.fnexecution.control.ControlClientPool
-
Sink for control clients.
- getSink() - Method in class org.apache.beam.runners.fnexecution.control.MapControlClientPool
-
- getSink() - Method in class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
-
Returns the FileBasedSink for this write operation.
- getSink() - Method in class org.apache.beam.sdk.io.WriteFiles
-
- getSize() - Method in class org.apache.beam.sdk.schemas.utils.AvroUtils.FixedBytesField
-
Get the size.
- getSize() - Method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
-
- getSize() - Method in class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
-
- getSize() - Method in interface org.apache.beam.sdk.transforms.splittabledofn.Sizes.HasSize
-
A representation for the amount of known work represented as a size.
- getSize() - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
-
- getSize() - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
-
- getSizeLimit(PipelineOptions) - Static method in interface org.apache.beam.sdk.fn.data.BeamFnDataBufferingOutboundObserver
-
- getSketchFromByteBuffer(ByteBuffer) - Static method in class org.apache.beam.sdk.extensions.zetasketch.HllCount
-
Converts the passed-in sketch from ByteBuffer
to byte[]
, mapping null
ByteBuffer
s (representing empty sketches) to empty byte[]
s.
- getSnsClient() - Method in interface org.apache.beam.sdk.io.aws2.sns.SnsClientProvider
-
- getSocketTimeout() - Method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.ConnectionConfiguration
-
- getSorterType() - Method in class org.apache.beam.sdk.extensions.sorter.ExternalSorter.Options
-
Returns the sorter type.
- getSource() - Method in interface org.apache.beam.runners.fnexecution.control.ControlClientPool
-
Source of control clients.
- getSource() - Method in class org.apache.beam.runners.fnexecution.control.MapControlClientPool
-
- getSource() - Method in class org.apache.beam.sdk.io.Read.Bounded
-
Returns the BoundedSource
used to create this Read
PTransform
.
- getSource() - Method in class org.apache.beam.sdk.io.Read.Unbounded
-
Returns the UnboundedSource
used to create this Read
PTransform
.
- getSource() - Method in class org.apache.beam.sdk.io.TextIO.Read
-
- getSource() - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
-
- getSourceStream(DataSource) - Method in class org.apache.beam.runners.gearpump.translators.TranslationContext
-
- getSparkMaster() - Method in interface org.apache.beam.runners.spark.SparkCommonPipelineOptions
-
- getSparkSession() - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.TranslationContext
-
- getSplit() - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.SerializableSplit
-
- getSplitBacklogBytes() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
-
Returns the size of the backlog of unread data in the underlying data source represented by
this split of this source.
- getSplitPointsConsumed() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
-
- getSplitPointsConsumed() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
-
- getSplitPointsConsumed() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
-
- getSplitPointsConsumed() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
-
- getSplitPointsProcessed() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
-
Returns the total number of split points that have been processed.
- getSplitPointsRemaining() - Method in class org.apache.beam.sdk.io.AvroSource.AvroReader
-
- getSplitPointsRemaining() - Method in class org.apache.beam.sdk.io.BoundedSource.BoundedReader
-
- getSplitPointsRemaining() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
-
- getSplitPointsRemaining() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
-
- getSqsClient() - Method in interface org.apache.beam.sdk.io.aws2.sqs.SqsClientProvider
-
- getSSEAlgorithm() - Method in interface org.apache.beam.sdk.io.aws.options.S3Options
-
- getSSEAwsKeyManagementParams() - Method in interface org.apache.beam.sdk.io.aws.options.S3Options
-
- getSSECustomerKey() - Method in interface org.apache.beam.sdk.io.aws.options.S3Options
-
- getStableUniqueNames() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
Whether to check for stable unique names on each transform.
- getStageBundleFactory(ExecutableStage) - Method in class org.apache.beam.runners.fnexecution.control.DefaultExecutableStageContext
-
- getStageBundleFactory(ExecutableStage) - Method in interface org.apache.beam.runners.fnexecution.control.ExecutableStageContext
-
- getStager() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineDebugOptions
-
The resource stager instance that should be used to stage resources.
- getStagerClass() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineDebugOptions
-
The class responsible for staging resources to be accessible by workers during job execution.
- getStagingLocation() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineOptions
-
GCS path for staging local files, e.g.
- getStartDate() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
-
- getStartDate() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
-
- getStartDate() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
-
- getStartKey() - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
-
- getStartOffset() - Method in class org.apache.beam.sdk.io.OffsetBasedSource
-
Returns the starting offset of the source.
- getStartPosition() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
-
- getStartPosition() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
-
- getStartPosition() - Method in interface org.apache.beam.sdk.io.range.RangeTracker
-
Returns the starting position of the current range, inclusive.
- getStartTime() - Method in class org.apache.beam.sdk.io.CountingSource.CounterMark
-
Returns the time the reader was started.
- getState() - Method in class org.apache.beam.runners.apex.ApexRunnerResult
-
- getState() - Method in class org.apache.beam.runners.dataflow.DataflowPipelineJob
-
- getState() - Method in class org.apache.beam.runners.dataflow.util.DataflowTemplateJob
-
- getState() - Method in class org.apache.beam.runners.direct.DirectRunner.DirectPipelineResult
-
- getState() - Method in class org.apache.beam.runners.flink.FlinkDetachedRunnerResult
-
- getState() - Method in class org.apache.beam.runners.flink.FlinkRunnerResult
-
- getState(JobApi.GetJobStateRequest, StreamObserver<JobApi.JobStateEvent>) - Method in class org.apache.beam.runners.fnexecution.jobsubmission.InMemoryJobService
-
- getState() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobInvocation
-
Retrieve the job's current state.
- getState() - Method in class org.apache.beam.runners.gearpump.GearpumpPipelineResult
-
- getState() - Method in class org.apache.beam.runners.jet.FailedRunningPipelineResults
-
- getState() - Method in class org.apache.beam.runners.jet.JetPipelineResult
-
- getState(JobApi.GetJobStateRequest, StreamObserver<JobApi.JobStateEvent>) - Method in class org.apache.beam.runners.portability.testing.TestJobService
-
- getState() - Method in class org.apache.beam.runners.spark.SparkPipelineResult
-
- getState() - Method in class org.apache.beam.runners.spark.structuredstreaming.SparkStructuredStreamingPipelineResult
-
- getState() - Method in interface org.apache.beam.sdk.PipelineResult
-
Retrieves the current state of the pipeline execution.
- getStateBackendFactory() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
State backend to store Beam's state during computation.
- getStateCoder() - Method in interface org.apache.beam.sdk.transforms.Watch.Growth.TerminationCondition
-
- getStateEvent() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobInvocation
-
Retrieve the job's current state.
- getStateStream(JobApi.GetJobStateRequest, StreamObserver<JobApi.JobStateEvent>) - Method in class org.apache.beam.runners.fnexecution.jobsubmission.InMemoryJobService
-
- getStaticCreator(Class, Method, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.JavaBeanUtils
-
- getStaticCreator(Class, Method, Schema, FieldValueTypeSupplier, ByteBuddyUtils.TypeConversionsFactory) - Static method in class org.apache.beam.sdk.schemas.utils.POJOUtils
-
- getStatistic() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteTable
-
- getStepNames() - Method in class org.apache.beam.runners.dataflow.DataflowPipelineTranslator.JobSpecification
-
Returns the mapping of AppliedPTransforms
to the internal step name
for that AppliedPTransform
.
- getStopPipelineWatermark() - Method in interface org.apache.beam.runners.spark.TestSparkPipelineOptions
-
- getStopPosition() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
-
- getStopPosition() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
-
- getStopPosition() - Method in interface org.apache.beam.sdk.io.range.RangeTracker
-
Returns the ending position of the current range, exclusive.
- getStorageClient(BigQueryOptions) - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryServices
-
- getStorageClient(BigQueryOptions) - Method in class org.apache.beam.sdk.io.gcp.testing.FakeBigQueryServices
-
- getStorageLevel() - Method in interface org.apache.beam.runners.spark.SparkPipelineOptions
-
- getStreamName() - Method in class org.apache.beam.sdk.io.kinesis.KinesisRecord
-
- getString(Map<String, Object>, String) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getString(Map<String, Object>, String, String) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getString(String) - Method in class org.apache.beam.sdk.values.Row
-
- getString(int) - Method in class org.apache.beam.sdk.values.Row
-
Get a String
value by field index, ClassCastException
is thrown if schema
doesn't match.
- getStrings(Map<String, Object>, String, List<String>) - Static method in class org.apache.beam.runners.dataflow.util.Structs
-
- getSubnetwork() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineWorkerPoolOptions
-
- getSubProvider(String) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.FullNameTableProvider
-
- getSubProvider(String) - Method in interface org.apache.beam.sdk.extensions.sql.meta.provider.TableProvider
-
Returns a sub-provider, e.g.
- getSubProviders() - Method in interface org.apache.beam.sdk.extensions.sql.meta.provider.TableProvider
-
Returns all sub-providers, e.g.
- getSubSchema(String) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteSchema
-
- getSubSchemaNames() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteSchema
-
- getSubscription() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSource
-
Get the subscription being read from.
- getSubscriptionProvider() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSource
-
- getSubSequenceNumber() - Method in class org.apache.beam.sdk.io.kinesis.KinesisRecord
-
- getSuggestedFilenameSuffix() - Method in enum org.apache.beam.sdk.io.FileBasedSink.CompressionType
-
Deprecated.
- getSuggestedFilenameSuffix() - Method in interface org.apache.beam.sdk.io.FileBasedSink.OutputFileHints
-
- getSuggestedSuffix() - Method in enum org.apache.beam.sdk.io.Compression
-
- getSum() - Method in class org.apache.beam.sdk.metrics.DistributionResult
-
- getSum() - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
-
- getSumAndReset() - Method in class org.apache.beam.sdk.testing.CoderProperties.TestElementByteSizeObserver
-
- getSupertype(Class<? super T>) - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns the generic form of a supertype.
- getSupported() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryFilter
-
- getSupported() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestTableFilter
-
- getSupportedClass() - Method in interface org.apache.beam.runners.dataflow.util.CloudObjectTranslator
-
- getSupportedClass() - Method in class org.apache.beam.runners.dataflow.util.SchemaCoderCloudObjectTranslator
-
- getSynchronizedProcessingInputTime() - Method in class org.apache.beam.runners.direct.WatermarkManager.TransformWatermarks
-
Returns the synchronized processing input time of the AppliedPTransform
.
- getSynchronizedProcessingOutputTime() - Method in class org.apache.beam.runners.direct.WatermarkManager.TransformWatermarks
-
Returns the synchronized processing output time of the AppliedPTransform
.
- getSynchronizedProcessingOutputWatermark() - Method in interface org.apache.beam.runners.local.Bundle
-
Returns the processing time output watermark at the time the producing Executable
committed this bundle.
- getSynchronizedProcessingTime() - Method in class org.apache.beam.runners.spark.util.GlobalWatermarkHolder.SparkWatermarks
-
- getTable(String) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteSchema
-
- getTable(String) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.datacatalog.DataCatalogTableProvider
-
- getTable(String) - Method in interface org.apache.beam.sdk.extensions.sql.meta.provider.TableProvider
-
Get a specific table from this provider it is present, or null if it is not present.
- getTable() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryInsertError
-
- getTable() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.Read
-
Returns the table to read, or null
if reading from a query instead.
- getTable() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.TypedRead
-
- getTable() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.Write
-
Returns the table reference, or null
.
- getTable(TableReference) - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryServices.DatasetService
-
Gets the specified
Table
resource by table ID.
- getTable(TableReference, List<String>) - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryServices.DatasetService
-
- getTable(DestinationT) - Method in class org.apache.beam.sdk.io.gcp.bigquery.DynamicDestinations
-
- getTable() - Method in class org.apache.beam.sdk.io.gcp.spanner.ReadOperation
-
- getTable(TableReference) - Method in class org.apache.beam.sdk.io.gcp.testing.FakeDatasetService
-
- getTable(TableReference, List<String>) - Method in class org.apache.beam.sdk.io.gcp.testing.FakeDatasetService
-
- getTableByFullName(TableName) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.datacatalog.DataCatalogTableProvider
-
- getTableByFullName(TableName) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.FullNameTableProvider
-
- getTableDescription() - Method in class org.apache.beam.sdk.io.gcp.bigquery.TableDestination
-
- getTableId() - Method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableIO.Read
-
Returns the table being read from.
- getTableId() - Method in class org.apache.beam.sdk.io.hbase.HBaseIO.Read
-
- getTableId() - Method in class org.apache.beam.sdk.io.hbase.HBaseIO.Write
-
- getTableId() - Method in class org.apache.beam.sdk.io.hbase.HBaseQuery
-
- getTableName() - Method in class org.apache.beam.sdk.extensions.sql.impl.TableName
-
Table name, the last element of the fully-specified table name with path.
- getTableNames() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteSchema
-
- getTablePath(Table) - Method in class org.apache.beam.sdk.extensions.sql.zetasql.QueryTrait
-
Returns a full table path (exlucding top-level schema) for a given ZetaSQL Table.
- getTableProvider() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteSchema
-
- getTableProvider() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.Read
-
Returns the table to read, or null
if reading from a query instead.
- getTableProvider() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.TypedRead
-
- getTableReference() - Method in class org.apache.beam.sdk.io.gcp.bigquery.TableDestination
-
- getTableResource(String, String, String) - Method in class org.apache.beam.sdk.io.gcp.testing.BigqueryClient
-
- getTables() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.datacatalog.DataCatalogTableProvider
-
- getTables() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.InMemoryMetaTableProvider
-
- getTables() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.ReadOnlyTableProvider
-
- getTables() - Method in interface org.apache.beam.sdk.extensions.sql.meta.provider.TableProvider
-
Get all tables from this provider.
- getTables() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestTableProvider
-
- getTables() - Method in class org.apache.beam.sdk.extensions.sql.meta.store.InMemoryMetaStore
-
- getTableSchema(String, String) - Static method in class org.apache.beam.sdk.io.clickhouse.ClickHouseIO
-
- getTableSchema() - Method in class org.apache.beam.sdk.io.gcp.bigquery.SchemaAndRecord
-
- getTableSchema(String, String) - Method in class org.apache.beam.sdk.io.hcatalog.HCatalogBeamSchema
-
Gets the table schema, or absent optional if the table doesn't exist in the database.
- getTableSpec() - Method in class org.apache.beam.sdk.io.gcp.bigquery.TableDestination
-
- getTableStatistics(PipelineOptions) - Method in class org.apache.beam.sdk.extensions.sql.impl.schema.BeamPCollectionTable
-
- getTableStatistics(PipelineOptions) - Method in interface org.apache.beam.sdk.extensions.sql.meta.BeamSqlTable
-
Estimates the number of rows or the rate for unbounded Tables.
- getTableStatistics(PipelineOptions) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.avro.AvroTable
-
- getTableStatistics(PipelineOptions) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.hcatalog.HCatalogTable
-
- getTableStatistics(PipelineOptions) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaTable
-
- getTableStatistics(PipelineOptions) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.mongodb.MongoDbTable
-
- getTableStatistics(PipelineOptions) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.parquet.ParquetTable
-
- getTableStatistics(PipelineOptions) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestBoundedTable
-
- getTableStatistics(PipelineOptions) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestUnboundedTable
-
- getTableStatistics(PipelineOptions) - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.text.TextTable
-
- getTableType() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.avro.AvroTableProvider
-
- getTableType() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTableProvider
-
- getTableType() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.datacatalog.DataCatalogTableProvider
-
- getTableType() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.datastore.DataStoreV1TableProvider
-
- getTableType() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.KafkaTableProvider
-
- getTableType() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.mongodb.MongoDbTableProvider
-
- getTableType() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.parquet.ParquetTableProvider
-
- getTableType() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.pubsub.PubsubJsonTableProvider
-
- getTableType() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.ReadOnlyTableProvider
-
- getTableType() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.seqgen.GenerateSequenceTableProvider
-
- getTableType() - Method in interface org.apache.beam.sdk.extensions.sql.meta.provider.TableProvider
-
Gets the table type this provider handles.
- getTableType() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestTableProvider
-
- getTableType() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.text.TextTableProvider
-
- getTableType() - Method in class org.apache.beam.sdk.extensions.sql.meta.store.InMemoryMetaStore
-
- getTag(int) - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
-
Returns the tuple tag at the given index.
- getTag() - Method in class org.apache.beam.sdk.values.TaggedPValue
-
Returns the local tag associated with the
PValue
.
- getTagInternal() - Method in interface org.apache.beam.sdk.values.PCollectionView
-
- getTagInternal() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
-
- getTagsToSideInputs(Collection<PCollectionView<?>>) - Static method in class org.apache.beam.runners.gearpump.translators.utils.TranslatorUtils
-
- getTargetDataset() - Method in interface org.apache.beam.sdk.io.gcp.bigquery.TestBigQueryOptions
-
- getTargetParallelism() - Method in interface org.apache.beam.runners.direct.DirectOptions
-
- getTargetTable(BigQueryOptions) - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageQuerySource
-
- getTargetTable(BigQueryOptions) - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageTableSource
-
- getTempDatasetId() - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryOptions
-
- getTempDirectoryProvider() - Method in class org.apache.beam.sdk.io.FileBasedSink
-
- getTempFilename() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
-
- getTemplateLocation() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineOptions
-
Where the runner should generate a template file.
- getTempLocation() - Method in class org.apache.beam.sdk.extensions.sorter.BufferedExternalSorter.Options
-
Returns the configured temporary location.
- getTempLocation() - Method in class org.apache.beam.sdk.extensions.sorter.ExternalSorter.Options
-
Returns the configured temporary location.
- getTempLocation() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
A pipeline level default location for storing temporary files.
- getTempRoot() - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
-
- GetterBasedSchemaProvider - Class in org.apache.beam.sdk.schemas
-
- GetterBasedSchemaProvider() - Constructor for class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
-
- GetterTypeSupplier() - Constructor for class org.apache.beam.sdk.schemas.JavaBeanSchema.GetterTypeSupplier
-
- getTestMode() - Method in interface org.apache.beam.runners.spark.structuredstreaming.SparkStructuredStreamingPipelineOptions
-
Set to true to run the job in test mode.
- getTestTimeoutSeconds() - Method in interface org.apache.beam.sdk.testing.TestPipelineOptions
-
- getTimeDomain() - Method in interface org.apache.beam.sdk.state.TimerSpec
-
- getTimeLimit(PipelineOptions) - Static method in interface org.apache.beam.sdk.fn.data.BeamFnDataBufferingOutboundObserver
-
- getTimePartitioning() - Method in class org.apache.beam.sdk.io.gcp.bigquery.TableDestination
-
- getTimers() - Method in class org.apache.beam.runners.direct.WatermarkManager.FiredTimers
-
Gets all of the timers that have fired within the provided
TimeDomain
.
- getTimers(MetricFilter) - Method in class org.apache.beam.runners.spark.metrics.WithMetricsSupport
-
- getTimers() - Method in class org.apache.beam.runners.spark.stateful.SparkTimerInternals
-
- getTimers(MetricFilter) - Method in class org.apache.beam.runners.spark.structuredstreaming.metrics.WithMetricsSupport
-
- getTimerSpec() - Method in class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors.TimerSpec
-
- getTimerSpecs() - Method in class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors.ExecutableProcessBundleDescriptor
-
Get a mapping from PTransform id to timer id to
timer specs
that are used
during execution.
- getTimes() - Method in class org.apache.beam.runners.spark.io.CreateStream
-
- getTimestamp(T, Instant) - Method in interface org.apache.beam.sdk.io.kafka.KafkaPublishTimestampFunction
-
Returns timestamp for element being published to Kafka.
- getTimestamp() - Method in class org.apache.beam.sdk.io.kafka.KafkaRecord
-
- getTimestamp() - Method in class org.apache.beam.sdk.metrics.GaugeResult.EmptyGaugeResult
-
- getTimestamp() - Method in class org.apache.beam.sdk.metrics.GaugeResult
-
- getTimestamp() - Method in class org.apache.beam.sdk.values.TimestampedValue
-
- getTimestamp() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
-
Returns the timestamp of this ValueInSingleWindow
.
- getTimestampAttribute() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSink
-
Get the timestamp attribute.
- getTimestampAttribute() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSource
-
Get the timestamp attribute.
- getTimestampCombiner() - Method in interface org.apache.beam.sdk.state.WatermarkHoldState
-
Return the
TimestampCombiner
which will be used to determine a watermark hold time
given an element timestamp, and to combine watermarks from windows which are about to be
merged.
- getTimestampCombiner() - Method in class org.apache.beam.sdk.values.WindowingStrategy
-
- getTimestampForRecord(TimestampPolicy.PartitionContext, KafkaRecord<K, V>) - Method in class org.apache.beam.sdk.io.kafka.CustomTimestampPolicyWithLimitedDelay
-
- getTimestampForRecord(TimestampPolicy.PartitionContext, KafkaRecord<K, V>) - Method in class org.apache.beam.sdk.io.kafka.TimestampPolicy
-
Returns record timestamp (aka event time).
- getTimestampForRecord(TimestampPolicy.PartitionContext, KafkaRecord<K, V>) - Method in class org.apache.beam.sdk.io.kafka.TimestampPolicyFactory.LogAppendTimePolicy
-
- getTimestampForRecord(TimestampPolicy.PartitionContext, KafkaRecord<K, V>) - Method in class org.apache.beam.sdk.io.kafka.TimestampPolicyFactory.ProcessingTimePolicy
-
- getTimestampForRecord(TimestampPolicy.PartitionContext, KafkaRecord<K, V>) - Method in class org.apache.beam.sdk.io.kafka.TimestampPolicyFactory.TimestampFnPolicy
-
- getTimestampTransforms() - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
-
The transforms applied to the arrival time of an element to determine when this trigger allows
output.
- getTimestampType() - Method in class org.apache.beam.sdk.io.kafka.KafkaRecord
-
- getTimeZone() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
-
- getTimeZone() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
-
- getTimeZone() - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
-
- getTiming() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
Return the timing of this pane.
- getTo() - Method in class org.apache.beam.sdk.io.range.OffsetRange
-
- getTokenNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
-
Deprecated.
- getTokenNames() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
-
Deprecated.
- getTopic() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSink
-
Get the topic being written to.
- getTopic() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSource
-
Get the topic being read from.
- getTopic() - Method in class org.apache.beam.sdk.io.kafka.KafkaCheckpointMark.PartitionMark
-
- getTopic() - Method in class org.apache.beam.sdk.io.kafka.KafkaRecord
-
- getTopicProvider() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSink
-
- getTopicProvider() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSource
-
- getTopics() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaTable
-
- getToRowFunction() - Method in class org.apache.beam.sdk.extensions.protobuf.ProtoDynamicMessageSchema
-
- getToRowFunction() - Method in class org.apache.beam.sdk.schemas.SchemaCoder
-
Returns the fromRow conversion function.
- getToRowFunction(Class<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Rerieve the function that converts an object of the specified type to a
Row
object.
- getToRowFunction(TypeDescriptor<T>) - Method in class org.apache.beam.sdk.schemas.SchemaRegistry
-
Rerieve the function that converts an object of the specified type to a
Row
object.
- getToRowFunction(Class<T>, Schema) - Static method in class org.apache.beam.sdk.schemas.utils.AvroUtils
-
- getToRowFunction() - Method in class org.apache.beam.sdk.values.PCollection
-
Returns the attached schema's toRowFunction.
- getTotalBacklogBytes() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
-
Returns the size of the backlog of unread data in the underlying data source represented by
all splits of this source.
- getTraitDef() - Method in enum org.apache.beam.sdk.extensions.sql.impl.rel.BeamLogicalConvention
-
- getTransactionIsolation() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- getTransformId() - Method in class org.apache.beam.sdk.fn.data.LogicalEndpoint
-
- getTransformingMap(Map<K1, V1>, Function<K1, K2>, Function<V1, V2>) - Static method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils
-
- getTransformNameMapping() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineDebugOptions
-
Mapping of old PTranform names to new ones, specified as JSON {"oldName":"newName",...}
.
- getTransformPayloadTranslators() - Method in class org.apache.beam.runners.dataflow.PrimitiveParDoSingleFactory.Registrar
-
- getTransformTranslator(Class<TransformT>) - Method in class org.apache.beam.runners.dataflow.DataflowPipelineTranslator
-
Returns the
TransformTranslator
to use for instances of the specified PTransform class,
or null if none registered.
- getTransformTranslator(TransformHierarchy.Node) - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.batch.PipelineTranslatorBatch
-
Returns a translator for the given node, if it is possible, otherwise null.
- getTransformTranslator(TransformHierarchy.Node) - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.PipelineTranslator
-
- getTransformTranslator(TransformHierarchy.Node) - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.streaming.PipelineTranslatorStreaming
-
Returns a translator for the given node, if it is possible, otherwise null.
- getTranslationContext() - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.PipelineTranslator
-
- getTranslator() - Method in class org.apache.beam.runners.dataflow.DataflowRunner
-
Returns the DataflowPipelineTranslator associated with this object.
- getTransport() - Static method in class org.apache.beam.sdk.extensions.gcp.util.Transport
-
- getTrigger() - Method in class org.apache.beam.sdk.values.WindowingStrategy
-
- getTruncateTimestamps() - Method in interface org.apache.beam.sdk.extensions.sql.meta.provider.datacatalog.DataCatalogPipelineOptions
-
Whether to truncate timestamps in tables described by Data Catalog.
- getTruncateTimestamps() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryUtils.ConversionOptions
-
- getTupleTag() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple.TaggedKeyedPCollection
-
Returns the TupleTag of this TaggedKeyedPCollection.
- getTupleTagId(PValue) - Static method in class org.apache.beam.runners.jet.Utils
-
- getTupleTagList() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
-
Returns the TupleTagList tuple associated with this schema.
- getType() - Method in class org.apache.beam.sdk.coders.AvroCoder
-
Returns the type this coder encodes/decodes.
- getType(String) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteSchema
-
- getType() - Method in class org.apache.beam.sdk.extensions.sql.meta.Table
-
type of the table.
- getType() - Method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.ConnectionConfiguration
-
- getType() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
Returns the field type.
- getType() - Method in class org.apache.beam.sdk.schemas.Schema.Field
-
- getType() - Method in interface org.apache.beam.sdk.testing.TestStream.Event
-
- getType() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
- getType() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
- getType() - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
- getTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.ViewFn
-
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollection
-
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn
-
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.ListViewFn
-
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.MapViewFn
-
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn
-
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
-
- getTypeDescriptor() - Method in class org.apache.beam.sdk.values.TupleTag
-
Returns a TypeDescriptor
capturing what is known statically about the type of this
TupleTag
instance's most-derived class.
- getTypeFactory() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- getTypeFactory() - Method in class org.apache.beam.sdk.extensions.sql.zetasql.ZetaSQLPlannerImpl
-
- getTypeMap() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- getTypeName() - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
- getTypeNames() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteSchema
-
- getTypeParameter(String) - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns a TypeVariable
for the named type parameter.
- getTypes() - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns a set of
TypeDescriptor
, one for each superclass as well as each
interface implemented by this class.
- getUdafs() - Method in interface org.apache.beam.sdk.extensions.sql.meta.provider.UdfUdafProvider
-
- getUnderlyingDoFn() - Method in class org.apache.beam.runners.dataflow.BatchStatefulParDoOverrides.BatchStatefulDoFn
-
- getUnionCoder() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
-
- getUnionTag() - Method in class org.apache.beam.runners.gearpump.translators.utils.TranslatorUtils.RawUnionValue
-
- getUnionTag() - Method in class org.apache.beam.sdk.transforms.join.RawUnionValue
-
- getUniqueId() - Method in class org.apache.beam.sdk.io.kinesis.KinesisRecord
-
- getUntilTrigger() - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
-
The trigger that signals termination of this trigger.
- getUrn(PrimitiveParDoSingleFactory.ParDoSingle<?, ?>) - Method in class org.apache.beam.runners.dataflow.PrimitiveParDoSingleFactory.PayloadTranslator
-
- getUrn() - Method in interface org.apache.beam.sdk.transforms.Materialization
-
- getUseGrpcForGcs() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcsOptions
-
If true, uses gRPC as the transport.
- getUsePublicIps() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineWorkerPoolOptions
-
Specifies whether worker pools should be started with public IP addresses.
- getUserAgent() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
A user agent string as per RFC2616, describing the pipeline to external services.
- getUsername() - Method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.ConnectionConfiguration
-
- getUsesProvidedSparkContext() - Method in interface org.apache.beam.runners.spark.SparkPipelineOptions
-
- getUsingStandardSql() - Method in class org.apache.beam.sdk.io.gcp.testing.BigqueryMatcher.TableAndQuery
-
- getUUID() - Method in class org.apache.beam.sdk.schemas.Schema
-
Get this schema's UUID.
- getV1Beta1Path() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.SubscriptionPath
-
- getV1Beta1Path() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.TopicPath
-
- getValue() - Method in class org.apache.beam.runners.flink.metrics.FlinkMetricContainer.FlinkDistributionGauge
-
- getValue() - Method in class org.apache.beam.runners.flink.metrics.FlinkMetricContainer.FlinkGauge
-
- getValue() - Method in class org.apache.beam.runners.gearpump.translators.utils.TranslatorUtils.RawUnionValue
-
- getValue(String, Class<T>) - Method in class org.apache.beam.runners.spark.aggregators.NamedAggregators
-
- getValue(String, Class<T>) - Method in class org.apache.beam.runners.spark.structuredstreaming.aggregators.NamedAggregators
-
- getValue() - Method in class org.apache.beam.runners.spark.util.ByteArray
-
- getValue() - Method in class org.apache.beam.runners.spark.util.SideInputBroadcast
-
- getValue() - Method in class org.apache.beam.sdk.coders.StructuralByteArray
-
- getValue() - Method in class org.apache.beam.sdk.io.range.ByteKey
-
Returns a read-only
ByteBuffer
representing this
ByteKey
.
- getValue() - Method in class org.apache.beam.sdk.metrics.GaugeResult.EmptyGaugeResult
-
- getValue() - Method in class org.apache.beam.sdk.metrics.GaugeResult
-
- getValue() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType.Value
-
Return the integer enum value.
- getValue(Class<T>) - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
-
Returns the current value of the OneOf as the destination type.
- getValue() - Method in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType.Value
-
Returns the current value of the OneOf.
- getValue() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
Retrieve the value of the display item.
- getValue() - Method in class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
The value of the display item.
- getValue() - Method in class org.apache.beam.sdk.transforms.join.RawUnionValue
-
- getValue() - Method in class org.apache.beam.sdk.values.KV
-
Returns the value of this
KV
.
- getValue(int) - Method in class org.apache.beam.sdk.values.Row
-
Get value by field index, ClassCastException
is thrown if schema doesn't match.
- getValue(String) - Method in class org.apache.beam.sdk.values.Row
-
Get value by field name, ClassCastException
is thrown if type doesn't match.
- getValue(int) - Method in class org.apache.beam.sdk.values.RowWithGetters
-
- getValue(int) - Method in class org.apache.beam.sdk.values.RowWithStorage
-
- getValue() - Method in class org.apache.beam.sdk.values.TaggedPValue
-
- getValue() - Method in class org.apache.beam.sdk.values.TimestampedValue
-
- getValue() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
-
Returns the value of this ValueInSingleWindow
.
- getValue() - Method in class org.apache.beam.sdk.values.ValueWithRecordId
-
- getValueCoder() - Method in class org.apache.beam.sdk.coders.KvCoder
-
- getValueCoder() - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
-
Gets the value coder that will be prefixed by the length.
- getValueCoder() - Method in class org.apache.beam.sdk.coders.MapCoder
-
- getValueCoder() - Method in class org.apache.beam.sdk.coders.NullableCoder
-
- getValueCoder() - Method in class org.apache.beam.sdk.testing.TestStream
-
- getValueCoder() - Method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
-
- getValueCoder() - Method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
-
- getValues() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
-
- getValues() - Method in class org.apache.beam.sdk.values.Row
-
Return the list of data values.
- getValues() - Method in class org.apache.beam.sdk.values.RowWithGetters
-
- getValues() - Method in class org.apache.beam.sdk.values.RowWithStorage
-
- getValuesMap() - Method in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
-
- getValueTranslationFunction() - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.Read
-
- getValueTypeDescriptor() - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.Read
-
- getView() - Method in class org.apache.beam.runners.apex.ApexRunner.CreateApexPCollectionView
-
- getView() - Method in class org.apache.beam.runners.dataflow.CreateDataflowView
-
- getView() - Method in class org.apache.beam.runners.dataflow.DataflowRunner.StreamingPCollectionViewWriterFn
-
- getView() - Method in class org.apache.beam.sdk.transforms.View.CreatePCollectionView
-
- getViewFn() - Method in interface org.apache.beam.sdk.values.PCollectionView
-
- getViewFn() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
-
- getVocabulary() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
-
- getVocabulary() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
-
- getWarnings() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- getWatermark() - Method in class org.apache.beam.runners.gearpump.translators.io.GearpumpSource
-
- getWatermark() - Method in class org.apache.beam.runners.spark.io.MicrobatchSource.Reader
-
- getWatermark(TimestampPolicy.PartitionContext) - Method in class org.apache.beam.sdk.io.kafka.CustomTimestampPolicyWithLimitedDelay
-
- getWatermark(TimestampPolicy.PartitionContext) - Method in class org.apache.beam.sdk.io.kafka.TimestampPolicy
-
Returns watermark for the partition.
- getWatermark(TimestampPolicy.PartitionContext) - Method in class org.apache.beam.sdk.io.kafka.TimestampPolicyFactory.LogAppendTimePolicy
-
- getWatermark(TimestampPolicy.PartitionContext) - Method in class org.apache.beam.sdk.io.kafka.TimestampPolicyFactory.ProcessingTimePolicy
-
- getWatermark(TimestampPolicy.PartitionContext) - Method in class org.apache.beam.sdk.io.kafka.TimestampPolicyFactory.TimestampFnPolicy
-
- getWatermark() - Method in interface org.apache.beam.sdk.io.kinesis.WatermarkPolicy
-
- getWatermark() - Method in class org.apache.beam.sdk.io.kinesis.WatermarkPolicyFactory.ArrivalTimeWatermarkPolicy
-
- getWatermark() - Method in class org.apache.beam.sdk.io.kinesis.WatermarkPolicyFactory.CustomWatermarkPolicy
-
- getWatermark() - Method in class org.apache.beam.sdk.io.kinesis.WatermarkPolicyFactory.ProcessingTimeWatermarkPolicy
-
- getWatermark() - Method in class org.apache.beam.sdk.io.UnboundedSource.UnboundedReader
-
Returns a timestamp before or at the timestamps of all future elements read by this reader.
- getWatermark() - Method in class org.apache.beam.sdk.testing.TestStream.WatermarkEvent
-
- getWatermarkMillis() - Method in class org.apache.beam.sdk.io.kafka.KafkaCheckpointMark.PartitionMark
-
- getWatermarks(ExecutableT) - Method in class org.apache.beam.runners.direct.WatermarkManager
-
Gets the input and output watermarks for an AppliedPTransform
.
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterAll
-
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterEach
-
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterFirst
-
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
-
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
-
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
-
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
-
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
-
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
-
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.Never.NeverTrigger
-
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
-
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.Repeatedly
-
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.ReshuffleTrigger
-
Deprecated.
- getWatermarkThatGuaranteesFiring(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
-
For internal use only; no backwards-compatibility guarantees.
- getWindmillServiceEndpoint() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineDebugOptions
-
Custom windmill service endpoint.
- getWindmillServicePort() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineDebugOptions
-
- getWindow() - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.NodeStats
-
This method returns the number of tuples in each window.
- getWindow() - Method in class org.apache.beam.sdk.io.FileBasedSink.FileResult
-
- getWindow() - Method in class org.apache.beam.sdk.values.ValueInSingleWindow
-
Returns the window of this ValueInSingleWindow
.
- getWindowedWrites() - Method in class org.apache.beam.sdk.io.WriteFiles
-
- getWindowFn() - Method in class org.apache.beam.sdk.transforms.windowing.Window.Assign
-
- getWindowFn() - Method in class org.apache.beam.sdk.transforms.windowing.Window
-
- getWindowFn() - Method in class org.apache.beam.sdk.values.WindowingStrategy
-
- getWindowingStrategy(String, RunnerApi.Components) - Static method in class org.apache.beam.runners.fnexecution.translation.PipelineTranslatorUtils
-
- getWindowingStrategy() - Method in class org.apache.beam.sdk.values.PCollection
-
- getWindowingStrategyInternal() - Method in interface org.apache.beam.sdk.values.PCollectionView
-
- getWindowingStrategyInternal() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
-
- getWindowMappingFn() - Method in interface org.apache.beam.sdk.values.PCollectionView
-
For internal use only.
- getWindowMappingFn() - Method in class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
-
- getWindowTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
-
- getWindowTypeDescriptor() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
Returns a
TypeDescriptor
capturing what is known statically about the window type of
this
WindowFn
instance's most-derived class.
- getWorkerCacheMb() - Method in interface org.apache.beam.runners.dataflow.options.DataflowWorkerHarnessOptions
-
The size of the worker's in-memory cache, in megabytes.
- getWorkerDiskType() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineWorkerPoolOptions
-
Specifies what type of persistent disk is used.
- getWorkerHarnessContainerImage() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineWorkerPoolOptions
-
Docker container image that executes Dataflow worker harness, residing in Google Container
Registry.
- getWorkerId() - Method in interface org.apache.beam.runners.dataflow.options.DataflowWorkerHarnessOptions
-
The identity of the worker running this pipeline.
- getWorkerId() - Method in class org.apache.beam.runners.fnexecution.control.FnApiControlClient
-
- getWorkerLogLevelOverrides() - Method in interface org.apache.beam.runners.dataflow.options.DataflowWorkerLoggingOptions
-
Deprecated.
This option controls the log levels for specifically named loggers.
- getWorkerMachineType() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineWorkerPoolOptions
-
Machine type to create Dataflow worker VMs as.
- getWorkerRegion() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcpOptions
-
The Compute Engine region (https://cloud.google.com/compute/docs/regions-zones/regions-zones)
in which worker processing should occur, e.g.
- getWorkerSystemErrMessageLevel() - Method in interface org.apache.beam.runners.dataflow.options.DataflowWorkerLoggingOptions
-
Deprecated.
Controls the log level given to messages printed to System.err
.
- getWorkerSystemOutMessageLevel() - Method in interface org.apache.beam.runners.dataflow.options.DataflowWorkerLoggingOptions
-
Deprecated.
Controls the log level given to messages printed to System.out
.
- getWorkerZone() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcpOptions
-
The Compute Engine zone (https://cloud.google.com/compute/docs/regions-zones/regions-zones) in
which worker processing should occur, e.g.
- getWritableByteChannelFactory() - Method in class org.apache.beam.sdk.io.FileBasedSink
-
- getWriteOperation() - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
-
Return the WriteOperation that this Writer belongs to.
- getYarnDeployDependencies() - Static method in class org.apache.beam.runners.apex.ApexYarnLauncher
-
From the current classpath, find the jar files that need to be deployed with the application to
run on YARN.
- getZetaSqlRuleSets() - Static method in class org.apache.beam.sdk.extensions.sql.zetasql.ZetaSQLQueryPlanner
-
- getZone() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcpOptions
-
- global(Map<Integer, GlobalWatermarkHolder.SparkWatermarks>) - Static method in class org.apache.beam.runners.spark.stateful.SparkTimerInternals
-
Build a global TimerInternals
for all feeding streams.
- Global() - Constructor for class org.apache.beam.sdk.schemas.transforms.Group.Global
-
- globalDefault() - Static method in class org.apache.beam.sdk.values.WindowingStrategy
-
Return a fully specified, default windowing strategy.
- GlobalDigest() - Constructor for class org.apache.beam.sdk.extensions.sketching.TDigestQuantiles.GlobalDigest
-
- globally() - Static method in class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct
-
Computes the approximate number of distinct elements in the input PCollection<InputT>
and returns a PCollection<Long>
.
- globally() - Static method in class org.apache.beam.sdk.extensions.sketching.SketchFrequencies
-
Create the
PTransform
that will build a Count-min sketch for keeping track of the
frequency of the elements in the whole stream.
- globally() - Static method in class org.apache.beam.sdk.extensions.sketching.TDigestQuantiles
-
Compute the stream in order to build a T-Digest structure (MergingDigest) for keeping track of
the stream distribution and returns a PCollection<MergingDigest>
.
- globally() - Static method in class org.apache.beam.sdk.extensions.zetasketch.HllCount.Extract
-
Returns a PTransform
that takes an input PCollection<byte[]>
of HLL++
sketches and returns a PCollection<Long>
of the estimated count of distinct elements
extracted from each sketch.
- globally() - Method in class org.apache.beam.sdk.extensions.zetasketch.HllCount.Init.Builder
-
Returns a Combine.Globally
PTransform
that takes an input PCollection<InputT>
and returns a PCollection<byte[]>
which consists of the HLL++
sketch computed from the elements in the input PCollection
.
- globally() - Static method in class org.apache.beam.sdk.extensions.zetasketch.HllCount.MergePartial
-
Returns a Combine.Globally
PTransform
that takes an input PCollection<byte[]>
of HLL++ sketches and returns a PCollection<byte[]>
of a new
sketch merged from the input sketches.
- globally() - Static method in class org.apache.beam.sdk.schemas.transforms.Group
-
Returns a transform that groups all elements in the input
PCollection
.
- globally(int, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles
-
Returns a PTransform
that takes a PCollection<T>
and returns a PCollection<List<T>>
whose single value is a List
of the approximate N
-tiles
of the elements of the input PCollection
.
- globally(int) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles
-
- globally(int) - Static method in class org.apache.beam.sdk.transforms.ApproximateUnique
-
Returns a PTransform
that takes a PCollection<T>
and returns a PCollection<Long>
containing a single value that is an estimate of the number of distinct
elements in the input PCollection
.
- globally(double) - Static method in class org.apache.beam.sdk.transforms.ApproximateUnique
-
- Globally(int) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.Globally
-
- Globally(double) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.Globally
-
- globally(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.Globally
PTransform
that uses the given
SerializableFunction
to combine all the elements in each window of the input
PCollection
into a single value in the output
PCollection
.
- globally(SerializableBiFunction<V, V, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.Globally
PTransform
that uses the given
SerializableBiFunction
to combine all the elements in each window of the input
PCollection
into a single value in the output
PCollection
.
- globally(CombineFnBase.GlobalCombineFn<? super InputT, ?, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.Globally
PTransform
that uses the given
GloballyCombineFn
to combine all the elements in each window of the input
PCollection
into a single value in the output
PCollection
.
- globally() - Static method in class org.apache.beam.sdk.transforms.Count
-
- globally() - Static method in class org.apache.beam.sdk.transforms.Latest
-
Returns a
PTransform
that takes as input a
PCollection<T>
and returns a
PCollection<T>
whose contents is the latest element according to its event time, or null if there are no elements.
- globally() - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a PTransform
that takes an input PCollection<T>
and returns a PCollection<T>
whose contents is the maximum according to the natural ordering of T
of
the input PCollection
's elements, or null
if there are no elements.
- globally(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a PTransform
that takes an input PCollection<T>
and returns a PCollection<T>
whose contents is the maximum of the input PCollection
's elements, or
null
if there are no elements.
- globally() - Static method in class org.apache.beam.sdk.transforms.Mean
-
Returns a PTransform
that takes an input PCollection<NumT>
and returns a PCollection<Double>
whose contents is the mean of the input PCollection
's elements, or
0
if there are no elements.
- globally() - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a PTransform
that takes an input PCollection<T>
and returns a PCollection<T>
whose contents is the minimum according to the natural ordering of T
of
the input PCollection
's elements, or null
if there are no elements.
- globally(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a PTransform
that takes an input PCollection<T>
and returns a PCollection<T>
whose contents is the minimum of the input PCollection
's elements, or
null
if there are no elements.
- GloballyDistinct() - Constructor for class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct.GloballyDistinct
-
- GlobalSketch() - Constructor for class org.apache.beam.sdk.extensions.sketching.SketchFrequencies.GlobalSketch
-
- GlobalWatermarkHolder - Class in org.apache.beam.runners.spark.util
-
A store to hold the global watermarks for a micro-batch.
- GlobalWatermarkHolder() - Constructor for class org.apache.beam.runners.spark.util.GlobalWatermarkHolder
-
- GlobalWatermarkHolder.SparkWatermarks - Class in org.apache.beam.runners.spark.util
-
- GlobalWatermarkHolder.WatermarkAdvancingStreamingListener - Class in org.apache.beam.runners.spark.util
-
Advance the WMs onBatchCompleted event.
- GlobalWindow - Class in org.apache.beam.sdk.transforms.windowing
-
The default window into which all data is placed (via
GlobalWindows
).
- GlobalWindow.Coder - Class in org.apache.beam.sdk.transforms.windowing
-
- GlobalWindows - Class in org.apache.beam.sdk.transforms.windowing
-
A
WindowFn
that assigns all data to the same window.
- GlobalWindows() - Constructor for class org.apache.beam.sdk.transforms.windowing.GlobalWindows
-
- GoogleApiDebugOptions - Interface in org.apache.beam.sdk.extensions.gcp.options
-
These options configure debug settings for Google API clients created within the Apache Beam SDK.
- GoogleApiDebugOptions.GoogleApiTracer - Class in org.apache.beam.sdk.extensions.gcp.options
-
- GoogleApiTracer() - Constructor for class org.apache.beam.sdk.extensions.gcp.options.GoogleApiDebugOptions.GoogleApiTracer
-
- GraphiteSink - Class in org.apache.beam.runners.spark.metrics.sink
-
- GraphiteSink(Properties, MetricRegistry, SecurityManager) - Constructor for class org.apache.beam.runners.spark.metrics.sink.GraphiteSink
-
- greaterThan(T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- greaterThan(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- greaterThan(T) - Static method in class org.apache.beam.sdk.transforms.Filter
-
Returns a PTransform
that takes an input PCollection<T>
and returns a PCollection<T>
with elements that are greater than a given value, based on the elements'
natural ordering.
- greaterThanEq(T) - Static method in class org.apache.beam.sdk.transforms.Filter
-
Returns a PTransform
that takes an input PCollection<T>
and returns a PCollection<T>
with elements that are greater than or equal to a given value, based on the
elements' natural ordering.
- greaterThanOrEqualTo(T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- greaterThanOrEqualTo(Coder<T>, T) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- Group - Class in org.apache.beam.sdk.schemas.transforms
-
- Group() - Constructor for class org.apache.beam.sdk.schemas.transforms.Group
-
- Group.ByFields<InputT> - Class in org.apache.beam.sdk.schemas.transforms
-
a
PTransform
that groups schema elements based on the given fields.
- Group.CombineFieldsByFields<InputT> - Class in org.apache.beam.sdk.schemas.transforms
-
a
PTransform
that does a per-key combine using an aggregation built up by calls to
aggregateField and aggregateFields.
- Group.CombineFieldsGlobally<InputT> - Class in org.apache.beam.sdk.schemas.transforms
-
a
PTransform
that does a global combine using an aggregation built up by calls to
aggregateField and aggregateFields.
- Group.CombineGlobally<InputT,OutputT> - Class in org.apache.beam.sdk.schemas.transforms
-
- Group.Global<InputT> - Class in org.apache.beam.sdk.schemas.transforms
-
A
PTransform
for doing global aggregations on schema PCollections.
- GroupAlsoByWindowViaOutputBufferFn<K,InputT,W extends BoundedWindow> - Class in org.apache.beam.runners.spark.structuredstreaming.translation.batch.functions
-
A FlatMap function that groups by windows in batch mode using ReduceFnRunner
.
- GroupAlsoByWindowViaOutputBufferFn(WindowingStrategy<?, W>, StateInternalsFactory<K>, SystemReduceFn<K, InputT, Iterable<InputT>, Iterable<InputT>, W>, SerializablePipelineOptions) - Constructor for class org.apache.beam.runners.spark.structuredstreaming.translation.batch.functions.GroupAlsoByWindowViaOutputBufferFn
-
- groupBy(WindowedValue<KV<K, V>>) - Method in class org.apache.beam.runners.gearpump.translators.GroupByKeyTranslator.GroupByFn
-
- GroupByKey<K,V> - Class in org.apache.beam.sdk.transforms
-
GroupByKey<K, V>
takes a PCollection<KV<K, V>>
, groups the values by key and
windows, and returns a PCollection<KV<K, Iterable<V>>>
representing a map from each
distinct key and window of the input PCollection
to an Iterable
over all the
values associated with that key in the input per window.
- groupByKeyAndWindow(JavaDStream<WindowedValue<KV<K, InputT>>>, Coder<K>, Coder<WindowedValue<InputT>>, WindowingStrategy<?, W>, SerializablePipelineOptions, List<Integer>, String) - Static method in class org.apache.beam.runners.spark.stateful.SparkGroupAlsoByWindowViaWindowSet
-
- GroupByKeyTranslator<K,V> - Class in org.apache.beam.runners.gearpump.translators
-
GroupByKey
is translated to Gearpump groupBy function.
- GroupByKeyTranslator() - Constructor for class org.apache.beam.runners.gearpump.translators.GroupByKeyTranslator
-
- GroupByKeyTranslator.GearpumpWindowFn<T,W extends BoundedWindow> - Class in org.apache.beam.runners.gearpump.translators
-
A transform used internally to translate Beam's Window to Gearpump's Window.
- GroupByKeyTranslator.GroupByFn<K,V> - Class in org.apache.beam.runners.gearpump.translators
-
A transform used internally to group KV message by its key.
- GroupByKeyTranslator.KeyedByTimestamp<K,V> - Class in org.apache.beam.runners.gearpump.translators
-
A transform used internally to transform WindowedValue to KV.
- GroupByKeyTranslator.Merge<K,V> - Class in org.apache.beam.runners.gearpump.translators
-
A transform used internally by Gearpump which encapsulates the merge logic.
- grouped() - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerIO.Write
-
- groupedValues(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.GroupedValues
PTransform
that takes a
PCollection
of
KV
s where a key maps to an
Iterable
of values, e.g., the result
of a
GroupByKey
, then uses the given
SerializableFunction
to combine all the
values associated with a key, ignoring the key.
- groupedValues(SerializableBiFunction<V, V, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.GroupedValues
PTransform
that takes a
PCollection
of
KV
s where a key maps to an
Iterable
of values, e.g., the result
of a
GroupByKey
, then uses the given
SerializableFunction
to combine all the
values associated with a key, ignoring the key.
- groupedValues(CombineFnBase.GlobalCombineFn<? super InputT, ?, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.GroupedValues
PTransform
that takes a
PCollection
of
KV
s where a key maps to an
Iterable
of values, e.g., the result
of a
GroupByKey
, then uses the given
CombineFn
to combine all the values
associated with a key, ignoring the key.
- GroupingState<InputT,OutputT> - Interface in org.apache.beam.sdk.state
-
A
ReadableState
cell that combines multiple input values and outputs a single value of a
different type.
- GroupIntoBatches<K,InputT> - Class in org.apache.beam.sdk.transforms
-
A
PTransform
that batches inputs to a desired batch size.
- Growth() - Constructor for class org.apache.beam.sdk.transforms.Watch.Growth
-
- growthOf(Watch.Growth.PollFn<InputT, OutputT>, Requirements) - Static method in class org.apache.beam.sdk.transforms.Watch
-
Watches the growth of the given poll function.
- growthOf(Watch.Growth.PollFn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Watch
-
Watches the growth of the given poll function.
- growthOf(Contextful<Watch.Growth.PollFn<InputT, OutputT>>, SerializableFunction<OutputT, KeyT>) - Static method in class org.apache.beam.sdk.transforms.Watch
-
Watches the growth of the given poll function, using the given "key function" to deduplicate
outputs.
- GrpcContextHeaderAccessorProvider - Class in org.apache.beam.runners.fnexecution
-
A HeaderAccessorProvider which intercept the header in a GRPC request and expose the relevant
fields.
- GrpcContextHeaderAccessorProvider() - Constructor for class org.apache.beam.runners.fnexecution.GrpcContextHeaderAccessorProvider
-
- GrpcDataService - Class in org.apache.beam.runners.fnexecution.data
-
- GrpcDataService() - Constructor for class org.apache.beam.runners.fnexecution.data.GrpcDataService
-
- GrpcFnServer<ServiceT extends FnService> - Class in org.apache.beam.runners.fnexecution
-
A
gRPC Server
which manages a single
FnService
.
- GrpcLoggingService - Class in org.apache.beam.runners.fnexecution.logging
-
An implementation of the Beam Fn Logging Service over gRPC.
- GrpcStateService - Class in org.apache.beam.runners.fnexecution.state
-
An implementation of the Beam Fn State service.
- id() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobPreparation
-
- id - Variable in enum org.apache.beam.sdk.io.kafka.KafkaTimestampType
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.Fixed32
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.Fixed64
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.SFixed32
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.SFixed64
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.SInt32
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.SInt64
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.UInt32
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.UInt64
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.extensions.sql.impl.utils.CalciteUtils.CharType
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.extensions.sql.impl.utils.CalciteUtils.DateType
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.extensions.sql.impl.utils.CalciteUtils.TimestampWithLocalTzType
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.extensions.sql.impl.utils.CalciteUtils.TimeType
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.extensions.sql.impl.utils.CalciteUtils.TimeWithLocalTzType
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.NanosDuration
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.NanosInstant
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationLexer
-
- IDENTIFIER - Static variable in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser
-
- IDENTIFIER() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.QualifiedComponentContext
-
- IDENTIFIER() - Method in class org.apache.beam.sdk.schemas.parser.generated.FieldSpecifierNotationParser.SimpleIdentifierContext
-
- Identifier() - Constructor for class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
-
- identity() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
-
Returns the identity element of this operation, i.e.
- identity() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
-
Returns the value that should be used for the combine of the empty set.
- identity() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
-
Returns the identity element of this operation, i.e.
- identity() - Method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
-
Returns the identity element of this operation, i.e.
- identity() - Static method in class org.apache.beam.sdk.transforms.SerializableFunctions
-
- IDENTITY_ELEMENT - Static variable in class org.apache.beam.sdk.metrics.DistributionResult
-
The IDENTITY_ELEMENT is used to start accumulating distributions.
- IdGenerator - Interface in org.apache.beam.sdk.fn
-
A generator of unique IDs.
- IdGenerators - Class in org.apache.beam.sdk.fn
-
- IdGenerators() - Constructor for class org.apache.beam.sdk.fn.IdGenerators
-
- ignored() - Static method in interface org.apache.beam.runners.fnexecution.control.BundleProgressHandler
-
Returns a handler that ignores metrics.
- ignoreInput(Watch.Growth.TerminationCondition<?, StateT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth
-
Wraps a given input-independent
Watch.Growth.TerminationCondition
as an equivalent condition with
a given input type, passing
null
to the original condition as input.
- ignoreInsertIds() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.Write
-
Setting this option to true disables insertId based data deduplication offered by BigQuery.
- ignoreUnknownValues() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.Write
-
Accept rows that contain values that do not match the schema.
- immediate(T) - Static method in class org.apache.beam.sdk.state.ReadableStates
-
A
ReadableState
constructed from a constant value, hence immediately available.
- immutableNames() - Method in class org.apache.beam.sdk.metrics.MetricsFilter
-
- immutableNamesBuilder() - Method in class org.apache.beam.sdk.metrics.MetricsFilter.Builder
-
- immutableSteps() - Method in class org.apache.beam.sdk.metrics.MetricsFilter
-
- immutableStepsBuilder() - Method in class org.apache.beam.sdk.metrics.MetricsFilter.Builder
-
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamEnumerableConverter
-
- Impulse - Class in org.apache.beam.sdk.transforms
-
For internal use only; no backwards-compatibility guarantees.
- IMPULSE_ELEMENT - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- ImpulseP - Class in org.apache.beam.runners.jet.processors
-
/** * Jet Processor
implementation for Beam's Impulse primitive.
- in(Pipeline) - Static method in class org.apache.beam.sdk.values.PBegin
-
- in(Pipeline) - Static method in class org.apache.beam.sdk.values.PDone
-
- inbound(Iterator<ByteString>) - Static method in class org.apache.beam.sdk.fn.stream.DataStreams
-
Converts multiple ByteString
s into a single InputStream
.
- InboundDataClient - Interface in org.apache.beam.sdk.fn.data
-
A client representing some stream of inbound data.
- inc() - Method in class org.apache.beam.runners.jet.metrics.CounterImpl
-
- inc(long) - Method in class org.apache.beam.runners.jet.metrics.CounterImpl
-
- inc() - Method in interface org.apache.beam.sdk.metrics.Counter
-
Increment the counter.
- inc(long) - Method in interface org.apache.beam.sdk.metrics.Counter
-
Increment the counter by the given amount.
- inc() - Method in class org.apache.beam.sdk.metrics.DelegatingCounter
-
Increment the counter.
- inc(long) - Method in class org.apache.beam.sdk.metrics.DelegatingCounter
-
Increment the counter by the given amount.
- include(String, HasDisplayData) - Method in interface org.apache.beam.sdk.transforms.display.DisplayData.Builder
-
Register display data from the specified subcomponent at the given path.
- inCombinedNonLatePanes(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Creates a new
PAssert.IterableAssert
like this one, but with the assertion restricted to only
run on the provided window across all panes that were not produced by the arrival of late
data.
- inCombinedNonLatePanes(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
-
- IncompatibleWindowException - Exception in org.apache.beam.sdk.transforms.windowing
-
- IncompatibleWindowException(WindowFn<?, ?>, String) - Constructor for exception org.apache.beam.sdk.transforms.windowing.IncompatibleWindowException
-
- incomplete(List<TimestampedValue<OutputT>>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
-
Constructs a
Watch.Growth.PollResult
with the given outputs and declares that new outputs might
appear for the current input.
- incomplete(Instant, List<OutputT>) - Static method in class org.apache.beam.sdk.transforms.Watch.Growth.PollResult
-
- increment() - Method in class org.apache.beam.runners.dataflow.util.RandomAccessData
-
Returns a RandomAccessData that is the smallest value of same length which is strictly greater
than this.
- incrementingLongs() - Static method in class org.apache.beam.sdk.fn.IdGenerators
-
Returns an
IdGenerator
which provides successive incrementing longs.
- INDEX_OF_MAX - Static variable in class org.apache.beam.sdk.io.ShardNameTemplate
-
Shard name containing the index and max.
- indexOf(String) - Method in class org.apache.beam.sdk.schemas.Schema
-
Find the index of a given field.
- indexOfProjectionColumnRef(long, List<ResolvedColumn>) - Method in class org.apache.beam.sdk.extensions.sql.zetasql.translation.ExpressionConverter
-
Return an index of the projection column reference.
- inEarlyGlobalWindowPanes() - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
- inEarlyGlobalWindowPanes() - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
-
- inEarlyPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Creates a new
PAssert.IterableAssert
like this one, but with the assertion restricted to only
run on the provided window across all panes that were produced by the arrival of early data.
- inEarlyPane(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
-
- inEarlyPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Creates a new
PAssert.SingletonAssert
like this one, but with the assertion restricted to
only run on the provided window, running the checker only on early panes for each key.
- InferableFunction<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
- InferableFunction() - Constructor for class org.apache.beam.sdk.transforms.InferableFunction
-
- InferableFunction(ProcessFunction<InputT, OutputT>) - Constructor for class org.apache.beam.sdk.transforms.InferableFunction
-
- inferType(Object) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
- inFinalPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Creates a new
PAssert.IterableAssert
like this one, but with the assertion restricted to only
run on the provided window, running the checker only on the final pane for each key.
- inFinalPane(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
-
- inFinalPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Creates a new
PAssert.SingletonAssert
like this one, but with the assertion restricted to
only run on the provided window, running the checker only on the final pane for each key.
- INHERIT_IO_FILE - Static variable in class org.apache.beam.runners.fnexecution.environment.ProcessManager
-
A symbolic file to indicate that we want to inherit I/O of parent process.
- init() - Method in class org.apache.beam.runners.gearpump.translators.GroupByKeyTranslator.Merge
-
- init(Processor.Context) - Method in class org.apache.beam.runners.jet.processors.BoundedSourceP
-
- init(Processor.Context) - Method in class org.apache.beam.runners.jet.processors.UnboundedSourceP
-
- init(SparkPipelineOptions, JavaSparkContext) - Static method in class org.apache.beam.runners.spark.aggregators.AggregatorsAccumulator
-
Init aggregators accumulator if it has not been initiated.
- init(SparkPipelineOptions, JavaSparkContext) - Static method in class org.apache.beam.runners.spark.metrics.MetricsAccumulator
-
Init metrics accumulator if it has not been initiated.
- init(JavaSparkContext) - Static method in class org.apache.beam.runners.spark.structuredstreaming.aggregators.AggregatorsAccumulator
-
Init aggregators accumulator if it has not been initiated.
- init(JavaSparkContext) - Static method in class org.apache.beam.runners.spark.structuredstreaming.metrics.MetricsAccumulator
-
Init metrics accumulator if it has not been initiated.
- initAccumulators(SparkPipelineOptions, JavaSparkContext) - Static method in class org.apache.beam.runners.spark.SparkRunner
-
Init Metrics/Aggregators accumulators.
- initAccumulators(SparkStructuredStreamingPipelineOptions, JavaSparkContext) - Static method in class org.apache.beam.runners.spark.structuredstreaming.SparkStructuredStreamingRunner
-
Init Metrics/Aggregators accumulators.
- initialBackoff() - Method in class org.apache.beam.sdk.io.clickhouse.ClickHouseIO.Write
-
- initialize(Map<ExecutableT, ? extends Iterable<Bundle<?, CollectionT>>>) - Method in class org.apache.beam.runners.direct.WatermarkManager
-
- initialize(HttpRequest) - Method in class org.apache.beam.sdk.extensions.gcp.auth.NullCredentialInitializer
-
- initialize(AbstractGoogleClientRequest<?>) - Method in class org.apache.beam.sdk.extensions.gcp.options.GoogleApiDebugOptions.GoogleApiTracer
-
- initialize(HttpRequest) - Method in class org.apache.beam.sdk.extensions.gcp.util.RetryHttpRequestInitializer
-
- initialSystemTimeAt(Instant) - Method in class org.apache.beam.runners.spark.io.CreateStream
-
Set the initial synchronized processing time.
- InjectPackageStrategy(Class<?>) - Constructor for class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.InjectPackageStrategy
-
- inLatePane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Creates a new
PAssert.IterableAssert
with the assertion restricted to only run on the
provided window across all panes that were produced by the arrival of late data.
- inLatePane(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
-
- inLatePane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Creates a new
PAssert.SingletonAssert
with the assertion restricted to only run on the
provided window, running the checker only on late panes for each key.
- inMemory(TableProvider...) - Static method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlEnv
-
This method creates
BeamSqlEnv
using empty *
Pipeline Options.
- InMemoryBagUserStateFactory<K,V,W extends BoundedWindow> - Class in org.apache.beam.runners.fnexecution.state
-
Holds user state in memory.
- InMemoryBagUserStateFactory() - Constructor for class org.apache.beam.runners.fnexecution.state.InMemoryBagUserStateFactory
-
- inMemoryFinalizer(InstructionRequestHandler) - Static method in class org.apache.beam.runners.fnexecution.control.BundleFinalizationHandlers
-
A bundle finalizer that stores all bundle finalization requests in memory.
- InMemoryJobService - Class in org.apache.beam.runners.fnexecution.jobsubmission
-
A InMemoryJobService that prepares and runs jobs on behalf of a client using a
JobInvoker
.
- InMemoryMetaStore - Class in org.apache.beam.sdk.extensions.sql.meta.store
-
A
MetaStore
which stores the meta info in memory.
- InMemoryMetaStore() - Constructor for class org.apache.beam.sdk.extensions.sql.meta.store.InMemoryMetaStore
-
- InMemoryMetaTableProvider - Class in org.apache.beam.sdk.extensions.sql.meta.provider
-
A InMemoryMetaTableProvider
is an abstract TableProvider
for in-memory types.
- InMemoryMetaTableProvider() - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.InMemoryMetaTableProvider
-
- inNamespace(String) - Static method in class org.apache.beam.sdk.metrics.MetricNameFilter
-
- inNamespace(Class<?>) - Static method in class org.apache.beam.sdk.metrics.MetricNameFilter
-
- Inner() - Constructor for class org.apache.beam.sdk.schemas.transforms.Filter.Inner
-
- innerJoin(PCollection<KV<K, V1>>, PCollection<KV<K, V2>>) - Static method in class org.apache.beam.sdk.extensions.joinlibrary.Join
-
Inner join of two collections of KV elements.
- innerJoin(String, PCollection<KV<K, V1>>, PCollection<KV<K, V2>>) - Static method in class org.apache.beam.sdk.extensions.joinlibrary.Join
-
Inner join of two collections of KV elements.
- innerJoin(PCollection<RhsT>) - Static method in class org.apache.beam.sdk.schemas.transforms.Join
-
Perform an inner join.
- inOnlyPane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Creates a new
PAssert.SingletonAssert
like this one, but with the assertion restricted to
only run on the provided window.
- inOnTimePane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Creates a new
PAssert.IterableAssert
like this one, but with the assertion restricted to only
run on the provided window.
- inOnTimePane(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
-
- inOnTimePane(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Creates a new
PAssert.SingletonAssert
like this one, but with the assertion restricted to
only run on the provided window, running the checker only on the on-time pane for each key.
- inOrder(Trigger...) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterEach
-
Returns an AfterEach
Trigger
with the given subtriggers.
- inOrder(List<Trigger>) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterEach
-
Returns an AfterEach
Trigger
with the given subtriggers.
- InProcessManagedChannelFactory - Class in org.apache.beam.sdk.fn.test
-
- InProcessServerFactory - Class in org.apache.beam.runners.fnexecution
-
A
ServerFactory
which creates
servers
with the
InProcessServerBuilder
.
- inputCollectionId() - Method in class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors.TimerSpec
-
- inputOf(ProcessFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
Returns a type descriptor for the input of the given
ProcessFunction
, subject to Java
type erasure: may contain unresolved type variables if the type was erased.
- inputOf(SerializableFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
- inputOf(Contextful.Fn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
- INPUTS - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- insertAll(TableReference, List<ValueInSingleWindow<TableRow>>, List<String>, InsertRetryPolicy, List<ValueInSingleWindow<T>>, ErrorContainer<T>, boolean, boolean, boolean) - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryServices.DatasetService
-
Inserts
TableRows
with the specified insertIds if not null.
- insertAll(TableReference, List<TableRow>, List<String>) - Method in class org.apache.beam.sdk.io.gcp.testing.FakeDatasetService
-
- insertAll(TableReference, List<ValueInSingleWindow<TableRow>>, List<String>, InsertRetryPolicy, List<ValueInSingleWindow<T>>, ErrorContainer<T>, boolean, boolean, boolean) - Method in class org.apache.beam.sdk.io.gcp.testing.FakeDatasetService
-
- insertDataToTable(String, String, String, List<Map<String, Object>>) - Method in class org.apache.beam.sdk.io.gcp.testing.BigqueryClient
-
Inserts rows to a table using a BigQuery streaming write.
- insertDeduplicate() - Method in class org.apache.beam.sdk.io.clickhouse.ClickHouseIO.Write
-
- insertDistributedSync() - Method in class org.apache.beam.sdk.io.clickhouse.ClickHouseIO.Write
-
- insertQuorum() - Method in class org.apache.beam.sdk.io.clickhouse.ClickHouseIO.Write
-
- InsertRetryPolicy - Class in org.apache.beam.sdk.io.gcp.bigquery
-
A retry policy for streaming BigQuery inserts.
- InsertRetryPolicy() - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.InsertRetryPolicy
-
- InsertRetryPolicy.Context - Class in org.apache.beam.sdk.io.gcp.bigquery
-
Contains information about a failed insert.
- insertRows(Schema, Row...) - Method in class org.apache.beam.sdk.io.gcp.bigquery.TestBigQuery
-
- insertTestData(Map<String, String>) - Static method in class org.apache.beam.sdk.io.hcatalog.test.HCatalogIOTestUtils
-
Inserts data into test datastore.
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.JdbcDriver
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamJavaTypeFactory
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamRelDataTypeSystem
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamAggregateProjectMergeRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamAggregationRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamBasicAggregationRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamCalcRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamCoGBKJoinRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamEnumerableConverterRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamIntersectRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamIOPushDownRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamIOSinkRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamJoinAssociateRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamMinusRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamSideInputJoinRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamSideInputLookupJoinRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamSortRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamUncollectRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamUnionRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamUnnestRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamValuesRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.extensions.sql.zetasql.BeamZetaSqlCalcRule
-
- INSTANCE - Static variable in class org.apache.beam.sdk.fn.windowing.EncodedBoundedWindow.Coder
-
- INSTANCE - Static variable in class org.apache.beam.sdk.schemas.AutoValueSchema.AbstractGetterTypeSupplier
-
- INSTANCE - Static variable in class org.apache.beam.sdk.schemas.JavaBeanSchema.GetterTypeSupplier
-
- INSTANCE - Static variable in class org.apache.beam.sdk.schemas.JavaFieldSchema.JavaFieldTypeSupplier
-
- INSTANCE - Static variable in class org.apache.beam.sdk.transforms.windowing.GlobalWindow.Coder
-
- INSTANCE - Static variable in class org.apache.beam.sdk.transforms.windowing.GlobalWindow
-
- INSTANCE - Static variable in class org.apache.beam.sdk.transforms.windowing.PaneInfo.PaneInfoCoder
-
- InstantCoder - Class in org.apache.beam.sdk.coders
-
A
Coder
for joda
Instant
that encodes it as a big endian
Long
shifted
such that lexicographic ordering of the bytes corresponds to chronological order.
- InstantDeserializer - Class in org.apache.beam.sdk.io.kafka.serialization
-
- InstantDeserializer() - Constructor for class org.apache.beam.sdk.io.kafka.serialization.InstantDeserializer
-
- instantiateCoder(String, RunnerApi.Components) - Static method in class org.apache.beam.runners.fnexecution.translation.PipelineTranslatorUtils
-
Creates a coder for a given PCollection id from the Proto definition.
- instantiateRunnerWireCoder(PipelineNode.PCollectionNode, RunnerApi.Components) - Static method in class org.apache.beam.runners.fnexecution.wire.WireCoders
-
Instantiates a runner-side wire coder for the given PCollection.
- instantiateRunnerWireCoder(PipelineNode.PCollectionNode, RunnerApi.Components, RunnerApi.ExecutableStagePayload.WireCoderSetting) - Static method in class org.apache.beam.runners.fnexecution.wire.WireCoders
-
Instantiates a runner-side wire coder for the given PCollection.
- InstantSerializer - Class in org.apache.beam.sdk.io.kafka.serialization
-
- InstantSerializer() - Constructor for class org.apache.beam.sdk.io.kafka.serialization.InstantSerializer
-
- InstructionRequestHandler - Interface in org.apache.beam.runners.fnexecution.control
-
Interface for any function that can handle a Fn API BeamFnApi.InstructionRequest
.
- INT16 - Static variable in class org.apache.beam.sdk.io.clickhouse.TableSchema.ColumnType
-
- INT16 - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
-
The type of int16 fields.
- INT32 - Static variable in class org.apache.beam.sdk.io.clickhouse.TableSchema.ColumnType
-
- INT32 - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
-
The type of int32 fields.
- INT64 - Static variable in class org.apache.beam.sdk.io.clickhouse.TableSchema.ColumnType
-
- INT64 - Static variable in class org.apache.beam.sdk.schemas.Schema.FieldType
-
The type of int64 fields.
- INT8 - Static variable in class org.apache.beam.sdk.io.clickhouse.TableSchema.ColumnType
-
- INTEGER - Static variable in class org.apache.beam.sdk.extensions.sql.impl.utils.CalciteUtils
-
- integers() - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
- integersGlobally() - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a PTransform
that takes an input PCollection<Integer>
and returns a
PCollection<Integer>
whose contents is the maximum of the input PCollection
's
elements, or Integer.MIN_VALUE
if there are no elements.
- integersGlobally() - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a PTransform
that takes an input PCollection<Integer>
and returns a
PCollection<Integer>
whose contents is a single value that is the minimum of the input
PCollection
's elements, or Integer.MAX_VALUE
if there are no elements.
- integersGlobally() - Static method in class org.apache.beam.sdk.transforms.Sum
-
Returns a PTransform
that takes an input PCollection<Integer>
and returns a
PCollection<Integer>
whose contents is the sum of the input PCollection
's
elements, or 0
if there are no elements.
- integersPerKey() - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a PTransform
that takes an input PCollection<KV<K, Integer>>
and
returns a PCollection<KV<K, Integer>>
that contains an output element mapping each
distinct key in the input PCollection
to the maximum of the values associated with that
key in the input PCollection
.
- integersPerKey() - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a PTransform
that takes an input PCollection<KV<K, Integer>>
and
returns a PCollection<KV<K, Integer>>
that contains an output element mapping each
distinct key in the input PCollection
to the minimum of the values associated with that
key in the input PCollection
.
- integersPerKey() - Static method in class org.apache.beam.sdk.transforms.Sum
-
Returns a PTransform
that takes an input PCollection<KV<K, Integer>>
and
returns a PCollection<KV<K, Integer>>
that contains an output element mapping each
distinct key in the input PCollection
to the sum of the values associated with that key
in the input PCollection
.
- interceptor() - Static method in class org.apache.beam.runners.fnexecution.GrpcContextHeaderAccessorProvider
-
- interceptResponse(HttpResponse) - Method in class org.apache.beam.sdk.extensions.gcp.util.UploadIdResponseInterceptor
-
- Internal - Annotation Type in org.apache.beam.sdk.annotations
-
Signifies that a publicly accessible API (public class, method or field) is intended for internal
use only and not for public consumption.
- interpolateKey(double) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
-
Returns a
ByteKey
key
such that
[startKey, key)
represents
approximately the specified fraction of the range
[startKey, endKey)
.
- intersects(IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
-
Returns whether this window intersects the given window.
- IntervalWindow - Class in org.apache.beam.sdk.transforms.windowing
-
- IntervalWindow(Instant, Instant) - Constructor for class org.apache.beam.sdk.transforms.windowing.IntervalWindow
-
Creates a new IntervalWindow that represents the half-open time interval [start, end).
- IntervalWindow(Instant, ReadableDuration) - Constructor for class org.apache.beam.sdk.transforms.windowing.IntervalWindow
-
- IntervalWindow.IntervalWindowCoder - Class in org.apache.beam.sdk.transforms.windowing
-
- IntervalWindowCoder() - Constructor for class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
-
- into(TypeDescriptor<OutputT>) - Static method in class org.apache.beam.sdk.transforms.FlatMapElements
-
- into(TypeDescriptor<OutputT>) - Static method in class org.apache.beam.sdk.transforms.MapElements
-
- into(WindowFn<? super T, ?>) - Static method in class org.apache.beam.sdk.transforms.windowing.Window
-
Creates a
Window
PTransform
that uses the given
WindowFn
to window the
data.
- InvalidTableException - Exception in org.apache.beam.sdk.extensions.sql.meta.provider
-
Exception thrown when the request for a table is invalid, such as invalid metadata.
- InvalidTableException(String) - Constructor for exception org.apache.beam.sdk.extensions.sql.meta.provider.InvalidTableException
-
- InvalidTableException(String, Throwable) - Constructor for exception org.apache.beam.sdk.extensions.sql.meta.provider.InvalidTableException
-
- InvalidTableException(Throwable) - Constructor for exception org.apache.beam.sdk.extensions.sql.meta.provider.InvalidTableException
-
- InvalidWindows<W extends BoundedWindow> - Class in org.apache.beam.sdk.transforms.windowing
-
A
WindowFn
that represents an invalid pipeline state.
- InvalidWindows(String, WindowFn<?, W>) - Constructor for class org.apache.beam.sdk.transforms.windowing.InvalidWindows
-
- invokeAdvance(ReaderT) - Method in class org.apache.beam.runners.flink.metrics.ReaderInvocationUtil
-
- invokeStart(ReaderT) - Method in class org.apache.beam.runners.flink.metrics.ReaderInvocationUtil
-
- invokeWithExecutor(RunnerApi.Pipeline, Struct, String, ListeningExecutorService) - Method in class org.apache.beam.runners.flink.FlinkJobInvoker
-
- invokeWithExecutor(RunnerApi.Pipeline, Struct, String, ListeningExecutorService) - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobInvoker
-
Start running a job, abstracting its state as a
JobInvocation
instance.
- invokeWithExecutor(RunnerApi.Pipeline, Struct, String, ListeningExecutorService) - Method in class org.apache.beam.runners.spark.SparkJobInvoker
-
- inWindow(BoundedWindow) - Method in interface org.apache.beam.sdk.testing.PAssert.IterableAssert
-
Creates a new
PAssert.IterableAssert
like this one, but with the assertion restricted to only
run on the provided window.
- inWindow(BoundedWindow) - Method in class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
-
- ioException() - Method in class org.apache.beam.sdk.extensions.gcp.util.GcsUtil.StorageObjectOrIOException
-
Returns the IOException
.
- IS_MERGING_WINDOW_FN - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- IS_PAIR_LIKE - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- IS_STREAM_LIKE - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- IS_WRAPPER - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- isAbsolute() - Method in class org.apache.beam.sdk.extensions.gcp.util.gcsfs.GcsPath
-
- isAccessible() - Method in interface org.apache.beam.sdk.options.ValueProvider
-
- isAccessible() - Method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
-
- isAccessible() - Method in class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
-
- isAccessible() - Method in class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
-
- isAliveOrThrow() - Method in class org.apache.beam.runners.fnexecution.environment.ProcessManager.RunningProcess
-
Checks if the underlying process is still running.
- isAllowedLatenessSpecified() - Method in class org.apache.beam.sdk.values.WindowingStrategy
-
- isArray() - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns true if this type is known to be an array type.
- isAtSplitPoint() - Method in class org.apache.beam.sdk.io.BlockBasedSource.BlockBasedReader
-
Returns true if the reader is at a split point.
- isAtSplitPoint() - Method in class org.apache.beam.sdk.io.CompressedSource.CompressedReader
-
Returns true only for the first record; compressed sources cannot be split.
- isAtSplitPoint() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
-
- isAutoBalanceWriteFilesShardingEnabled() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- isBlockOnRun() - Method in interface org.apache.beam.runners.direct.DirectOptions
-
- isBounded() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamIOSourceRel
-
- isBounded() - Method in interface org.apache.beam.sdk.extensions.sql.impl.rel.BeamRelNode
-
Whether the collection of rows represented by this relational expression is bounded (known to
be finite) or unbounded (may or may not be finite).
- isBounded() - Method in class org.apache.beam.sdk.extensions.sql.impl.schema.BeamPCollectionTable
-
- isBounded() - Method in interface org.apache.beam.sdk.extensions.sql.meta.BeamSqlTable
-
Whether this table is bounded (known to be finite) or unbounded (may or may not be finite).
- isBounded() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.avro.AvroTable
-
- isBounded() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.hcatalog.HCatalogTable
-
- isBounded() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaTable
-
- isBounded() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.mongodb.MongoDbTable
-
- isBounded() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.parquet.ParquetTable
-
- isBounded() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestBoundedTable
-
- isBounded() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestUnboundedTable
-
- isBounded() - Method in class org.apache.beam.sdk.extensions.sql.meta.provider.text.TextTable
-
- isBounded() - Method in class org.apache.beam.sdk.values.PCollection
-
- isBoundedCollection(Collection<PValue>) - Method in class org.apache.beam.runners.spark.SparkRunner.Evaluator
-
- isCacheDisabled() - Method in interface org.apache.beam.runners.spark.SparkPipelineOptions
-
- isCleanArtifactsPerJob() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobServerDriver.ServerConfiguration
-
- isClosed() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- isCollectionType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
-
- isCompatible(Trigger) - Method in class org.apache.beam.sdk.transforms.windowing.AfterPane
-
- isCompatible(Trigger) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
-
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
-
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
-
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
-
- isCompatible(Trigger) - Method in class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
-
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
-
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.GlobalWindows
-
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.InvalidWindows
-
InvalidWindows
objects with the same originalWindowFn
are compatible.
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
-
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
-
- isCompatible(Trigger) - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
-
For internal use only; no backwards-compatibility guarantees.
- isCompatible(WindowFn<?, ?>) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
- isCompositeType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
-
- isCompound() - Method in class org.apache.beam.sdk.extensions.sql.impl.TableName
-
Whether it's a compound table name (with multiple path components).
- isCompressed(String) - Static method in enum org.apache.beam.sdk.io.CompressedSource.CompressionMode
-
Deprecated.
Returns whether the file's extension matches of one of the known compression formats.
- isCompressed(String) - Method in enum org.apache.beam.sdk.io.Compression
-
- isCooperative() - Method in class org.apache.beam.runners.jet.processors.BoundedSourceP
-
- isCooperative() - Method in class org.apache.beam.runners.jet.processors.UnboundedSourceP
-
- isDateTimeType(Schema.FieldType) - Static method in class org.apache.beam.sdk.extensions.sql.impl.utils.CalciteUtils
-
Returns true if the type is any of the various date time types.
- isDateType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
-
- isDdl(String) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlEnv
-
- isDecimal(Schema.TypeName) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
-
Checks if type is decimal.
- isDirectory() - Method in class org.apache.beam.sdk.extensions.gcp.storage.GcsResourceId
-
- isDirectory() - Method in interface org.apache.beam.sdk.io.fs.ResourceId
-
Returns
true
if this
ResourceId
represents a directory, false otherwise.
- isDisjoint(IntervalWindow) - Method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow
-
Returns whether this window is disjoint from the given window.
- isDone() - Method in class org.apache.beam.sdk.fn.data.BeamFnDataInboundObserver
-
- isDone() - Method in class org.apache.beam.sdk.fn.data.CompletableFutureInboundDataClient
-
- isDone() - Method in interface org.apache.beam.sdk.fn.data.InboundDataClient
-
Returns true if the client is done, either via completing successfully or by being cancelled.
- isDone() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
-
- isDone() - Method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
-
- isDone() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
-
- isEmbeddedExecution() - Method in interface org.apache.beam.runners.apex.ApexPipelineOptions
-
- isEmbeddedExecutionDebugMode() - Method in interface org.apache.beam.runners.apex.ApexPipelineOptions
-
- isEmpty() - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.batch.functions.SparkSideInputReader
-
- isEmpty() - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.utils.CachedSideInputReader
-
- isEmpty() - Method in class org.apache.beam.runners.spark.util.CachedSideInputReader
-
- isEmpty() - Method in class org.apache.beam.runners.spark.util.SparkSideInputReader
-
- isEmpty() - Method in class org.apache.beam.sdk.io.range.ByteKey
-
Returns
true
if the
byte[]
backing this
ByteKey
is of length 0.
- isEmpty() - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
-
- isEmpty() - Method in interface org.apache.beam.sdk.state.GroupingState
-
- isEmpty() - Method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
- isEmpty() - Method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
- isEmpty() - Method in class org.apache.beam.sdk.transforms.Requirements
-
Whether this is an empty set of requirements.
- isEnableStreamingEngine() - Method in interface org.apache.beam.sdk.extensions.gcp.options.GcpOptions
-
- isEnforceEncodability() - Method in interface org.apache.beam.runners.direct.DirectOptions
-
- isEnforceImmutability() - Method in interface org.apache.beam.runners.direct.DirectOptions
-
- isEOF() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient
-
- isEOF() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubGrpcClient
-
- isEOF() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubJsonClient
-
- isEOF() - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubTestClient
-
- isEqualTo(T) - Method in interface org.apache.beam.sdk.testing.PAssert.SingletonAssert
-
Asserts that the value in question is equal to the provided value, according to Object.equals(java.lang.Object)
.
- isEqWithEpsilon(RelOptCost) - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamCostModel
-
- isExternalizedCheckpointsEnabled() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
Enables or disables externalized checkpoints.
- isFinished() - Method in class org.apache.beam.runners.apex.ApexYarnLauncher.ProcessWatcher
-
- isFirst() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
Return true if this is the first pane produced for the associated window.
- IsFlinkNativeTransform() - Constructor for class org.apache.beam.runners.flink.FlinkBatchPortablePipelineTranslator.IsFlinkNativeTransform
-
- IsFlinkNativeTransform() - Constructor for class org.apache.beam.runners.flink.FlinkStreamingPortablePipelineTranslator.IsFlinkNativeTransform
-
- isFnApi() - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.TranslationContext
-
- isForceStreaming() - Method in interface org.apache.beam.runners.spark.TestSparkPipelineOptions
-
- isForceWatermarkSync() - Method in class org.apache.beam.runners.spark.io.CreateStream
-
- isGetter(Method) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
-
- isIn(Collection<T>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- isIn(Coder<T>, Collection<T>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- isIn(T[]) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- isIn(Coder<T>, T[]) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- isInboundEdgeOfVertex(Edge, String, String, String) - Method in interface org.apache.beam.runners.jet.DAGBuilder.WiringListener
-
- isInboundEdgeOfVertex(Edge, String, String, String) - Method in class org.apache.beam.runners.jet.processors.FlattenP.Supplier
-
- IsInf - Class in org.apache.beam.sdk.extensions.sql.impl.udf
-
IS_INF(X)
- IsInf() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.udf.IsInf
-
- isInf(Double) - Method in class org.apache.beam.sdk.extensions.sql.impl.udf.IsInf
-
- isInf(Float) - Method in class org.apache.beam.sdk.extensions.sql.impl.udf.IsInf
-
- isInfinite() - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamCostModel
-
- isInputSortRelAndLimitOnly() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.AbstractBeamCalcRel
-
- isInsertDefault() - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
Returns whether or not this transformation applies a default value.
- isIntegral(Schema.TypeName) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
-
Checks if type is integral.
- isJoinLegal(Join) - Static method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamJoinRel
-
This method checks if a join is legal and can be converted into Beam SQL.
- isKey(ImmutableBitSet) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamTableStatistics
-
- isLast() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
Return true if this is the last pane that will be produced in the associated window.
- isLe(RelOptCost) - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamCostModel
-
- isLimitOnly() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSortRel
-
- isLocalSparkMaster(SparkPipelineOptions) - Static method in interface org.apache.beam.runners.spark.SparkPipelineOptions
-
Detects if the pipeline is run in spark local mode.
- isLocalSparkMaster(SparkStructuredStreamingPipelineOptions) - Static method in class org.apache.beam.runners.spark.structuredstreaming.translation.PipelineTranslator
-
Detects if the pipeline is run in local spark mode.
- isLogicalType(String) - Method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
- isLogicalType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
-
- isLt(RelOptCost) - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamCostModel
-
- isMapType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
-
- isMetricsSupported() - Static method in class org.apache.beam.sdk.metrics.MetricsEnvironment
-
Indicates whether metrics reporting is supported.
- isModeSpecified() - Method in class org.apache.beam.sdk.values.WindowingStrategy
-
- isMutable() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteSchema
-
- IsNan - Class in org.apache.beam.sdk.extensions.sql.impl.udf
-
IS_NAN(X)
- IsNan() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.udf.IsNan
-
- isNan(Float) - Method in class org.apache.beam.sdk.extensions.sql.impl.udf.IsNan
-
- isNan(Double) - Method in class org.apache.beam.sdk.extensions.sql.impl.udf.IsNan
-
- isNonMerging() - Method in class org.apache.beam.runners.gearpump.translators.GroupByKeyTranslator.GearpumpWindowFn
-
- isNonMerging() - Method in class org.apache.beam.sdk.transforms.windowing.NonMergingWindowFn
-
- isNonMerging() - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
Returns true if this WindowFn
never needs to merge any windows.
- isNullable() - Method in class org.apache.beam.sdk.schemas.FieldValueTypeInformation
-
Returns whether the field is nullable.
- isNumericType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
-
- isOneOf(T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- isOneOf(Coder<T>, T...) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- isOutboundEdgeOfVertex(Edge, String, String, String) - Method in interface org.apache.beam.runners.jet.DAGBuilder.WiringListener
-
- isOutboundEdgeOfVertex(Edge, String, String, String) - Method in class org.apache.beam.runners.jet.processors.FlattenP.Supplier
-
- isParDoFusionEnabled() - Method in interface org.apache.beam.runners.apex.ApexPipelineOptions
-
- isPrimitiveType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
-
- isReadOnly() - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- isReadSeekEfficient() - Method in class org.apache.beam.sdk.io.fs.MatchResult.Metadata
-
- isRegisterByteSizeObserverCheap(RandomAccessData) - Method in class org.apache.beam.runners.dataflow.util.RandomAccessData.RandomAccessDataCoder
-
- isRegisterByteSizeObserverCheap(BigDecimal) - Method in class org.apache.beam.sdk.coders.BigDecimalCoder
-
- isRegisterByteSizeObserverCheap(Integer) - Method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
-
- isRegisterByteSizeObserverCheap(Long) - Method in class org.apache.beam.sdk.coders.BigEndianLongCoder
-
- isRegisterByteSizeObserverCheap(Short) - Method in class org.apache.beam.sdk.coders.BigEndianShortCoder
-
- isRegisterByteSizeObserverCheap(BigInteger) - Method in class org.apache.beam.sdk.coders.BigIntegerCoder
-
- isRegisterByteSizeObserverCheap(Boolean) - Method in class org.apache.beam.sdk.coders.BooleanCoder
-
- isRegisterByteSizeObserverCheap(byte[]) - Method in class org.apache.beam.sdk.coders.ByteArrayCoder
-
- isRegisterByteSizeObserverCheap(Byte) - Method in class org.apache.beam.sdk.coders.ByteCoder
-
- isRegisterByteSizeObserverCheap(T) - Method in class org.apache.beam.sdk.coders.Coder
-
- isRegisterByteSizeObserverCheap(Double) - Method in class org.apache.beam.sdk.coders.DoubleCoder
-
- isRegisterByteSizeObserverCheap(ReadableDuration) - Method in class org.apache.beam.sdk.coders.DurationCoder
-
- isRegisterByteSizeObserverCheap(Float) - Method in class org.apache.beam.sdk.coders.FloatCoder
-
- isRegisterByteSizeObserverCheap(Instant) - Method in class org.apache.beam.sdk.coders.InstantCoder
-
- isRegisterByteSizeObserverCheap(IterableT) - Method in class org.apache.beam.sdk.coders.IterableLikeCoder
-
- isRegisterByteSizeObserverCheap(KV<K, V>) - Method in class org.apache.beam.sdk.coders.KvCoder
-
Returns whether both keyCoder and valueCoder are considered not expensive.
- isRegisterByteSizeObserverCheap(T) - Method in class org.apache.beam.sdk.coders.LengthPrefixCoder
-
LengthPrefixCoder
is cheap if valueCoder
is cheap.
- isRegisterByteSizeObserverCheap(T) - Method in class org.apache.beam.sdk.coders.NullableCoder
-
NullableCoder
is cheap if valueCoder
is cheap.
- isRegisterByteSizeObserverCheap(Integer) - Method in class org.apache.beam.sdk.coders.VarIntCoder
-
- isRegisterByteSizeObserverCheap(Long) - Method in class org.apache.beam.sdk.coders.VarLongCoder
-
- isRegisterByteSizeObserverCheap(Void) - Method in class org.apache.beam.sdk.coders.VoidCoder
-
- isRegisterByteSizeObserverCheap(ByteString) - Method in class org.apache.beam.sdk.extensions.protobuf.ByteStringCoder
-
- isRegisterByteSizeObserverCheap(HyperLogLogPlus) - Method in class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct.HyperLogLogPlusCoder
-
- isRegisterByteSizeObserverCheap(EncodedBoundedWindow) - Method in class org.apache.beam.sdk.fn.windowing.EncodedBoundedWindow.Coder
-
- isRegisterByteSizeObserverCheap(KafkaRecord<K, V>) - Method in class org.apache.beam.sdk.io.kafka.KafkaRecordCoder
-
- isRegisterByteSizeObserverCheap(ProducerRecord<K, V>) - Method in class org.apache.beam.sdk.io.kafka.ProducerRecordCoder
-
- isRegisterByteSizeObserverCheap(OffsetRange) - Method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
-
- isRegisterByteSizeObserverCheap(RawUnionValue) - Method in class org.apache.beam.sdk.transforms.join.UnionCoder
-
Since this coder uses elementCoders.get(index) and coders that are known to run in constant
time, we defer the return value to that coder.
- isRunnerDeterminedSharding() - Method in interface org.apache.beam.runners.direct.DirectTestOptions
-
- isSetter(Method) - Static method in class org.apache.beam.sdk.schemas.utils.ReflectUtils
-
- isShutdownSourcesOnFinalWatermark() - Method in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
Whether to shutdown sources when their watermark reaches +Inf
.
- isSideInputLookupJoin() - Method in class org.apache.beam.sdk.extensions.sql.impl.rel.BeamJoinRel
-
- isSimple() - Method in class org.apache.beam.sdk.extensions.sql.impl.TableName
-
Whether it's a simple name, with a single name component.
- isSplittable() - Method in class org.apache.beam.sdk.io.CompressedSource
-
Determines whether a single file represented by this source is splittable.
- isSplittable() - Method in class org.apache.beam.sdk.io.FileBasedSource
-
Determines whether a file represented by this source is can be split into bundles.
- isStarted() - Method in class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
-
- isStarted() - Method in class org.apache.beam.sdk.io.range.OffsetRangeTracker
-
- isStreaming() - Method in interface org.apache.beam.sdk.options.StreamingOptions
-
Set to true if running a streaming pipeline.
- isStreamingEngine() - Method in interface org.apache.beam.runners.dataflow.TransformTranslator.TranslationContext
-
- isStringType(Schema.FieldType) - Static method in class org.apache.beam.sdk.extensions.sql.impl.utils.CalciteUtils
-
- isStringType() - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
-
- isSubtypeOf(Schema.TypeName) - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
-
- isSubtypeOf(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Return true if this type is a subtype of the given type.
- isSuccess() - Method in class org.apache.beam.sdk.io.tika.ParseResult
-
Returns whether this file was parsed successfully.
- isSuccess() - Method in class org.apache.beam.sdk.testing.SuccessOrFailure
-
- isSupertypeOf(Schema.TypeName) - Method in enum org.apache.beam.sdk.schemas.Schema.TypeName
-
Whether this is a super type of the another type.
- isSupertypeOf(TypeDescriptor<?>) - Method in class org.apache.beam.sdk.values.TypeDescriptor
-
Returns true if this type is assignable from the given type.
- isSupported() - Method in enum org.apache.beam.sdk.extensions.sql.meta.ProjectSupport
-
- isTableEmpty(TableReference) - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryServices.DatasetService
-
Returns true if the table is empty.
- isTableEmpty(TableReference) - Method in class org.apache.beam.sdk.io.gcp.testing.FakeDatasetService
-
- isTableResolved(Table) - Method in class org.apache.beam.sdk.extensions.sql.zetasql.QueryTrait
-
True if the table was resolved using the Calcite schema.
- isTermainal() - Method in enum org.apache.beam.runners.local.ExecutionDriver.DriverState
-
- isTerminal() - Method in enum org.apache.beam.sdk.PipelineResult.State
-
- isTimestampCombinerSpecified() - Method in class org.apache.beam.sdk.values.WindowingStrategy
-
- isTriggerSpecified() - Method in class org.apache.beam.sdk.values.WindowingStrategy
-
- isTrustSelfSignedCerts() - Method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.ConnectionConfiguration
-
- isTupleTracingEnabled() - Method in interface org.apache.beam.runners.apex.ApexPipelineOptions
-
- isUnknown() - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamTableStatistics
-
- isUnknown() - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.NodeStats
-
If any of the values for rowCount, rate or window is infinite, it returns true.
- isUnknown() - Method in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
Return true if there is no timing information for the current
PaneInfo
.
- isUpdate() - Method in interface org.apache.beam.runners.dataflow.options.DataflowPipelineOptions
-
Whether to update the currently running pipeline with the same name as this one.
- isValid(int) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- isWholeStream - Variable in class org.apache.beam.sdk.coders.Coder.Context
-
Deprecated.
Whether the encoded or decoded value fills the remainder of the output or input (resp.)
record/stream contents.
- isWildcard(GcsPath) - Static method in class org.apache.beam.sdk.extensions.gcp.util.GcsUtil
-
Returns true if the given spec
contains wildcard.
- isWrapperFor(Class<?>) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- isZero() - Method in class org.apache.beam.runners.spark.aggregators.NamedAggregatorsAccumulator
-
- isZero() - Method in class org.apache.beam.runners.spark.metrics.MetricsContainerStepMapAccumulator
-
- isZero() - Method in class org.apache.beam.runners.spark.structuredstreaming.aggregators.NamedAggregatorsAccumulator
-
- isZero() - Method in class org.apache.beam.runners.spark.structuredstreaming.metrics.MetricsContainerStepMapAccumulator
-
- item(String, String) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and string value.
- item(String, ValueProvider<?>) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
- item(String, Integer) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and integer value.
- item(String, Long) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and integer value.
- item(String, Float) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and floating point value.
- item(String, Double) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and floating point value.
- item(String, Boolean) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and boolean value.
- item(String, Instant) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and timestamp value.
- item(String, Duration) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and duration value.
- item(String, Class<T>) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key and class value.
- item(String, DisplayData.Type, T) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData
-
Create a display item for the specified key, type, and value.
- Item() - Constructor for class org.apache.beam.sdk.transforms.display.DisplayData.Item
-
- items() - Method in class org.apache.beam.sdk.io.aws.dynamodb.DynamoDBIO.Read
-
- items() - Method in class org.apache.beam.sdk.io.aws2.dynamodb.DynamoDBIO.Read
-
- items() - Method in class org.apache.beam.sdk.transforms.display.DisplayData
-
- ItemSpec() - Constructor for class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
-
- iterable(Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
- iterable() - Static method in class org.apache.beam.sdk.transforms.Materializations
-
For internal use only; no backwards-compatibility guarantees.
- ITERABLE_MATERIALIZATION_URN - Static variable in class org.apache.beam.sdk.transforms.Materializations
-
The URN for a
Materialization
where the primitive view type is an iterable of fully
specified windowed values.
- IterableCoder<T> - Class in org.apache.beam.sdk.coders
-
- IterableCoder(Coder<T>) - Constructor for class org.apache.beam.sdk.coders.IterableCoder
-
- IterableLikeCoder<T,IterableT extends java.lang.Iterable<T>> - Class in org.apache.beam.sdk.coders
-
An abstract base class with functionality for assembling a
Coder
for a class that
implements
Iterable
.
- IterableLikeCoder(Coder<T>, String) - Constructor for class org.apache.beam.sdk.coders.IterableLikeCoder
-
- iterables() - Static method in class org.apache.beam.sdk.transforms.Flatten
-
Returns a PTransform
that takes a PCollection<Iterable<T>>
and returns a PCollection<T>
containing all the elements from all the Iterable
s.
- iterables() - Static method in class org.apache.beam.sdk.transforms.ToString
-
Transforms each item in the iterable of the input
PCollection
to a
String
using
the
Object.toString()
method followed by a "," until the last element in the iterable.
- iterables(String) - Static method in class org.apache.beam.sdk.transforms.ToString
-
Transforms each item in the iterable of the input
PCollection
to a
String
using
the
Object.toString()
method followed by the specified delimiter until the last element
in the iterable.
- iterables(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
- iterableView(PCollection<KV<Void, T>>, PCollectionViews.TypeDescriptorSupplier<T>, WindowingStrategy<?, W>) - Static method in class org.apache.beam.sdk.values.PCollectionViews
-
Returns a
PCollectionView<Iterable<T>>
capable of processing elements windowed using
the provided
WindowingStrategy
.
- IterableViewFn(PCollectionViews.TypeDescriptorSupplier<T>) - Constructor for class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn
-
- iterableWithSize(int) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- iterableWithSize(SerializableMatcher<? super Integer>) - Static method in class org.apache.beam.sdk.testing.SerializableMatchers
-
- iterator() - Method in class org.apache.beam.sdk.extensions.gcp.util.gcsfs.GcsPath
-
- iterator() - Method in class org.apache.beam.sdk.io.gcp.spanner.MutationGroup
-
- iterator() - Method in class org.apache.beam.sdk.io.gcp.testing.FakeBigQueryServices.FakeBigQueryServerStream
-
- OBJECT_MAPPER - Static variable in class org.apache.beam.sdk.extensions.sql.impl.JdbcDriver
-
- OBJECT_TYPE_NAME - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- observe(RestrictionTracker<RestrictionT, PositionT>, RestrictionTrackers.ClaimObserver<PositionT>) - Static method in class org.apache.beam.sdk.fn.splittabledofn.RestrictionTrackers
-
- of(PCollectionView<ViewT>) - Static method in class org.apache.beam.runners.apex.ApexRunner.CreateApexPCollectionView
-
- of() - Static method in class org.apache.beam.runners.dataflow.util.RandomAccessData.RandomAccessDataCoder
-
- of(BeamFnApi.ProcessBundleDescriptor, Map<String, RemoteInputDestination>, Map<String, Coder>, Map<String, Map<String, ProcessBundleDescriptors.SideInputSpec>>, Map<String, Map<String, ProcessBundleDescriptors.BagUserStateSpec>>, Map<String, Map<String, ProcessBundleDescriptors.TimerSpec>>) - Static method in class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors.ExecutableProcessBundleDescriptor
-
- of(String, String, RunnerApi.FunctionSpec, Coder<T>, Coder<W>) - Static method in class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors.SideInputSpec
-
- of(Coder<T>, FnDataReceiver<T>) - Static method in class org.apache.beam.runners.fnexecution.control.RemoteOutputReceiver
-
- of(Coder<T>, String) - Static method in class org.apache.beam.runners.fnexecution.data.RemoteInputDestination
-
- of(K, Coder<K>) - Static method in class org.apache.beam.runners.local.StructuralKey
-
Create a new Structural Key of the provided key that can be encoded by the provided coder.
- of(T, CloseableResource.Closer<T>) - Static method in class org.apache.beam.runners.portability.CloseableResource
-
- of(JobApi.MetricResults) - Static method in class org.apache.beam.runners.portability.PortableMetrics
-
- of(Coder<T>, Duration, boolean) - Static method in class org.apache.beam.runners.spark.io.CreateStream
-
Creates a new Spark based stream intended for test purposes.
- of(Coder<T>, Duration) - Static method in class org.apache.beam.runners.spark.io.CreateStream
-
Creates a new Spark based stream without forced watermark sync, intended for test purposes.
- of(NamedAggregators) - Static method in class org.apache.beam.runners.spark.metrics.AggregatorMetric
-
- of(NamedAggregators) - Static method in class org.apache.beam.runners.spark.structuredstreaming.metrics.AggregatorMetric
-
- of(Coder<TupleTag>, Map<TupleTag<?>, Coder<?>>, Coder<? extends BoundedWindow>) - Static method in class org.apache.beam.runners.spark.structuredstreaming.translation.helpers.MultiOuputCoder
-
- of(SideInputReader) - Static method in class org.apache.beam.runners.spark.structuredstreaming.translation.utils.CachedSideInputReader
-
Create a new cached SideInputReader
.
- of(SideInputReader) - Static method in class org.apache.beam.runners.spark.util.CachedSideInputReader
-
Create a new cached SideInputReader
.
- of(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.coders.AvroCoder
-
Returns an AvroCoder
instance for the provided element type.
- of(Class<T>) - Static method in class org.apache.beam.sdk.coders.AvroCoder
-
Returns an AvroCoder
instance for the provided element class.
- of(Schema) - Static method in class org.apache.beam.sdk.coders.AvroCoder
-
Returns an AvroGenericCoder
instance for the Avro schema.
- of(Class<T>, Schema) - Static method in class org.apache.beam.sdk.coders.AvroCoder
-
Returns an AvroCoder
instance for the provided element type using the provided Avro
schema.
- of(Schema) - Static method in class org.apache.beam.sdk.coders.AvroGenericCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.BigDecimalCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.BigEndianIntegerCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.BigEndianLongCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.BigEndianShortCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.BigIntegerCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.BitSetCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.BooleanCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.ByteArrayCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.ByteCoder
-
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.CollectionCoder
-
- of(Coder<IntermediateT>, DelegateCoder.CodingFunction<T, IntermediateT>, DelegateCoder.CodingFunction<IntermediateT, T>) - Static method in class org.apache.beam.sdk.coders.DelegateCoder
-
- of(Coder<IntermediateT>, DelegateCoder.CodingFunction<T, IntermediateT>, DelegateCoder.CodingFunction<IntermediateT, T>, TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.coders.DelegateCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.DoubleCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.DurationCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.FloatCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.InstantCoder
-
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.IterableCoder
-
- of(Coder<K>, Coder<V>) - Static method in class org.apache.beam.sdk.coders.KvCoder
-
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.LengthPrefixCoder
-
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.ListCoder
-
- of(Coder<K>, Coder<V>) - Static method in class org.apache.beam.sdk.coders.MapCoder
-
Produces a MapCoder with the given keyCoder and valueCoder.
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.NullableCoder
-
- of(Schema) - Static method in class org.apache.beam.sdk.coders.RowCoder
-
- of(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.coders.SerializableCoder
-
- of(Class<T>) - Static method in class org.apache.beam.sdk.coders.SerializableCoder
-
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.SetCoder
-
Produces a
SetCoder
with the given
elementCoder
.
- of(Coder<KeyT>) - Static method in class org.apache.beam.sdk.coders.ShardedKeyCoder
-
- of(Coder<T>) - Static method in class org.apache.beam.sdk.coders.SnappyCoder
-
- of(Class<T>) - Static method in class org.apache.beam.sdk.coders.StringDelegateCoder
-
- of(Class<T>, TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.coders.StringDelegateCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.StringUtf8Coder
-
- of() - Static method in class org.apache.beam.sdk.coders.TextualIntegerCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.VarIntCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.VarLongCoder
-
- of() - Static method in class org.apache.beam.sdk.coders.VoidCoder
-
- of(Class<? extends InputT>) - Static method in class org.apache.beam.sdk.extensions.jackson.AsJsons
-
- of(Class<? extends OutputT>) - Static method in class org.apache.beam.sdk.extensions.jackson.ParseJsons
-
- of() - Static method in class org.apache.beam.sdk.extensions.protobuf.ByteStringCoder
-
- of(Descriptors.Descriptor) - Static method in class org.apache.beam.sdk.extensions.protobuf.DynamicProtoCoder
-
- of(ProtoDomain, Descriptors.Descriptor) - Static method in class org.apache.beam.sdk.extensions.protobuf.DynamicProtoCoder
-
- of(ProtoDomain, String) - Static method in class org.apache.beam.sdk.extensions.protobuf.DynamicProtoCoder
-
- of(Class<T>) - Static method in class org.apache.beam.sdk.extensions.protobuf.ProtoCoder
-
- of(TypeDescriptor<T>) - Static method in class org.apache.beam.sdk.extensions.protobuf.ProtoCoder
-
- of() - Static method in class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct.HyperLogLogPlusCoder
-
- of(BeamSqlTable) - Static method in class org.apache.beam.sdk.extensions.sql.impl.BeamCalciteTable
-
- of(Object...) - Static method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestBoundedTable
-
Convenient way to build a mocked bounded table.
- of(Schema) - Static method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestBoundedTable
-
Build a mocked bounded table with the specified type.
- of(Object...) - Static method in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestUnboundedTable
-
Convenient way to build a mocked unbounded table.
- of(FrameworkConfig, ExpressionConverter, RelOptCluster, QueryTrait) - Static method in class org.apache.beam.sdk.extensions.sql.zetasql.translation.ConversionContext
-
- of(String, String) - Static method in class org.apache.beam.sdk.fn.data.LogicalEndpoint
-
- of() - Static method in class org.apache.beam.sdk.io.aws.dynamodb.AttributeValueCoder
-
- of() - Static method in class org.apache.beam.sdk.io.aws2.dynamodb.AttributeValueCoder
-
- of(String, TableSchema.ColumnType) - Static method in class org.apache.beam.sdk.io.clickhouse.TableSchema.Column
-
- of(String, TableSchema.ColumnType, TableSchema.DefaultType, Object) - Static method in class org.apache.beam.sdk.io.clickhouse.TableSchema.Column
-
- of(TableSchema.TypeName) - Static method in class org.apache.beam.sdk.io.clickhouse.TableSchema.ColumnType
-
- of(TableSchema.Column...) - Static method in class org.apache.beam.sdk.io.clickhouse.TableSchema
-
- of() - Static method in class org.apache.beam.sdk.io.DefaultFilenamePolicy.ParamsCoder
-
- of(Coder<BoundedWindow>, Coder<DestinationT>) - Static method in class org.apache.beam.sdk.io.FileBasedSink.FileResultCoder
-
- of() - Static method in class org.apache.beam.sdk.io.fs.MetadataCoder
-
- of() - Static method in class org.apache.beam.sdk.io.fs.MetadataCoderV2
-
- of() - Static method in class org.apache.beam.sdk.io.fs.ResourceIdCoder
-
- of() - Static method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryInsertErrorCoder
-
- of() - Static method in class org.apache.beam.sdk.io.gcp.bigquery.TableDestinationCoder
-
- of() - Static method in class org.apache.beam.sdk.io.gcp.bigquery.TableDestinationCoderV2
-
- of() - Static method in class org.apache.beam.sdk.io.gcp.bigquery.TableDestinationCoderV3
-
- of() - Static method in class org.apache.beam.sdk.io.gcp.bigquery.TableRowJsonCoder
-
- of() - Static method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableWriteResultCoder
-
- of(PubsubMessage, long, String) - Static method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.OutgoingMessage
-
- of(PubsubMessage, long, String) - Static method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.OutgoingMessage
-
- of() - Static method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessagePayloadOnlyCoder
-
- of(TypeDescriptor<PubsubMessage>) - Static method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessageWithAttributesAndMessageIdCoder
-
- of() - Static method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessageWithAttributesAndMessageIdCoder
-
- of(TypeDescriptor<PubsubMessage>) - Static method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessageWithAttributesCoder
-
- of() - Static method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessageWithAttributesCoder
-
- of() - Static method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessageWithMessageIdCoder
-
- of(Class<T>) - Static method in class org.apache.beam.sdk.io.hadoop.WritableCoder
-
Returns a WritableCoder
instance for the provided element class.
- of(String, Scan) - Static method in class org.apache.beam.sdk.io.hbase.HBaseQuery
-
- of(JdbcIO.DataSourceConfiguration) - Static method in class org.apache.beam.sdk.io.jdbc.JdbcIO.DataSourceProviderFromDataSourceConfiguration
-
- of(JdbcIO.DataSourceConfiguration) - Static method in class org.apache.beam.sdk.io.jdbc.JdbcIO.PoolableDataSourceProvider
-
- of(String, String) - Static method in class org.apache.beam.sdk.io.kafka.ConfluentSchemaRegistryDeserializerProvider
-
- of(String, String, Integer) - Static method in class org.apache.beam.sdk.io.kafka.ConfluentSchemaRegistryDeserializerProvider
-
- of(Coder<K>, Coder<V>) - Static method in class org.apache.beam.sdk.io.kafka.KafkaRecordCoder
-
- of(Coder<K>, Coder<V>) - Static method in class org.apache.beam.sdk.io.kafka.ProducerRecordCoder
-
- of(int...) - Static method in class org.apache.beam.sdk.io.range.ByteKey
-
Creates a new
ByteKey
backed by a copy of the specified
int[]
.
- of(ByteKey, ByteKey) - Static method in class org.apache.beam.sdk.io.range.ByteKeyRange
-
Creates a new
ByteKeyRange
with the given start and end keys.
- of(ByteKeyRange) - Static method in class org.apache.beam.sdk.io.range.ByteKeyRangeTracker
-
- of() - Static method in class org.apache.beam.sdk.io.range.OffsetRange.Coder
-
- of() - Static method in class org.apache.beam.sdk.io.ReadableFileCoder
-
- of(Class<T>) - Static method in class org.apache.beam.sdk.io.xml.JAXBCoder
-
Create a coder for a given type of JAXB annotated objects.
- of(ValueProvider<X>, SerializableFunction<X, T>) - Static method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
-
- of(T) - Static method in class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
-
- of(FieldAccessDescriptor.FieldDescriptor.ListQualifier) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
-
- of(FieldAccessDescriptor.FieldDescriptor.MapQualifier) - Static method in class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
-
- of(int) - Static method in class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
-
- of(String, Schema.FieldType) - Static method in class org.apache.beam.sdk.schemas.Schema.Field
-
Return's a field with the give name and type.
- of(Schema.TypeName) - Static method in class org.apache.beam.sdk.schemas.Schema.FieldType
-
- of(Schema.Field...) - Static method in class org.apache.beam.sdk.schemas.Schema
-
- of(Schema, TypeDescriptor<T>, SerializableFunction<T, Row>, SerializableFunction<Row, T>) - Static method in class org.apache.beam.sdk.schemas.SchemaCoder
-
- of(Schema) - Static method in class org.apache.beam.sdk.schemas.SchemaCoder
-
- of() - Static method in class org.apache.beam.sdk.schemas.transforms.Cast.Narrowing
-
- of(Schema, Cast.Validator) - Static method in class org.apache.beam.sdk.schemas.transforms.Cast
-
- of() - Static method in class org.apache.beam.sdk.schemas.transforms.Cast.Widening
-
- of(Coder<T>) - Static method in class org.apache.beam.sdk.testing.TestStream.TestStreamCoder
-
- of(SerializableBiFunction<V, V, V>) - Static method in class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
-
Returns a CombineFn
that uses the given SerializableBiFunction
to combine
values.
- of(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
-
Returns a CombineFn
that uses the given SerializableFunction
to combine
values.
- of(SerializableFunction<Iterable<V>, V>, int) - Static method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
-
Returns a CombineFn
that uses the given SerializableFunction
to combine
values, attempting to buffer at least bufferSize
values between invocations.
- of(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine.SimpleCombineFn
-
Deprecated.
Returns a CombineFn
that uses the given SerializableFunction
to combine
values.
- of(ClosureT, Requirements) - Static method in class org.apache.beam.sdk.transforms.Contextful
-
Constructs a pair of the given closure and its requirements.
- of(Iterable<T>) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns a new
Create.Values
transform that produces a
PCollection
containing
elements of the provided
Iterable
.
- of(T, T...) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns a new
Create.Values
transform that produces a
PCollection
containing
the specified elements.
- of(Map<K, V>) - Static method in class org.apache.beam.sdk.transforms.Create
-
Returns a new
Create.Values
transform that produces a
PCollection
of
KV
s corresponding to the keys and values of the specified
Map
.
- of(DisplayData.Path, Class<?>, String) - Static method in class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
-
- of(DoFn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.DoFnTester
-
- of(CoGbkResultSchema, UnionCoder) - Static method in class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
-
- of(TupleTag<V>, List<V>) - Static method in class org.apache.beam.sdk.transforms.join.CoGbkResult
-
Returns a new CoGbkResult that contains just the given tag and given data.
- of(List<TupleTag<?>>) - Static method in class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
-
- of(TupleTag<InputT>, PCollection<KV<K, InputT>>) - Static method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
Returns a new KeyedPCollectionTuple<K>
with the given tag and initial PCollection.
- of(String, PCollection<KV<K, InputT>>) - Static method in class org.apache.beam.sdk.transforms.join.KeyedPCollectionTuple
-
- of(List<Coder<?>>) - Static method in class org.apache.beam.sdk.transforms.join.UnionCoder
-
Builds a union coder with the given list of element coders.
- of(T, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Max
-
- of(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Max
-
- of() - Static method in class org.apache.beam.sdk.transforms.Mean
-
A Combine.CombineFn
that computes the arithmetic mean (a.k.a.
- of(T, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Min
-
- of(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Min
-
- of(DoFn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.transforms.ParDo
-
- of(int, Partition.PartitionFn<? super T>) - Static method in class org.apache.beam.sdk.transforms.Partition
-
Returns a new Partition
PTransform
that divides its input PCollection
into the given number of partitions, using the given partitioning function.
- of() - Static method in class org.apache.beam.sdk.transforms.Reshuffle
-
Deprecated.
- of(ByteKeyRange) - Static method in class org.apache.beam.sdk.transforms.splittabledofn.ByteKeyRangeTracker
-
- of(RestrictionT, RestrictionT) - Static method in class org.apache.beam.sdk.transforms.splittabledofn.SplitResult
-
Returns a
SplitResult
for the specified primary and residual restrictions.
- of() - Static method in class org.apache.beam.sdk.transforms.ToJson
-
- of(int, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a PTransform
that takes an input PCollection<T>
and returns a PCollection<List<T>>
with a single element containing the largest count
elements of
the input PCollection<T>
, in decreasing order, sorted using the given Comparator<T>
.
- of(PCollectionView<ViewT>) - Static method in class org.apache.beam.sdk.transforms.View.CreatePCollectionView
-
- of(Trigger.OnceTrigger...) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterAll
-
Returns an AfterAll
Trigger
with the given subtriggers.
- of(List<Trigger>) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterAll
-
Returns an AfterAll
Trigger
with the given subtriggers.
- of(Trigger.OnceTrigger...) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterFirst
-
Returns an AfterFirst
Trigger
with the given subtriggers.
- of(List<Trigger>) - Static method in class org.apache.beam.sdk.transforms.windowing.AfterFirst
-
Returns an AfterFirst
Trigger
with the given subtriggers.
- of() - Static method in class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
-
Returns the default trigger.
- of(Duration) - Static method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
-
Partitions the timestamp space into half-open intervals of the form [N * size, (N + 1) * size),
where 0 is the epoch.
- of() - Static method in class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
-
- of() - Static method in class org.apache.beam.sdk.transforms.windowing.PaneInfo.PaneInfoCoder
-
- of(Duration) - Static method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
-
Assigns timestamps into half-open intervals of the form [N * period, N * period + size), where
0 is the epoch.
- of(T, Exception) - Static method in class org.apache.beam.sdk.transforms.WithFailures.ExceptionElement
-
- of(OutputT, PCollection<FailureElementT>) - Static method in class org.apache.beam.sdk.transforms.WithFailures.Result
-
- of(PCollection<OutputElementT>, PCollection<FailureElementT>) - Static method in class org.apache.beam.sdk.transforms.WithFailures.Result
-
- of(PCollectionTuple, TupleTag<OutputElementT>, TupleTag<FailureElementT>) - Static method in class org.apache.beam.sdk.transforms.WithFailures.Result
-
- of(SerializableFunction<V, K>) - Static method in class org.apache.beam.sdk.transforms.WithKeys
-
Returns a PTransform
that takes a PCollection<V>
and returns a PCollection<KV<K, V>>
, where each of the values in the input PCollection
has been
paired with a key computed from the value by invoking the given SerializableFunction
.
- of(K) - Static method in class org.apache.beam.sdk.transforms.WithKeys
-
Returns a PTransform
that takes a PCollection<V>
and returns a PCollection<KV<K, V>>
, where each of the values in the input PCollection
has been
paired with the given key.
- of(SerializableFunction<T, Instant>) - Static method in class org.apache.beam.sdk.transforms.WithTimestamps
-
- of(K, V) - Static method in class org.apache.beam.sdk.values.KV
-
Returns a
KV
with the given key and value.
- of(PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionList
-
- of(Iterable<PCollection<T>>) - Static method in class org.apache.beam.sdk.values.PCollectionList
-
- of(TupleTag<T>, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
- of(String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
- of(String, PCollection<T>, String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
- of(String, PCollection<T>, String, PCollection<T>, String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
- of(String, PCollection<T>, String, PCollection<T>, String, PCollection<T>, String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
- of(String, PCollection<T>, String, PCollection<T>, String, PCollection<T>, String, PCollection<T>, String, PCollection<T>) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
- of(K, int) - Static method in class org.apache.beam.sdk.values.ShardedKey
-
- of(TupleTag<?>, PValue) - Static method in class org.apache.beam.sdk.values.TaggedPValue
-
- of(V, Instant) - Static method in class org.apache.beam.sdk.values.TimestampedValue
-
Returns a new TimestampedValue
with the given value and timestamp.
- of(Coder<T>) - Static method in class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
-
- of(TupleTag<?>) - Static method in class org.apache.beam.sdk.values.TupleTagList
-
- of(List<TupleTag<?>>) - Static method in class org.apache.beam.sdk.values.TupleTagList
-
- of(Class<T>) - Static method in class org.apache.beam.sdk.values.TypeDescriptor
-
- of(Type) - Static method in class org.apache.beam.sdk.values.TypeDescriptor
-
- of(Coder<T>, Coder<? extends BoundedWindow>) - Static method in class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
-
- of(T, Instant, BoundedWindow, PaneInfo) - Static method in class org.apache.beam.sdk.values.ValueInSingleWindow
-
- of(Coder<ValueT>) - Static method in class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
-
- of(WindowFn<T, W>) - Static method in class org.apache.beam.sdk.values.WindowingStrategy
-
- ofDoubles() - Static method in class org.apache.beam.sdk.transforms.Max
-
- ofDoubles() - Static method in class org.apache.beam.sdk.transforms.Min
-
- ofDoubles() - Static method in class org.apache.beam.sdk.transforms.Sum
-
- ofExpandedValue(PValue) - Static method in class org.apache.beam.sdk.values.TaggedPValue
-
- offerCoders(Coder[]) - Method in interface org.apache.beam.sdk.state.StateSpec
-
For internal use only; no backwards-compatibility guarantees.
- offeringClientsToPool(ControlClientPool.Sink, HeaderAccessor) - Static method in class org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService
-
- ofFirstElement() - Static method in class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
-
- offset(Duration) - Method in interface org.apache.beam.sdk.state.Timer
-
- OFFSET_INFINITY - Static variable in class org.apache.beam.sdk.io.range.OffsetRangeTracker
-
Offset corresponding to infinity.
- OffsetBasedReader(OffsetBasedSource<T>) - Constructor for class org.apache.beam.sdk.io.OffsetBasedSource.OffsetBasedReader
-
- OffsetBasedSource<T> - Class in org.apache.beam.sdk.io
-
A
BoundedSource
that uses offsets to define starting and ending positions.
- OffsetBasedSource(long, long, long) - Constructor for class org.apache.beam.sdk.io.OffsetBasedSource
-
- OffsetBasedSource.OffsetBasedReader<T> - Class in org.apache.beam.sdk.io
-
- OffsetRange - Class in org.apache.beam.sdk.io.range
-
A restriction represented by a range of integers [from, to).
- OffsetRange(long, long) - Constructor for class org.apache.beam.sdk.io.range.OffsetRange
-
- OffsetRange.Coder - Class in org.apache.beam.sdk.io.range
-
- OffsetRangeTracker - Class in org.apache.beam.sdk.io.range
-
- OffsetRangeTracker(long, long) - Constructor for class org.apache.beam.sdk.io.range.OffsetRangeTracker
-
Creates an OffsetRangeTracker
for the specified range.
- OffsetRangeTracker - Class in org.apache.beam.sdk.transforms.splittabledofn
-
- OffsetRangeTracker(OffsetRange) - Constructor for class org.apache.beam.sdk.transforms.splittabledofn.OffsetRangeTracker
-
- ofIntegers() - Static method in class org.apache.beam.sdk.transforms.Max
-
- ofIntegers() - Static method in class org.apache.beam.sdk.transforms.Min
-
- ofIntegers() - Static method in class org.apache.beam.sdk.transforms.Sum
-
- ofLongs() - Static method in class org.apache.beam.sdk.transforms.Max
-
- ofLongs() - Static method in class org.apache.beam.sdk.transforms.Min
-
- ofLongs() - Static method in class org.apache.beam.sdk.transforms.Sum
-
- ofNamed(Map<String, ?>) - Static method in class org.apache.beam.sdk.extensions.sql.impl.QueryPlanner.QueryParameters
-
- ofNone() - Static method in class org.apache.beam.sdk.extensions.sql.impl.QueryPlanner.QueryParameters
-
- ofPositional(List) - Static method in class org.apache.beam.sdk.extensions.sql.impl.QueryPlanner.QueryParameters
-
- ofPrimitiveOutputsInternal(Pipeline, TupleTagList, Map<TupleTag<?>, Coder<?>>, WindowingStrategy<?, ?>, PCollection.IsBounded) - Static method in class org.apache.beam.sdk.values.PCollectionTuple
-
For internal use only; no backwards-compatibility guarantees.
- ofProvider(ValueProvider<T>, Coder<T>) - Static method in class org.apache.beam.sdk.transforms.Create
-
- ofSize(long) - Static method in class org.apache.beam.sdk.transforms.GroupIntoBatches
-
- on(Join.FieldsEqual.Impl) - Method in class org.apache.beam.sdk.schemas.transforms.Join.Impl
-
Join the PCollections using the provided predicate.
- on(PCollection<?>...) - Static method in class org.apache.beam.sdk.transforms.Wait
-
Waits on the given signal collections.
- on(List<PCollection<?>>) - Static method in class org.apache.beam.sdk.transforms.Wait
-
Waits on the given signal collections.
- ON_TIME_AND_ONLY_FIRING - Static variable in class org.apache.beam.sdk.transforms.windowing.PaneInfo
-
PaneInfo
to use when there will be exactly one firing and it is on time.
- onAdvance(int, int) - Method in class org.apache.beam.sdk.fn.stream.AdvancingPhaser
-
- onBatchCompleted(JavaStreamingListenerBatchCompleted) - Method in class org.apache.beam.runners.spark.aggregators.AggregatorsAccumulator.AccumulatorCheckpointingSparkListener
-
- onBatchCompleted(JavaStreamingListenerBatchCompleted) - Method in class org.apache.beam.runners.spark.metrics.MetricsAccumulator.AccumulatorCheckpointingSparkListener
-
- onBatchCompleted(JavaStreamingListenerBatchCompleted) - Method in class org.apache.beam.runners.spark.util.GlobalWatermarkHolder.WatermarkAdvancingStreamingListener
-
- onBundleSuccess() - Method in interface org.apache.beam.sdk.transforms.DoFn.BundleFinalizer.Callback
-
- OnceTrigger(List<Trigger>) - Constructor for class org.apache.beam.sdk.transforms.windowing.Trigger.OnceTrigger
-
- onCheckpoint(BeamFnApi.ProcessBundleResponse) - Method in interface org.apache.beam.runners.fnexecution.control.BundleCheckpointHandler
-
- onClaimed(PositionT) - Method in interface org.apache.beam.sdk.fn.splittabledofn.RestrictionTrackers.ClaimObserver
-
- onClaimFailed(PositionT) - Method in interface org.apache.beam.sdk.fn.splittabledofn.RestrictionTrackers.ClaimObserver
-
- onClose(Consumer<FnApiControlClient>) - Method in class org.apache.beam.runners.fnexecution.control.FnApiControlClient
-
- onCompleted(BeamFnApi.ProcessBundleResponse) - Method in interface org.apache.beam.runners.fnexecution.control.BundleProgressHandler
-
Handles the bundle's completion report.
- onCompleted() - Method in class org.apache.beam.sdk.fn.stream.BufferingStreamObserver
-
- onCompleted() - Method in class org.apache.beam.sdk.fn.stream.DirectStreamObserver
-
- onCompleted() - Method in class org.apache.beam.sdk.fn.stream.ForwardingClientResponseObserver
-
- onCompleted() - Method in class org.apache.beam.sdk.fn.stream.SynchronizedStreamObserver
-
- OneOfType - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A logical type representing a union of fields.
- OneOfType.Value - Class in org.apache.beam.sdk.schemas.logicaltypes
-
Represents a single OneOf value.
- onError(Throwable) - Method in class org.apache.beam.sdk.fn.stream.BufferingStreamObserver
-
- onError(Throwable) - Method in class org.apache.beam.sdk.fn.stream.DirectStreamObserver
-
- onError(Throwable) - Method in class org.apache.beam.sdk.fn.stream.ForwardingClientResponseObserver
-
- onError(Throwable) - Method in class org.apache.beam.sdk.fn.stream.SynchronizedStreamObserver
-
- onMatch(RelOptRuleCall) - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamAggregateProjectMergeRule
-
- onMatch(RelOptRuleCall) - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamAggregationRule
-
- onMatch(RelOptRuleCall) - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamBasicAggregationRule
-
- onMatch(RelOptRuleCall) - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamCoGBKJoinRule
-
- onMatch(RelOptRuleCall) - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamIOPushDownRule
-
- onMatch(RelOptRuleCall) - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamJoinAssociateRule
-
- onMatch(RelOptRuleCall) - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamJoinPushThroughJoinRule
-
- onMatch(RelOptRuleCall) - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamSideInputJoinRule
-
- onMatch(RelOptRuleCall) - Method in class org.apache.beam.sdk.extensions.sql.impl.rule.BeamUnnestRule
-
- onNext(T) - Method in class org.apache.beam.sdk.fn.stream.BufferingStreamObserver
-
- onNext(T) - Method in class org.apache.beam.sdk.fn.stream.DirectStreamObserver
-
- onNext(ReqT) - Method in class org.apache.beam.sdk.fn.stream.ForwardingClientResponseObserver
-
- onNext(V) - Method in class org.apache.beam.sdk.fn.stream.SynchronizedStreamObserver
-
- onProgress(BeamFnApi.ProcessBundleProgressResponse) - Method in interface org.apache.beam.runners.fnexecution.control.BundleProgressHandler
-
Handles a progress report from the bundle while it is executing.
- onSeenNewOutput(Instant, StateT) - Method in interface org.apache.beam.sdk.transforms.Watch.Growth.TerminationCondition
-
- onStartup() - Method in interface org.apache.beam.sdk.harness.JvmInitializer
-
Implement onStartup to run some custom initialization immediately after the JVM is launched for
pipeline execution.
- onTimer(String, String, BoundedWindow, Instant, Instant, TimeDomain) - Method in class org.apache.beam.runners.flink.metrics.DoFnRunnerWithMetricsUpdate
-
- OnTimerContext() - Constructor for class org.apache.beam.sdk.transforms.DoFn.OnTimerContext
-
- open(MetricConfig) - Method in class org.apache.beam.runners.flink.metrics.FileReporter
-
- open(TaskContext, Instant) - Method in class org.apache.beam.runners.gearpump.translators.io.GearpumpSource
-
- open(GcsPath) - Method in class org.apache.beam.sdk.extensions.gcp.util.GcsUtil
-
Opens an object in GCS.
- open(WritableByteChannel) - Method in class org.apache.beam.sdk.io.AvroIO.Sink
-
- open(String) - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
-
- open() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
-
- open(WritableByteChannel) - Method in interface org.apache.beam.sdk.io.FileIO.Sink
-
Initializes writing to the given channel.
- open(ResourceIdT) - Method in class org.apache.beam.sdk.io.FileSystem
-
Returns a read channel for the given ResourceIdT
.
- open(ResourceId) - Static method in class org.apache.beam.sdk.io.FileSystems
-
- open(WritableByteChannel) - Method in class org.apache.beam.sdk.io.parquet.ParquetIO.Sink
-
- open(WritableByteChannel) - Method in class org.apache.beam.sdk.io.TextIO.Sink
-
- open(WritableByteChannel) - Method in class org.apache.beam.sdk.io.TFRecordIO.Sink
-
- open(WritableByteChannel) - Method in class org.apache.beam.sdk.io.thrift.ThriftIO.Sink
-
- open(WritableByteChannel) - Method in class org.apache.beam.sdk.io.xml.XmlIO.Sink
-
- openManifest(String) - Method in class org.apache.beam.runners.fnexecution.artifact.AbstractArtifactRetrievalService
-
- openManifest(String) - Method in class org.apache.beam.runners.fnexecution.artifact.AbstractArtifactStagingService
-
- openManifest(String) - Method in class org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService
-
- openManifest(String) - Method in class org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService
-
- openManifest(String) - Method in class org.apache.beam.runners.fnexecution.artifact.ClassLoaderArtifactRetrievalService
-
- openManifest(String) - Method in class org.apache.beam.runners.fnexecution.artifact.JavaFilesystemArtifactStagingService
-
- openSeekable() - Method in class org.apache.beam.sdk.io.FileIO.ReadableFile
-
- openUri(String, String) - Method in class org.apache.beam.runners.fnexecution.artifact.AbstractArtifactRetrievalService
-
- openUri(String) - Method in class org.apache.beam.runners.fnexecution.artifact.AbstractArtifactStagingService
-
- openUri(String, String) - Method in class org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactRetrievalService
-
- openUri(String) - Method in class org.apache.beam.runners.fnexecution.artifact.BeamFileSystemArtifactStagingService
-
- openUri(String, String) - Method in class org.apache.beam.runners.fnexecution.artifact.ClassLoaderArtifactRetrievalService
-
- openUri(String) - Method in class org.apache.beam.runners.fnexecution.artifact.JavaFilesystemArtifactStagingService
-
- optimizedWrites() - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.Write
-
If true, enables new codepaths that are expected to use less resources while writing to
BigQuery.
- Options() - Constructor for class org.apache.beam.runners.apex.ApexRunnerRegistrar.Options
-
- Options() - Constructor for class org.apache.beam.runners.dataflow.DataflowPipelineRegistrar.Options
-
- Options() - Constructor for class org.apache.beam.runners.direct.DirectRegistrar.Options
-
- Options() - Constructor for class org.apache.beam.runners.flink.FlinkRunnerRegistrar.Options
-
- options() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobPreparation
-
- Options() - Constructor for class org.apache.beam.runners.gearpump.GearpumpRunnerRegistrar.Options
-
- Options() - Constructor for class org.apache.beam.runners.jet.JetRunnerRegistrar.Options
-
- Options() - Constructor for class org.apache.beam.runners.spark.SparkRunnerRegistrar.Options
-
- options() - Static method in class org.apache.beam.sdk.extensions.sorter.BufferedExternalSorter
-
- options - Variable in class org.apache.beam.sdk.extensions.sorter.ExternalSorter
-
- Options() - Constructor for class org.apache.beam.sdk.extensions.sorter.ExternalSorter.Options
-
- Options() - Constructor for class org.apache.beam.sdk.options.ManualDockerEnvironmentOptions.Options
-
- Options() - Constructor for class org.apache.beam.sdk.options.RemoteEnvironmentOptions.Options
-
- Order - Class in org.apache.beam.sdk.extensions.sql.example.model
-
Describes an order.
- Order(int, int) - Constructor for class org.apache.beam.sdk.extensions.sql.example.model.Order
-
- Order() - Constructor for class org.apache.beam.sdk.extensions.sql.example.model.Order
-
- OrderByKey() - Constructor for class org.apache.beam.sdk.values.KV.OrderByKey
-
- OrderByValue() - Constructor for class org.apache.beam.sdk.values.KV.OrderByValue
-
- orFinally(Trigger.OnceTrigger) - Method in class org.apache.beam.sdk.transforms.windowing.Trigger
-
Specify an ending condition for this trigger.
- OrFinallyTrigger - Class in org.apache.beam.sdk.transforms.windowing
-
A
Trigger
that executes according to its main trigger until its "finally" trigger fires.
- org.apache.beam.runners.apex - package org.apache.beam.runners.apex
-
Implementation of the Beam runner for Apache Apex.
- org.apache.beam.runners.dataflow - package org.apache.beam.runners.dataflow
-
Provides a Beam runner that executes pipelines on the Google Cloud Dataflow service.
- org.apache.beam.runners.dataflow.options - package org.apache.beam.runners.dataflow.options
-
- org.apache.beam.runners.dataflow.util - package org.apache.beam.runners.dataflow.util
-
Provides miscellaneous internal utilities used by the Google Cloud Dataflow runner.
- org.apache.beam.runners.direct - package org.apache.beam.runners.direct
-
- org.apache.beam.runners.flink - package org.apache.beam.runners.flink
-
Internal implementation of the Beam runner for Apache Flink.
- org.apache.beam.runners.flink.metrics - package org.apache.beam.runners.flink.metrics
-
Internal metrics implementation of the Beam runner for Apache Flink.
- org.apache.beam.runners.fnexecution - package org.apache.beam.runners.fnexecution
-
Utilities used by runners to interact with the fn execution components of the Beam Portability
Framework.
- org.apache.beam.runners.fnexecution.artifact - package org.apache.beam.runners.fnexecution.artifact
-
Pipeline execution-time artifact-management services, including abstract implementations of the
Artifact Retrieval Service.
- org.apache.beam.runners.fnexecution.control - package org.apache.beam.runners.fnexecution.control
-
Utilities for a Beam runner to interact with the Fn API Control Service
via java abstractions.
- org.apache.beam.runners.fnexecution.data - package org.apache.beam.runners.fnexecution.data
-
Utilities for a Beam runner to interact with the Fn API Data Service
via java abstractions.
- org.apache.beam.runners.fnexecution.environment - package org.apache.beam.runners.fnexecution.environment
-
Classes used to instantiate and manage SDK harness environments.
- org.apache.beam.runners.fnexecution.environment.testing - package org.apache.beam.runners.fnexecution.environment.testing
-
Test utilities for the environment management package.
- org.apache.beam.runners.fnexecution.jobsubmission - package org.apache.beam.runners.fnexecution.jobsubmission
-
Job management services for use in beam runners.
- org.apache.beam.runners.fnexecution.logging - package org.apache.beam.runners.fnexecution.logging
-
Classes used to log informational messages over the Beam Fn Logging Service
.
- org.apache.beam.runners.fnexecution.provisioning - package org.apache.beam.runners.fnexecution.provisioning
-
Provision api services.
- org.apache.beam.runners.fnexecution.splittabledofn - package org.apache.beam.runners.fnexecution.splittabledofn
-
Utilities for a Beam runner to interact with a remotely running splittable DoFn.
- org.apache.beam.runners.fnexecution.state - package org.apache.beam.runners.fnexecution.state
-
State API services.
- org.apache.beam.runners.fnexecution.status - package org.apache.beam.runners.fnexecution.status
-
Worker Status API services.
- org.apache.beam.runners.fnexecution.translation - package org.apache.beam.runners.fnexecution.translation
-
Shared utilities for a Beam runner to translate portable pipelines.
- org.apache.beam.runners.fnexecution.wire - package org.apache.beam.runners.fnexecution.wire
-
Wire coders for communications between runner and SDK harness.
- org.apache.beam.runners.gearpump - package org.apache.beam.runners.gearpump
-
Internal implementation of the Beam runner for Apache Gearpump.
- org.apache.beam.runners.gearpump.translators - package org.apache.beam.runners.gearpump.translators
-
Gearpump specific translators.
- org.apache.beam.runners.gearpump.translators.functions - package org.apache.beam.runners.gearpump.translators.functions
-
Gearpump specific wrappers for Beam DoFn.
- org.apache.beam.runners.gearpump.translators.io - package org.apache.beam.runners.gearpump.translators.io
-
Gearpump specific wrappers for Beam I/O.
- org.apache.beam.runners.gearpump.translators.utils - package org.apache.beam.runners.gearpump.translators.utils
-
Utilities for translators.
- org.apache.beam.runners.jet - package org.apache.beam.runners.jet
-
Implementation of the Beam runner for Hazelcast Jet.
- org.apache.beam.runners.jet.metrics - package org.apache.beam.runners.jet.metrics
-
Helper classes for implementing metrics in the Hazelcast Jet based runner.
- org.apache.beam.runners.jet.processors - package org.apache.beam.runners.jet.processors
-
Individual DAG node processors used by the Beam runner for Hazelcast Jet.
- org.apache.beam.runners.local - package org.apache.beam.runners.local
-
Utilities useful when executing a pipeline on a single machine.
- org.apache.beam.runners.portability - package org.apache.beam.runners.portability
-
Support for executing a pipeline locally over the Beam fn API.
- org.apache.beam.runners.portability.testing - package org.apache.beam.runners.portability.testing
-
Testing utilities for the reference runner.
- org.apache.beam.runners.spark - package org.apache.beam.runners.spark
-
Internal implementation of the Beam runner for Apache Spark.
- org.apache.beam.runners.spark.aggregators - package org.apache.beam.runners.spark.aggregators
-
Provides internal utilities for implementing Beam aggregators using Spark accumulators.
- org.apache.beam.runners.spark.coders - package org.apache.beam.runners.spark.coders
-
Beam coders and coder-related utilities for running on Apache Spark.
- org.apache.beam.runners.spark.io - package org.apache.beam.runners.spark.io
-
Spark-specific transforms for I/O.
- org.apache.beam.runners.spark.metrics - package org.apache.beam.runners.spark.metrics
-
Provides internal utilities for implementing Beam metrics using Spark accumulators.
- org.apache.beam.runners.spark.metrics.sink - package org.apache.beam.runners.spark.metrics.sink
-
Spark sinks that supports beam metrics and aggregators.
- org.apache.beam.runners.spark.stateful - package org.apache.beam.runners.spark.stateful
-
Spark-specific stateful operators.
- org.apache.beam.runners.spark.structuredstreaming - package org.apache.beam.runners.spark.structuredstreaming
-
Internal implementation of the Beam runner for Apache Spark.
- org.apache.beam.runners.spark.structuredstreaming.aggregators - package org.apache.beam.runners.spark.structuredstreaming.aggregators
-
Provides internal utilities for implementing Beam aggregators using Spark accumulators.
- org.apache.beam.runners.spark.structuredstreaming.examples - package org.apache.beam.runners.spark.structuredstreaming.examples
-
- org.apache.beam.runners.spark.structuredstreaming.metrics - package org.apache.beam.runners.spark.structuredstreaming.metrics
-
Provides internal utilities for implementing Beam metrics using Spark accumulators.
- org.apache.beam.runners.spark.structuredstreaming.metrics.sink - package org.apache.beam.runners.spark.structuredstreaming.metrics.sink
-
Spark sinks that supports beam metrics and aggregators.
- org.apache.beam.runners.spark.structuredstreaming.translation - package org.apache.beam.runners.spark.structuredstreaming.translation
-
Internal translators for running Beam pipelines on Spark.
- org.apache.beam.runners.spark.structuredstreaming.translation.batch - package org.apache.beam.runners.spark.structuredstreaming.translation.batch
-
Internal utilities to translate Beam pipelines to Spark batching.
- org.apache.beam.runners.spark.structuredstreaming.translation.batch.functions - package org.apache.beam.runners.spark.structuredstreaming.translation.batch.functions
-
Internal implementation of the Beam runner for Apache Spark.
- org.apache.beam.runners.spark.structuredstreaming.translation.helpers - package org.apache.beam.runners.spark.structuredstreaming.translation.helpers
-
Internal helpers to translate Beam pipelines to Spark streaming.
- org.apache.beam.runners.spark.structuredstreaming.translation.streaming - package org.apache.beam.runners.spark.structuredstreaming.translation.streaming
-
Internal utilities to translate Beam pipelines to Spark streaming.
- org.apache.beam.runners.spark.structuredstreaming.translation.utils - package org.apache.beam.runners.spark.structuredstreaming.translation.utils
-
Internal utils to translate Beam pipelines to Spark streaming.
- org.apache.beam.runners.spark.util - package org.apache.beam.runners.spark.util
-
Internal utilities to translate Beam pipelines to Spark.
- org.apache.beam.sdk - package org.apache.beam.sdk
-
Provides a simple, powerful model for building both batch and streaming parallel data processing
Pipeline
s.
- org.apache.beam.sdk.annotations - package org.apache.beam.sdk.annotations
-
Defines annotations used across the SDK.
- org.apache.beam.sdk.coders - package org.apache.beam.sdk.coders
-
Defines
Coders
to specify how data is encoded to and
decoded from byte strings.
- org.apache.beam.sdk.expansion - package org.apache.beam.sdk.expansion
-
Contains classes needed to expose transforms to other SDKs.
- org.apache.beam.sdk.extensions.gcp.auth - package org.apache.beam.sdk.extensions.gcp.auth
-
Defines classes related to interacting with
Credentials
for pipeline
creation and execution containing Google Cloud Platform components.
- org.apache.beam.sdk.extensions.gcp.options - package org.apache.beam.sdk.extensions.gcp.options
-
Defines
PipelineOptions
for configuring pipeline execution
for Google Cloud Platform components.
- org.apache.beam.sdk.extensions.gcp.storage - package org.apache.beam.sdk.extensions.gcp.storage
-
Defines IO connectors for Google Cloud Storage.
- org.apache.beam.sdk.extensions.gcp.util - package org.apache.beam.sdk.extensions.gcp.util
-
Defines Google Cloud Platform component utilities that can be used by Beam runners.
- org.apache.beam.sdk.extensions.gcp.util.gcsfs - package org.apache.beam.sdk.extensions.gcp.util.gcsfs
-
Defines utilities used to interact with Google Cloud Storage.
- org.apache.beam.sdk.extensions.jackson - package org.apache.beam.sdk.extensions.jackson
-
Utilities for parsing and creating JSON serialized objects.
- org.apache.beam.sdk.extensions.joinlibrary - package org.apache.beam.sdk.extensions.joinlibrary
-
Utilities for performing SQL-style joins of keyed
PCollections
.
- org.apache.beam.sdk.extensions.protobuf - package org.apache.beam.sdk.extensions.protobuf
-
Defines a
Coder
for Protocol Buffers messages,
ProtoCoder
.
- org.apache.beam.sdk.extensions.sketching - package org.apache.beam.sdk.extensions.sketching
-
Utilities for computing statistical indicators using probabilistic sketches.
- org.apache.beam.sdk.extensions.sorter - package org.apache.beam.sdk.extensions.sorter
-
Utility for performing local sort of potentially large sets of values.
- org.apache.beam.sdk.extensions.sql - package org.apache.beam.sdk.extensions.sql
-
BeamSQL provides a new interface to run a SQL statement with Beam.
- org.apache.beam.sdk.extensions.sql.example - package org.apache.beam.sdk.extensions.sql.example
-
Example how to use Data Catalog table provider.
- org.apache.beam.sdk.extensions.sql.example.model - package org.apache.beam.sdk.extensions.sql.example.model
-
Java classes used to for modeling the examples.
- org.apache.beam.sdk.extensions.sql.impl - package org.apache.beam.sdk.extensions.sql.impl
-
Implementation classes of BeamSql.
- org.apache.beam.sdk.extensions.sql.impl.parser - package org.apache.beam.sdk.extensions.sql.impl.parser
-
Beam SQL parsing additions to Calcite SQL.
- org.apache.beam.sdk.extensions.sql.impl.planner - package org.apache.beam.sdk.extensions.sql.impl.planner
-
BeamQueryPlanner
is the main interface.
- org.apache.beam.sdk.extensions.sql.impl.rel - package org.apache.beam.sdk.extensions.sql.impl.rel
-
BeamSQL specified nodes, to replace RelNode
.
- org.apache.beam.sdk.extensions.sql.impl.rule - package org.apache.beam.sdk.extensions.sql.impl.rule
-
- org.apache.beam.sdk.extensions.sql.impl.schema - package org.apache.beam.sdk.extensions.sql.impl.schema
-
define table schema, to map with Beam IO components.
- org.apache.beam.sdk.extensions.sql.impl.transform - package org.apache.beam.sdk.extensions.sql.impl.transform
-
- org.apache.beam.sdk.extensions.sql.impl.transform.agg - package org.apache.beam.sdk.extensions.sql.impl.transform.agg
-
Implementation of standard SQL aggregation functions, e.g.
- org.apache.beam.sdk.extensions.sql.impl.udf - package org.apache.beam.sdk.extensions.sql.impl.udf
-
UDF classes.
- org.apache.beam.sdk.extensions.sql.impl.utils - package org.apache.beam.sdk.extensions.sql.impl.utils
-
Utility classes.
- org.apache.beam.sdk.extensions.sql.meta - package org.apache.beam.sdk.extensions.sql.meta
-
Metadata related classes.
- org.apache.beam.sdk.extensions.sql.meta.provider - package org.apache.beam.sdk.extensions.sql.meta.provider
-
Table providers.
- org.apache.beam.sdk.extensions.sql.meta.provider.avro - package org.apache.beam.sdk.extensions.sql.meta.provider.avro
-
Table schema for AvroIO.
- org.apache.beam.sdk.extensions.sql.meta.provider.bigquery - package org.apache.beam.sdk.extensions.sql.meta.provider.bigquery
-
Table schema for BigQuery.
- org.apache.beam.sdk.extensions.sql.meta.provider.datacatalog - package org.apache.beam.sdk.extensions.sql.meta.provider.datacatalog
-
Table schema for Google Cloud Data Catalog.
- org.apache.beam.sdk.extensions.sql.meta.provider.datastore - package org.apache.beam.sdk.extensions.sql.meta.provider.datastore
-
Table schema for DataStore.
- org.apache.beam.sdk.extensions.sql.meta.provider.hcatalog - package org.apache.beam.sdk.extensions.sql.meta.provider.hcatalog
-
Table schema for HCatalog.
- org.apache.beam.sdk.extensions.sql.meta.provider.kafka - package org.apache.beam.sdk.extensions.sql.meta.provider.kafka
-
Table schema for KafkaIO.
- org.apache.beam.sdk.extensions.sql.meta.provider.mongodb - package org.apache.beam.sdk.extensions.sql.meta.provider.mongodb
-
Table schema for MongoDb.
- org.apache.beam.sdk.extensions.sql.meta.provider.parquet - package org.apache.beam.sdk.extensions.sql.meta.provider.parquet
-
Table schema for ParquetIO.
- org.apache.beam.sdk.extensions.sql.meta.provider.pubsub - package org.apache.beam.sdk.extensions.sql.meta.provider.pubsub
-
- org.apache.beam.sdk.extensions.sql.meta.provider.seqgen - package org.apache.beam.sdk.extensions.sql.meta.provider.seqgen
-
Table schema for streaming sequence generator.
- org.apache.beam.sdk.extensions.sql.meta.provider.test - package org.apache.beam.sdk.extensions.sql.meta.provider.test
-
Table schema for in-memory test data.
- org.apache.beam.sdk.extensions.sql.meta.provider.text - package org.apache.beam.sdk.extensions.sql.meta.provider.text
-
Table schema for text files.
- org.apache.beam.sdk.extensions.sql.meta.store - package org.apache.beam.sdk.extensions.sql.meta.store
-
Meta stores.
- org.apache.beam.sdk.extensions.sql.zetasql - package org.apache.beam.sdk.extensions.sql.zetasql
-
ZetaSQL Dialect package.
- org.apache.beam.sdk.extensions.sql.zetasql.translation - package org.apache.beam.sdk.extensions.sql.zetasql.translation
-
Conversion logic between ZetaSQL resolved query nodes and Calcite rel nodes.
- org.apache.beam.sdk.extensions.zetasketch - package org.apache.beam.sdk.extensions.zetasketch
-
PTransform
s to compute statistical sketches on data streams based on the
ZetaSketch implementation.
- org.apache.beam.sdk.fn - package org.apache.beam.sdk.fn
-
The top level package for the Fn Execution Java libraries.
- org.apache.beam.sdk.fn.channel - package org.apache.beam.sdk.fn.channel
-
gRPC channel management.
- org.apache.beam.sdk.fn.data - package org.apache.beam.sdk.fn.data
-
Classes to interact with the portability framework data plane.
- org.apache.beam.sdk.fn.splittabledofn - package org.apache.beam.sdk.fn.splittabledofn
-
- org.apache.beam.sdk.fn.stream - package org.apache.beam.sdk.fn.stream
-
gRPC stream management.
- org.apache.beam.sdk.fn.test - package org.apache.beam.sdk.fn.test
-
Utilities for testing use of this package.
- org.apache.beam.sdk.fn.windowing - package org.apache.beam.sdk.fn.windowing
-
Common utilities related to windowing during execution of a pipeline.
- org.apache.beam.sdk.function - package org.apache.beam.sdk.function
-
Java 8 functional interface extensions.
- org.apache.beam.sdk.harness - package org.apache.beam.sdk.harness
-
Utilities for configuring worker environment.
- org.apache.beam.sdk.io - package org.apache.beam.sdk.io
-
Defines transforms for reading and writing common storage formats, including
AvroIO
, and
TextIO
.
- org.apache.beam.sdk.io.amqp - package org.apache.beam.sdk.io.amqp
-
Transforms for reading and writing using AMQP 1.0 protocol.
- org.apache.beam.sdk.io.aws.dynamodb - package org.apache.beam.sdk.io.aws.dynamodb
-
Defines IO connectors for Amazon Web Services DynamoDB.
- org.apache.beam.sdk.io.aws.options - package org.apache.beam.sdk.io.aws.options
-
Defines
PipelineOptions
for configuring pipeline execution
for Amazon Web Services components.
- org.apache.beam.sdk.io.aws.s3 - package org.apache.beam.sdk.io.aws.s3
-
Defines IO connectors for Amazon Web Services S3.
- org.apache.beam.sdk.io.aws.sns - package org.apache.beam.sdk.io.aws.sns
-
Defines IO connectors for Amazon Web Services SNS.
- org.apache.beam.sdk.io.aws.sqs - package org.apache.beam.sdk.io.aws.sqs
-
Defines IO connectors for Amazon Web Services SQS.
- org.apache.beam.sdk.io.aws2.dynamodb - package org.apache.beam.sdk.io.aws2.dynamodb
-
Defines IO connectors for Amazon Web Services DynamoDB.
- org.apache.beam.sdk.io.aws2.options - package org.apache.beam.sdk.io.aws2.options
-
Defines
PipelineOptions
for configuring pipeline execution
for Amazon Web Services components.
- org.apache.beam.sdk.io.aws2.sns - package org.apache.beam.sdk.io.aws2.sns
-
Defines IO connectors for Amazon Web Services SNS.
- org.apache.beam.sdk.io.aws2.sqs - package org.apache.beam.sdk.io.aws2.sqs
-
Defines IO connectors for Amazon Web Services SQS.
- org.apache.beam.sdk.io.cassandra - package org.apache.beam.sdk.io.cassandra
-
Transforms for reading and writing from/to Apache Cassandra.
- org.apache.beam.sdk.io.clickhouse - package org.apache.beam.sdk.io.clickhouse
-
Transform for writing to ClickHouse.
- org.apache.beam.sdk.io.elasticsearch - package org.apache.beam.sdk.io.elasticsearch
-
Transforms for reading and writing from Elasticsearch.
- org.apache.beam.sdk.io.fs - package org.apache.beam.sdk.io.fs
-
Apache Beam FileSystem interfaces and their default implementations.
- org.apache.beam.sdk.io.gcp.bigquery - package org.apache.beam.sdk.io.gcp.bigquery
-
Defines transforms for reading and writing from Google BigQuery.
- org.apache.beam.sdk.io.gcp.bigtable - package org.apache.beam.sdk.io.gcp.bigtable
-
Defines transforms for reading and writing from Google Cloud Bigtable.
- org.apache.beam.sdk.io.gcp.common - package org.apache.beam.sdk.io.gcp.common
-
Defines common Google Cloud Platform IO support classes.
- org.apache.beam.sdk.io.gcp.datastore - package org.apache.beam.sdk.io.gcp.datastore
-
Provides an API for reading from and writing to
Google Cloud Datastore over different
versions of the Cloud Datastore Client libraries.
- org.apache.beam.sdk.io.gcp.pubsub - package org.apache.beam.sdk.io.gcp.pubsub
-
- org.apache.beam.sdk.io.gcp.spanner - package org.apache.beam.sdk.io.gcp.spanner
-
- org.apache.beam.sdk.io.gcp.testing - package org.apache.beam.sdk.io.gcp.testing
-
Defines utilities for unit testing Google Cloud Platform components of Apache Beam pipelines.
- org.apache.beam.sdk.io.hadoop - package org.apache.beam.sdk.io.hadoop
-
Classes shared by Hadoop based IOs.
- org.apache.beam.sdk.io.hadoop.format - package org.apache.beam.sdk.io.hadoop.format
-
Defines transforms for writing to Data sinks that implement
HadoopFormatIO
.
- org.apache.beam.sdk.io.hbase - package org.apache.beam.sdk.io.hbase
-
Transforms for reading and writing from/to Apache HBase.
- org.apache.beam.sdk.io.hcatalog - package org.apache.beam.sdk.io.hcatalog
-
Transforms for reading and writing using HCatalog.
- org.apache.beam.sdk.io.hcatalog.test - package org.apache.beam.sdk.io.hcatalog.test
-
Test utilities for HCatalog IO.
- org.apache.beam.sdk.io.hdfs - package org.apache.beam.sdk.io.hdfs
-
FileSystem
implementation for any Hadoop
FileSystem
.
- org.apache.beam.sdk.io.jdbc - package org.apache.beam.sdk.io.jdbc
-
Transforms for reading and writing from JDBC.
- org.apache.beam.sdk.io.jms - package org.apache.beam.sdk.io.jms
-
Transforms for reading and writing from JMS (Java Messaging Service).
- org.apache.beam.sdk.io.kafka - package org.apache.beam.sdk.io.kafka
-
Transforms for reading and writing from Apache Kafka.
- org.apache.beam.sdk.io.kafka.serialization - package org.apache.beam.sdk.io.kafka.serialization
-
Kafka serializers and deserializers.
- org.apache.beam.sdk.io.kinesis - package org.apache.beam.sdk.io.kinesis
-
Transforms for reading and writing from Amazon Kinesis.
- org.apache.beam.sdk.io.mongodb - package org.apache.beam.sdk.io.mongodb
-
Transforms for reading and writing from MongoDB.
- org.apache.beam.sdk.io.mqtt - package org.apache.beam.sdk.io.mqtt
-
Transforms for reading and writing from MQTT.
- org.apache.beam.sdk.io.parquet - package org.apache.beam.sdk.io.parquet
-
Transforms for reading and writing from Parquet.
- org.apache.beam.sdk.io.range - package org.apache.beam.sdk.io.range
-
Provides thread-safe helpers for implementing dynamic work rebalancing in position-based bounded
sources.
- org.apache.beam.sdk.io.redis - package org.apache.beam.sdk.io.redis
-
Transforms for reading and writing from Redis.
- org.apache.beam.sdk.io.solr - package org.apache.beam.sdk.io.solr
-
Transforms for reading and writing from/to Solr.
- org.apache.beam.sdk.io.thrift - package org.apache.beam.sdk.io.thrift
-
Transforms for reading and writing to Thrift files.
- org.apache.beam.sdk.io.tika - package org.apache.beam.sdk.io.tika
-
Transform for reading and parsing files with Apache Tika.
- org.apache.beam.sdk.io.xml - package org.apache.beam.sdk.io.xml
-
Transforms for reading and writing Xml files.
- org.apache.beam.sdk.metrics - package org.apache.beam.sdk.metrics
-
Metrics allow exporting information about the execution of a pipeline.
- org.apache.beam.sdk.options - package org.apache.beam.sdk.options
-
- org.apache.beam.sdk.schemas - package org.apache.beam.sdk.schemas
-
Defines
Schema
and other classes for representing schema'd
data in a
Pipeline
.
- org.apache.beam.sdk.schemas.annotations - package org.apache.beam.sdk.schemas.annotations
-
Defines
Schema
and other classes for representing schema'd
data in a
Pipeline
.
- org.apache.beam.sdk.schemas.logicaltypes - package org.apache.beam.sdk.schemas.logicaltypes
-
A set of common LogicalTypes for use with schemas.
- org.apache.beam.sdk.schemas.parser - package org.apache.beam.sdk.schemas.parser
-
Defines utilities for deailing with schemas.
- org.apache.beam.sdk.schemas.parser.generated - package org.apache.beam.sdk.schemas.parser.generated
-
Defines utilities for deailing with schemas.
- org.apache.beam.sdk.schemas.transforms - package org.apache.beam.sdk.schemas.transforms
-
Defines transforms that work on PCollections with schemas..
- org.apache.beam.sdk.schemas.utils - package org.apache.beam.sdk.schemas.utils
-
Defines utilities for deailing with schemas.
- org.apache.beam.sdk.state - package org.apache.beam.sdk.state
-
Classes and interfaces for interacting with state.
- org.apache.beam.sdk.testing - package org.apache.beam.sdk.testing
-
Defines utilities for unit testing Apache Beam pipelines.
- org.apache.beam.sdk.transforms - package org.apache.beam.sdk.transforms
-
Defines
PTransform
s for transforming data in a pipeline.
- org.apache.beam.sdk.transforms.display - package org.apache.beam.sdk.transforms.display
-
- org.apache.beam.sdk.transforms.join - package org.apache.beam.sdk.transforms.join
-
Defines the
CoGroupByKey
transform for joining
multiple PCollections.
- org.apache.beam.sdk.transforms.splittabledofn - package org.apache.beam.sdk.transforms.splittabledofn
-
- org.apache.beam.sdk.transforms.windowing - package org.apache.beam.sdk.transforms.windowing
-
Defines the
Window
transform for dividing the
elements in a PCollection into windows, and the
Trigger
for controlling when those elements are output.
- org.apache.beam.sdk.values - package org.apache.beam.sdk.values
-
- OTHER - Static variable in class org.apache.beam.sdk.extensions.sql.zetasql.SqlOperators
-
- out() - Static method in class org.apache.beam.runners.spark.io.ConsoleIO.Write
-
- out(int) - Static method in class org.apache.beam.runners.spark.io.ConsoleIO.Write
-
- outbound(DataStreams.OutputChunkConsumer<ByteString>) - Static method in class org.apache.beam.sdk.fn.stream.DataStreams
-
Converts a single element delimited OutputStream
into multiple ByteStrings
.
- outbound(DataStreams.OutputChunkConsumer<ByteString>, int) - Static method in class org.apache.beam.sdk.fn.stream.DataStreams
-
Converts a single element delimited OutputStream
into multiple ByteStrings
using the specified maximum chunk size.
- OutboundObserverFactory - Class in org.apache.beam.sdk.fn.stream
-
Creates factories which determine an underlying StreamObserver
implementation to use in
to interact with fn execution APIs.
- OutboundObserverFactory() - Constructor for class org.apache.beam.sdk.fn.stream.OutboundObserverFactory
-
- OutboundObserverFactory.BasicFactory<ReqT,RespT> - Interface in org.apache.beam.sdk.fn.stream
-
Creates an outbound observer for the given inbound observer.
- outboundObserverFor(StreamObserver<ReqT>) - Method in interface org.apache.beam.sdk.fn.stream.OutboundObserverFactory.BasicFactory
-
- outboundObserverFor(OutboundObserverFactory.BasicFactory<ReqT, RespT>, StreamObserver<ReqT>) - Method in class org.apache.beam.sdk.fn.stream.OutboundObserverFactory
-
Creates an outbound observer for the given inbound observer by potentially inserting hooks into
the inbound and outbound observers.
- OUTER - Static variable in class org.apache.beam.sdk.coders.Coder.Context
-
Deprecated.
The outer context: the value being encoded or decoded takes up the remainder of the
record/stream contents.
- OutgoingMessage() - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.OutgoingMessage
-
- OUTPUT - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- output(T) - Method in interface org.apache.beam.sdk.io.mongodb.MongoDbGridFSIO.ParserCallback
-
Output the object.
- output(T, Instant) - Method in interface org.apache.beam.sdk.io.mongodb.MongoDbGridFSIO.ParserCallback
-
Output the object using the specified timestamp.
- output(OutputT, Instant, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFn.FinishBundleContext
-
Adds the given element to the main output PCollection
at the given timestamp in the
given window.
- output(TupleTag<T>, T, Instant, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFn.FinishBundleContext
-
Adds the given element to the output PCollection
with the given tag at the given
timestamp in the given window.
- output(T) - Method in interface org.apache.beam.sdk.transforms.DoFn.OutputReceiver
-
- output(OutputT) - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
-
Adds the given element to the main output PCollection
.
- output(TupleTag<T>, T) - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
-
Adds the given element to the output PCollection
with the given tag.
- output() - Method in class org.apache.beam.sdk.transforms.WithFailures.Result
-
- OUTPUT_DIR - Static variable in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO
-
MRJobConfig.MAPREDUCE_JOB_DIR
.
- OUTPUT_FORMAT_CLASS_ATTR - Static variable in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO
-
MRJobConfig.OUTPUT_FORMAT_CLASS_ATTR
.
- OUTPUT_INFO - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- OUTPUT_KEY_CLASS - Static variable in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO
-
MRJobConfig.OUTPUT_KEY_CLASS
.
- OUTPUT_NAME - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- OUTPUT_VALUE_CLASS - Static variable in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO
-
MRJobConfig.OUTPUT_VALUE_CLASS
.
- outputCollectionId() - Method in class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors.TimerSpec
-
- outputColumnMap - Variable in class org.apache.beam.sdk.extensions.sql.zetasql.QueryTrait
-
- outputOf(ProcessFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
Returns a type descriptor for the output of the given
ProcessFunction
, subject to Java
type erasure: may contain unresolved type variables if the type was erased.
- outputOf(SerializableFunction<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
- outputOf(Contextful.Fn<InputT, OutputT>) - Static method in class org.apache.beam.sdk.values.TypeDescriptors
-
- OutputReceiverFactory - Interface in org.apache.beam.runners.fnexecution.control
-
A factory that can create output receivers during an executable stage.
- OutputReference - Class in org.apache.beam.runners.dataflow.util
-
A representation used by
Step
s to reference the
output of other
Step
s.
- OutputReference(String, String) - Constructor for class org.apache.beam.runners.dataflow.util.OutputReference
-
- outputRuntimeOptions() - Method in interface org.apache.beam.sdk.options.PipelineOptions
-
- outputSchema() - Method in class org.apache.beam.sdk.schemas.transforms.Cast
-
- outputSchemaCoder - Variable in class org.apache.beam.sdk.schemas.utils.ConvertHelpers.ConvertedSchemaInformation
-
- outputTransformId() - Method in class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors.TimerSpec
-
- outputWithTimestamp(T, Instant) - Method in interface org.apache.beam.sdk.transforms.DoFn.OutputReceiver
-
- outputWithTimestamp(OutputT, Instant) - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
-
Adds the given element to the main output PCollection
, with the given timestamp.
- outputWithTimestamp(TupleTag<T>, T, Instant) - Method in class org.apache.beam.sdk.transforms.DoFn.WindowedContext
-
Adds the given element to the specified output PCollection
, with the given timestamp.
- overlaps(ByteKeyRange) - Method in class org.apache.beam.sdk.io.range.ByteKeyRange
-
Returns
true
if the specified
ByteKeyRange
overlaps this range.
- pane() - Method in class org.apache.beam.sdk.transforms.DoFn.ProcessContext
-
Returns information about the pane within this window into which the input element has been
assigned.
- PaneInfo - Class in org.apache.beam.sdk.transforms.windowing
-
Provides information about the pane an element belongs to.
- PaneInfo.PaneInfoCoder - Class in org.apache.beam.sdk.transforms.windowing
-
A Coder for encoding PaneInfo instances.
- PaneInfo.Timing - Enum in org.apache.beam.sdk.transforms.windowing
-
Enumerates the possibilities for the timing of this pane firing related to the input and output
watermarks for its computation.
- PARALLEL_INPUT - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- ParameterListBuilder() - Constructor for class org.apache.beam.sdk.extensions.sql.impl.UdfImplReflectiveFunctionBase.ParameterListBuilder
-
- parameters - Variable in class org.apache.beam.sdk.extensions.sql.impl.UdfImplReflectiveFunctionBase
-
Types of parameter for the function call.
- Params() - Constructor for class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
-
Construct a default Params object.
- ParamsCoder() - Constructor for class org.apache.beam.sdk.io.DefaultFilenamePolicy.ParamsCoder
-
- ParDo - Class in org.apache.beam.sdk.transforms
-
ParDo
is the core element-wise transform in Apache Beam, invoking a user-specified
function on each of the elements of the input
PCollection
to produce zero or more output
elements, all of which are collected into the output
PCollection
.
- ParDo() - Constructor for class org.apache.beam.sdk.transforms.ParDo
-
- ParDo.MultiOutput<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
A
PTransform
that, when applied to a
PCollection<InputT>
, invokes a
user-specified
DoFn<InputT, OutputT>
on all its elements, which can emit elements to
any of the
PTransform
's output
PCollection
s, which are bundled into a result
PCollectionTuple
.
- ParDo.SingleOutput<InputT,OutputT> - Class in org.apache.beam.sdk.transforms
-
A
PTransform
that, when applied to a
PCollection<InputT>
, invokes a
user-specified
DoFn<InputT, OutputT>
on all its elements, with all its outputs
collected into an output
PCollection<OutputT>
.
- ParDoMultiOutputTranslator<InputT,OutputT> - Class in org.apache.beam.runners.gearpump.translators
-
ParDo.MultiOutput
is translated to Gearpump flatMap function with
DoFn
wrapped in
DoFnFunction
.
- ParDoMultiOutputTranslator() - Constructor for class org.apache.beam.runners.gearpump.translators.ParDoMultiOutputTranslator
-
- ParDoMultiOverrideFactory<InputT,OutputT> - Class in org.apache.beam.runners.direct
-
A
PTransformOverrideFactory
that provides overrides for applications of a
ParDo
in the direct runner.
- ParDoMultiOverrideFactory() - Constructor for class org.apache.beam.runners.direct.ParDoMultiOverrideFactory
-
- ParDoP<InputT,OutputT> - Class in org.apache.beam.runners.jet.processors
-
Jet Processor
implementation for Beam's ParDo primitive (when no
user-state is being used).
- ParDoP.Supplier<InputT,OutputT> - Class in org.apache.beam.runners.jet.processors
-
Jet
Processor
supplier that will provide instances of
ParDoP
.
- parent() - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
-
Type of parent node in a tree.
- ParquetIO - Class in org.apache.beam.sdk.io.parquet
-
IO to read and write Parquet files.
- ParquetIO.Read - Class in org.apache.beam.sdk.io.parquet
-
- ParquetIO.ReadFiles - Class in org.apache.beam.sdk.io.parquet
-
- ParquetIO.Sink - Class in org.apache.beam.sdk.io.parquet
-
- ParquetTable - Class in org.apache.beam.sdk.extensions.sql.meta.provider.parquet
-
- ParquetTable(Schema, String) - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.parquet.ParquetTable
-
- ParquetTableProvider - Class in org.apache.beam.sdk.extensions.sql.meta.provider.parquet
-
- ParquetTableProvider() - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.parquet.ParquetTableProvider
-
- parse(String) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner
-
Parse input SQL query, and return a SqlNode
as grammar tree.
- parse(String) - Method in interface org.apache.beam.sdk.extensions.sql.impl.QueryPlanner
-
Parse input SQL query, and return a SqlNode
as grammar tree.
- parse(String) - Method in class org.apache.beam.sdk.extensions.sql.zetasql.ZetaSQLPlannerImpl
-
- parse(Reader) - Method in class org.apache.beam.sdk.extensions.sql.zetasql.ZetaSQLPlannerImpl
-
- parse(String) - Method in class org.apache.beam.sdk.extensions.sql.zetasql.ZetaSQLQueryPlanner
-
- Parse() - Constructor for class org.apache.beam.sdk.io.AvroIO.Parse
-
- parse(String) - Static method in class org.apache.beam.sdk.io.clickhouse.TableSchema.ColumnType
-
- parse(String) - Static method in enum org.apache.beam.sdk.io.clickhouse.TableSchema.DefaultType
-
- parse(GridFSDBFile, MongoDbGridFSIO.ParserCallback<T>) - Method in interface org.apache.beam.sdk.io.mongodb.MongoDbGridFSIO.Parser
-
- parse() - Static method in class org.apache.beam.sdk.io.tika.TikaIO
-
Parses files matching a given filepattern.
- Parse() - Constructor for class org.apache.beam.sdk.io.tika.TikaIO.Parse
-
- parse(String) - Static method in class org.apache.beam.sdk.schemas.parser.FieldAccessDescriptorParser
-
- parse(T) - Method in class org.apache.beam.sdk.testing.JsonMatcher
-
- ParseAll() - Constructor for class org.apache.beam.sdk.io.AvroIO.ParseAll
-
Deprecated.
- parseAllGenericRecords(SerializableFunction<GenericRecord, T>) - Static method in class org.apache.beam.sdk.io.AvroIO
-
- parseArgs(String[]) - Static method in class org.apache.beam.runners.flink.FlinkJobServerDriver
-
- parseDate(String) - Static method in class org.apache.beam.sdk.extensions.sql.zetasql.DateTimeUtils
-
- parseDateToValue(String) - Static method in class org.apache.beam.sdk.extensions.sql.zetasql.DateTimeUtils
-
- parseDefaultExpression(TableSchema.ColumnType, String) - Static method in class org.apache.beam.sdk.io.clickhouse.TableSchema.ColumnType
-
Get default value of a column based on expression.
- ParseException - Exception in org.apache.beam.sdk.extensions.sql.impl
-
Exception thrown when Beam SQL is unable to parse the statement.
- ParseException(Throwable) - Constructor for exception org.apache.beam.sdk.extensions.sql.impl.ParseException
-
- ParseException(String, Throwable) - Constructor for exception org.apache.beam.sdk.extensions.sql.impl.ParseException
-
- ParseFiles() - Constructor for class org.apache.beam.sdk.io.AvroIO.ParseFiles
-
- parseFiles() - Static method in class org.apache.beam.sdk.io.tika.TikaIO
-
- ParseFiles() - Constructor for class org.apache.beam.sdk.io.tika.TikaIO.ParseFiles
-
- parseFilesGenericRecords(SerializableFunction<GenericRecord, T>) - Static method in class org.apache.beam.sdk.io.AvroIO
-
- parseGenericRecords(SerializableFunction<GenericRecord, T>) - Static method in class org.apache.beam.sdk.io.AvroIO
-
Reads Avro file(s) containing records of an unspecified schema and converting each record to a
custom type.
- ParseJsons<OutputT> - Class in org.apache.beam.sdk.extensions.jackson
-
- ParseJsons.ParseJsonsWithFailures<FailureT> - Class in org.apache.beam.sdk.extensions.jackson
-
A
PTransform
that adds exception handling to
ParseJsons
.
- parseQuery(String) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlEnv
-
- parseQuery(String, QueryPlanner.QueryParameters) - Method in class org.apache.beam.sdk.extensions.sql.impl.BeamSqlEnv
-
- ParseResult - Class in org.apache.beam.sdk.io.tika
-
The result of parsing a single file with Tika: contains the file's location, metadata, extracted
text, and optionally an error.
- parseTableSpec(String) - Static method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryHelpers
-
Parse a table specification in the form "[project_id]:[dataset_id].[table_id]"
or
"[dataset_id].[table_id]"
.
- parseTime(String) - Static method in class org.apache.beam.sdk.extensions.sql.zetasql.DateTimeUtils
-
- parseTimestampWithLocalTimeZone(String) - Static method in class org.apache.beam.sdk.extensions.sql.zetasql.DateTimeUtils
-
- parseTimestampWithoutTimeZone(String) - Static method in class org.apache.beam.sdk.extensions.sql.zetasql.DateTimeUtils
-
- parseTimestampWithTimeZone(String) - Static method in class org.apache.beam.sdk.extensions.sql.zetasql.DateTimeUtils
-
- parseTimestampWithTZToValue(String) - Static method in class org.apache.beam.sdk.extensions.sql.zetasql.DateTimeUtils
-
- parseTimestampWithUTCTimeZone(String) - Static method in class org.apache.beam.sdk.extensions.sql.zetasql.DateTimeUtils
-
- parseTimeToValue(String) - Static method in class org.apache.beam.sdk.extensions.sql.zetasql.DateTimeUtils
-
- Partition<T> - Class in org.apache.beam.sdk.transforms
-
Partition
takes a PCollection<T>
and a PartitionFn
, uses the PartitionFn
to split the elements of the input PCollection
into N
partitions,
and returns a PCollectionList<T>
that bundles N
PCollection<T>
s
containing the split elements.
- Partition.PartitionFn<T> - Interface in org.apache.beam.sdk.transforms
-
A function object that chooses an output partition for an element.
- PartitionContext() - Constructor for class org.apache.beam.sdk.io.kafka.TimestampPolicy.PartitionContext
-
- partitioner() - Method in class org.apache.beam.runners.spark.io.SourceRDD.Unbounded
-
- PARTITIONER_CLASS_ATTR - Static variable in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO
-
MRJobConfig.PARTITIONER_CLASS_ATTR
.
- partitionFor(T, int) - Method in interface org.apache.beam.sdk.transforms.Partition.PartitionFn
-
Chooses the partition into which to put the given element.
- PartitioningWindowFn<T,W extends BoundedWindow> - Class in org.apache.beam.sdk.transforms.windowing
-
A
WindowFn
that places each value into exactly one window based on its timestamp and
never merges windows.
- PartitioningWindowFn() - Constructor for class org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn
-
- PartitionMark(String, int, long, long) - Constructor for class org.apache.beam.sdk.io.kafka.KafkaCheckpointMark.PartitionMark
-
- PAssert - Class in org.apache.beam.sdk.testing
-
An assertion on the contents of a
PCollection
incorporated into the pipeline.
- PAssert.DefaultConcludeTransform - Class in org.apache.beam.sdk.testing
-
Default transform to check that a PAssert was successful.
- PAssert.GroupThenAssert<T> - Class in org.apache.beam.sdk.testing
-
A transform that applies an assertion-checking function over iterables of ActualT
to
the entirety of the contents of its input.
- PAssert.GroupThenAssertForSingleton<T> - Class in org.apache.beam.sdk.testing
-
A transform that applies an assertion-checking function to the sole element of a
PCollection
.
- PAssert.IterableAssert<T> - Interface in org.apache.beam.sdk.testing
-
Builder interface for assertions applicable to iterables and PCollection contents.
- PAssert.OneSideInputAssert<ActualT> - Class in org.apache.beam.sdk.testing
-
An assertion checker that takes a single
PCollectionView<ActualT>
and an assertion over
ActualT
, and checks it within a Beam pipeline.
- PAssert.PAssertionSite - Class in org.apache.beam.sdk.testing
-
Track the place where an assertion is defined.
- PAssert.PCollectionContentsAssert<T> - Class in org.apache.beam.sdk.testing
-
- PAssert.PCollectionContentsAssert.MatcherCheckerFn<T> - Class in org.apache.beam.sdk.testing
-
Check that the passed-in matchers match the existing data.
- PAssert.SingletonAssert<T> - Interface in org.apache.beam.sdk.testing
-
Builder interface for assertions applicable to a single value.
- PassThroughLogicalType<T> - Class in org.apache.beam.sdk.schemas.logicaltypes
-
A base class for LogicalTypes that use the same Java type as the underlying base type.
- PassThroughLogicalType(String, Schema.FieldType, Object, Schema.FieldType) - Constructor for class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
-
- pastEndOfWindow() - Static method in class org.apache.beam.sdk.transforms.windowing.AfterWatermark
-
Creates a trigger that fires when the watermark passes the end of the window.
- pastFirstElementInPane() - Static method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
-
Creates a trigger that fires when the current processing time passes the processing time at
which this trigger saw the first element in a pane.
- patchTableDescription(TableReference, String) - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryServices.DatasetService
-
Patch BigQuery
Table
description.
- patchTableDescription(TableReference, String) - Method in class org.apache.beam.sdk.io.gcp.testing.FakeDatasetService
-
- path() - Method in class org.apache.beam.sdk.schemas.transforms.Cast.CompatibilityError
-
- path() - Method in class org.apache.beam.sdk.schemas.utils.SchemaZipFold.Context
-
Field path from a root of a schema.
- PathValidator - Interface in org.apache.beam.sdk.extensions.gcp.storage
-
For internal use only; no backwards compatibility guarantees.
- PathValidatorFactory() - Constructor for class org.apache.beam.sdk.extensions.gcp.options.GcsOptions.PathValidatorFactory
-
- PBegin - Class in org.apache.beam.sdk.values
-
- PBegin(Pipeline) - Constructor for class org.apache.beam.sdk.values.PBegin
-
- PCollection<T> - Class in org.apache.beam.sdk.values
-
- PCollection.IsBounded - Enum in org.apache.beam.sdk.values
-
The enumeration of cases for whether a
PCollection
is bounded.
- PCollectionContentsAssert(PCollection<T>, PAssert.PAssertionSite) - Constructor for class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
-
- PCollectionContentsAssert(PCollection<T>, PAssert.AssertionWindows, SimpleFunction<Iterable<ValueInSingleWindow<T>>, Iterable<T>>, PAssert.PAssertionSite) - Constructor for class org.apache.beam.sdk.testing.PAssert.PCollectionContentsAssert
-
- PCollectionList<T> - Class in org.apache.beam.sdk.values
-
- pCollections() - Static method in class org.apache.beam.sdk.transforms.Flatten
-
- PCollectionTuple - Class in org.apache.beam.sdk.values
-
- PCollectionView<T> - Interface in org.apache.beam.sdk.values
-
- PCollectionViews - Class in org.apache.beam.sdk.values
-
For internal use only; no backwards compatibility guarantees.
- PCollectionViews() - Constructor for class org.apache.beam.sdk.values.PCollectionViews
-
- PCollectionViews.IterableViewFn<T> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt a multimap materialization to a Iterable<T>
.
- PCollectionViews.ListViewFn<T> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt a multimap materialization to a List<T>
.
- PCollectionViews.MapViewFn<K,V> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt a multimap materialization to a Map<K, V>
.
- PCollectionViews.MultimapViewFn<K,V> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt a multimap materialization to a Map<K,
Iterable<V>>
.
- PCollectionViews.SimplePCollectionView<ElemT,PrimitiveViewT,ViewT,W extends BoundedWindow> - Class in org.apache.beam.sdk.values
-
A class for
PCollectionView
implementations, with additional type parameters that are
not visible at pipeline assembly time when the view is used as a side input.
- PCollectionViews.SingletonViewFn<T> - Class in org.apache.beam.sdk.values
-
Implementation which is able to adapt a multimap materialization to a T
.
- PCollectionViews.TypeDescriptorSupplier<T> - Interface in org.apache.beam.sdk.values
-
- PDone - Class in org.apache.beam.sdk.values
-
- peekOutputElements() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- peekOutputElements(TupleTag<T>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- peekOutputElementsInWindow(BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- peekOutputElementsInWindow(TupleTag<OutputT>, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- peekOutputElementsWithTimestamp() - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- perElement() - Static method in class org.apache.beam.sdk.transforms.Count
-
- perKey() - Static method in class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct
-
Like
ApproximateDistinct.globally()
but per key, i.e computes the approximate number of distinct values per
key in a
PCollection<KV<K, V>>
and returns
PCollection<KV<K, Long>>
.
- perKey() - Static method in class org.apache.beam.sdk.extensions.sketching.SketchFrequencies
-
Like
SketchFrequencies.globally()
but per key, i.e a Count-min sketch per key in
PCollection<KV<K, V>>
and returns a
PCollection<KV<K, {@link CountMinSketch}>>
.
- perKey() - Static method in class org.apache.beam.sdk.extensions.sketching.TDigestQuantiles
-
- perKey() - Static method in class org.apache.beam.sdk.extensions.zetasketch.HllCount.Extract
-
Returns a PTransform
that takes an input PCollection<KV<K, byte[]>>
of (key,
HLL++ sketch) pairs and returns a PCollection<KV<K, Long>>
of (key, estimated count
of distinct elements extracted from each sketch).
- perKey() - Method in class org.apache.beam.sdk.extensions.zetasketch.HllCount.Init.Builder
-
Returns a Combine.PerKey
PTransform
that takes an input PCollection<KV<K, InputT>>
and returns a PCollection<KV<K, byte[]>>
which consists
of the per-key HLL++ sketch computed from the values matching each key in the input PCollection
.
- perKey() - Static method in class org.apache.beam.sdk.extensions.zetasketch.HllCount.MergePartial
-
Returns a Combine.PerKey
PTransform
that takes an input PCollection<KV<K, byte[]>>
of (key, HLL++ sketch) pairs and returns a PCollection<KV<K, byte[]>>
of (key, new sketch merged from the input sketches under the
key).
- perKey(int, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles
-
Returns a PTransform
that takes a PCollection<KV<K, V>>
and returns a PCollection<KV<K, List<V>>>
that contains an output element mapping each distinct key in the
input PCollection
to a List
of the approximate N
-tiles of the values
associated with that key in the input PCollection
.
- perKey(int) - Static method in class org.apache.beam.sdk.transforms.ApproximateQuantiles
-
- perKey(int) - Static method in class org.apache.beam.sdk.transforms.ApproximateUnique
-
Returns a PTransform
that takes a PCollection<KV<K, V>>
and returns a PCollection<KV<K, Long>>
that contains an output element mapping each distinct key in the
input PCollection
to an estimate of the number of distinct values associated with that
key in the input PCollection
.
- perKey(double) - Static method in class org.apache.beam.sdk.transforms.ApproximateUnique
-
- PerKey(int) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.PerKey
-
- PerKey(double) - Constructor for class org.apache.beam.sdk.transforms.ApproximateUnique.PerKey
-
- perKey(SerializableFunction<Iterable<V>, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.PerKey
PTransform
that first groups its input
PCollection
of
KV
s by keys and windows, then invokes the given function on each of the
values lists to produce a combined value, and then returns a
PCollection
of
KV
s
mapping each distinct key to its combined value for each window.
- perKey(SerializableBiFunction<V, V, V>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.PerKey
PTransform
that first groups its input
PCollection
of
KV
s by keys and windows, then invokes the given function on each of the
values lists to produce a combined value, and then returns a
PCollection
of
KV
s
mapping each distinct key to its combined value for each window.
- perKey(CombineFnBase.GlobalCombineFn<? super InputT, ?, OutputT>) - Static method in class org.apache.beam.sdk.transforms.Combine
-
Returns a
Combine.PerKey
PTransform
that first groups its input
PCollection
of
KV
s by keys and windows, then invokes the given function on each of the
values lists to produce a combined value, and then returns a
PCollection
of
KV
s
mapping each distinct key to its combined value for each window.
- perKey() - Static method in class org.apache.beam.sdk.transforms.Count
-
Returns a
PTransform
that counts the number of elements associated with each key of its
input
PCollection
.
- perKey() - Static method in class org.apache.beam.sdk.transforms.Latest
-
Returns a
PTransform
that takes as input a
PCollection<KV<K, V>>
and returns a
PCollection<KV<K, V>>
whose contents is the latest element per-key according to its
event time.
- perKey() - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a PTransform
that takes an input PCollection<KV<K, T>>
and returns a
PCollection<KV<K, T>>
that contains an output element mapping each distinct key in the
input PCollection
to the maximum according to the natural ordering of T
of the
values associated with that key in the input PCollection
.
- perKey(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Max
-
Returns a PTransform
that takes an input PCollection<KV<K, T>>
and returns a
PCollection<KV<K, T>>
that contains one output element per key mapping each to the
maximum of the values associated with that key in the input PCollection
.
- perKey() - Static method in class org.apache.beam.sdk.transforms.Mean
-
Returns a PTransform
that takes an input PCollection<KV<K, N>>
and returns a
PCollection<KV<K, Double>>
that contains an output element mapping each distinct key in
the input PCollection
to the mean of the values associated with that key in the input
PCollection
.
- perKey() - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a PTransform
that takes an input PCollection<KV<K, T>>
and returns a
PCollection<KV<K, T>>
that contains an output element mapping each distinct key in the
input PCollection
to the minimum according to the natural ordering of T
of the
values associated with that key in the input PCollection
.
- perKey(ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Min
-
Returns a PTransform
that takes an input PCollection<KV<K, T>>
and returns a
PCollection<KV<K, T>>
that contains one output element per key mapping each to the
minimum of the values associated with that key in the input PCollection
.
- perKey(int, ComparatorT) - Static method in class org.apache.beam.sdk.transforms.Top
-
Returns a PTransform
that takes an input PCollection<KV<K, V>>
and returns a
PCollection<KV<K, List<V>>>
that contains an output element mapping each distinct key
in the input PCollection
to the largest count
values associated with that key
in the input PCollection<KV<K, V>>
, in decreasing order, sorted using the given Comparator<V>
.
- PerKeyDigest() - Constructor for class org.apache.beam.sdk.extensions.sketching.TDigestQuantiles.PerKeyDigest
-
- PerKeyDistinct() - Constructor for class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct.PerKeyDistinct
-
- PerKeySketch() - Constructor for class org.apache.beam.sdk.extensions.sketching.SketchFrequencies.PerKeySketch
-
- PInput - Interface in org.apache.beam.sdk.values
-
The interface for things that might be input to a
PTransform
.
- pipeline() - Method in class org.apache.beam.runners.fnexecution.jobsubmission.JobPreparation
-
- Pipeline - Class in org.apache.beam.sdk
-
- Pipeline(PipelineOptions) - Constructor for class org.apache.beam.sdk.Pipeline
-
- Pipeline.PipelineExecutionException - Exception in org.apache.beam.sdk
-
Thrown during execution of a
Pipeline
, whenever user code within that
Pipeline
throws an exception.
- Pipeline.PipelineVisitor - Interface in org.apache.beam.sdk
-
For internal use only; no backwards-compatibility guarantees.
- Pipeline.PipelineVisitor.CompositeBehavior - Enum in org.apache.beam.sdk
-
Control enum for indicating whether or not a traversal should process the contents of a
composite transform or not.
- Pipeline.PipelineVisitor.Defaults - Class in org.apache.beam.sdk
-
- PIPELINE_PROTO_CODER_ID - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- PIPELINED - Static variable in interface org.apache.beam.runners.flink.FlinkPipelineOptions
-
- PipelineExecutionException(Throwable) - Constructor for exception org.apache.beam.sdk.Pipeline.PipelineExecutionException
-
- PipelineMessageReceiver - Interface in org.apache.beam.runners.local
-
Handles failures in the form of exceptions.
- pipelineOptions() - Method in class org.apache.beam.runners.fnexecution.provisioning.JobInfo
-
- PipelineOptions - Interface in org.apache.beam.sdk.options
-
PipelineOptions are used to configure Pipelines.
- PipelineOptions.AtomicLongFactory - Class in org.apache.beam.sdk.options
-
DefaultValueFactory
which supplies an ID that is guaranteed to be unique within the
given process.
- PipelineOptions.CheckEnabled - Enum in org.apache.beam.sdk.options
-
Enumeration of the possible states for a given check.
- PipelineOptions.DirectRunner - Class in org.apache.beam.sdk.options
-
A
DefaultValueFactory
that obtains the class of the
DirectRunner
if it exists
on the classpath, and throws an exception otherwise.
- PipelineOptions.JobNameFactory - Class in org.apache.beam.sdk.options
-
- PipelineOptions.UserAgentFactory - Class in org.apache.beam.sdk.options
-
Returns a user agent string constructed from ReleaseInfo.getName()
and ReleaseInfo.getVersion()
, in the format [name]/[version]
.
- PipelineOptionsFactory - Class in org.apache.beam.sdk.options
-
- PipelineOptionsFactory() - Constructor for class org.apache.beam.sdk.options.PipelineOptionsFactory
-
- PipelineOptionsFactory.Builder - Class in org.apache.beam.sdk.options
-
- PipelineOptionsRegistrar - Interface in org.apache.beam.sdk.options
-
PipelineOptions
creators have the ability to automatically have their
PipelineOptions
registered with this SDK by creating a
ServiceLoader
entry and a
concrete implementation of this interface.
- PipelineOptionsValidator - Class in org.apache.beam.sdk.options
-
- PipelineOptionsValidator() - Constructor for class org.apache.beam.sdk.options.PipelineOptionsValidator
-
- PipelineResult - Interface in org.apache.beam.sdk
-
- PipelineResult.State - Enum in org.apache.beam.sdk
-
Possible job states, for both completed and ongoing jobs.
- PipelineRunner<ResultT extends PipelineResult> - Class in org.apache.beam.sdk
-
- PipelineRunner() - Constructor for class org.apache.beam.sdk.PipelineRunner
-
- PipelineTranslator - Class in org.apache.beam.runners.spark.structuredstreaming.translation
-
Pipeline.PipelineVisitor
that translates the Beam operators to their Spark counterparts.
- PipelineTranslator() - Constructor for class org.apache.beam.runners.spark.structuredstreaming.translation.PipelineTranslator
-
- PipelineTranslatorBatch - Class in org.apache.beam.runners.spark.structuredstreaming.translation.batch
-
- PipelineTranslatorBatch(SparkStructuredStreamingPipelineOptions) - Constructor for class org.apache.beam.runners.spark.structuredstreaming.translation.batch.PipelineTranslatorBatch
-
- PipelineTranslatorStreaming - Class in org.apache.beam.runners.spark.structuredstreaming.translation.streaming
-
- PipelineTranslatorStreaming(SparkStructuredStreamingPipelineOptions) - Constructor for class org.apache.beam.runners.spark.structuredstreaming.translation.streaming.PipelineTranslatorStreaming
-
- PipelineTranslatorUtils - Class in org.apache.beam.runners.fnexecution.translation
-
Utilities for pipeline translation.
- plus(RelOptCost) - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.BeamCostModel
-
- plus(NodeStats) - Method in class org.apache.beam.sdk.extensions.sql.impl.planner.NodeStats
-
- plusDelayOf(Duration) - Method in class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
-
Adds some delay to the original target time.
- POJOUtils - Class in org.apache.beam.sdk.schemas.utils
-
A set of utilities to generate getter and setter classes for POJOs.
- POJOUtils() - Constructor for class org.apache.beam.sdk.schemas.utils.POJOUtils
-
- PollFn() - Constructor for class org.apache.beam.sdk.transforms.Watch.Growth.PollFn
-
- pollFor(Duration) - Method in interface org.apache.beam.sdk.io.gcp.bigquery.TestBigQuery.PollingAssertion
-
- pollJob(JobReference, int) - Method in interface org.apache.beam.sdk.io.gcp.bigquery.BigQueryServices.JobService
-
Waits for the job is Done, and returns the job.
- pollJob(JobReference, int) - Method in class org.apache.beam.sdk.io.gcp.testing.FakeJobService
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct.ApproximateDistinctFn
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.extensions.sketching.SketchFrequencies.CountMinSketchFn
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.extensions.sketching.TDigestQuantiles.TDigestQuantilesFn
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.amqp.AmqpIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.Parse
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.ParseAll
-
Deprecated.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.ParseFiles
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.ReadAll
-
Deprecated.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.ReadFiles
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.TypedWrite
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.AvroIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.BoundedReadFromUnboundedSource
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.CompressedSource
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.DefaultFilenamePolicy
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.BoundedElasticsearchSource
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
-
Populates the display data.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileBasedSink.FilenamePolicy
-
Populates the display data.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileBasedSink
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileBasedSource
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileIO.Match
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileIO.MatchAll
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileIO.MatchConfiguration
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.FileIO.ReadMatches
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.TypedRead
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageQuerySource
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageStreamSource
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageTableSource
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.bigtable.BigtableIO.WriteWithResults
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.Write.PubsubBoundedWriter
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerConfig
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.gcp.spanner.SpannerIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.GenerateSequence
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.HadoopInputFormatBoundedSource
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.hbase.HBaseIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.hbase.HBaseIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.hcatalog.HCatalogIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.jdbc.JdbcIO.DataSourceProviderFromDataSourceConfiguration
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.jdbc.JdbcIO.PoolableDataSourceProvider
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.jdbc.JdbcIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.jdbc.JdbcIO.ReadAll
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.jdbc.JdbcIO.ReadRows
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.jdbc.JdbcIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.jms.JmsIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.kafka.KafkaIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.kafka.KafkaIO.TypedWithoutMetadata
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.kafka.KafkaIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.kafka.KafkaIO.WriteRecords
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.mongodb.MongoDbGridFSIO.Read.BoundedGridFSSource
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.mongodb.MongoDbGridFSIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.mongodb.MongoDbGridFSIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.mongodb.MongoDbIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.mongodb.MongoDbIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.mqtt.MqttIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.mqtt.MqttIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.OffsetBasedSource
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.parquet.ParquetIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.Read.Bounded
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.Read.Unbounded
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.redis.RedisConnectionConfiguration
-
Populate the display data with connectionConfiguration details.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.redis.RedisIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.solr.SolrIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.Source
-
Register display data for the given transform or component.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.ReadAll
-
Deprecated.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.ReadFiles
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.TypedWrite
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TextIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TFRecordIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.TFRecordIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.thrift.ThriftIO.ReadFiles
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.tika.TikaIO.Parse
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.tika.TikaIO.ParseFiles
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.WriteFiles
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.xml.XmlIO.Read
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.io.xml.XmlIO.Write
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.Globally
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ApproximateUnique.PerKey
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.Globally
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.GloballyAsSingletonView
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.GroupedValues
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.PerKey
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Combine.PerKeyWithHotKeyFanout
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
-
- populateDisplayData(DisplayData.Builder) - Method in interface org.apache.beam.sdk.transforms.display.HasDisplayData
-
Register display data for the given transform or component.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.DoFn
-
Register display data for the given transform or component.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Filter
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.FlatMapElements.FlatMapWithFailures
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.FlatMapElements
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.GroupByKey
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.InferableFunction
-
Register display data for the given transform or component.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.MapElements.MapWithFailures
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.MapElements
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ParDo.MultiOutput
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.ParDo.SingleOutput
-
Register display data for the given transform or component.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Partition
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.PTransform
-
Register display data for the given transform or component.
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.Top.TopCombineFn
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.FixedWindows
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.Sessions
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.SlidingWindows
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.Window.Assign
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.Window
-
- populateDisplayData(DisplayData.Builder) - Method in class org.apache.beam.sdk.transforms.windowing.WindowFn
-
Register display data for the given transform or component.
- portableMetrics() - Method in class org.apache.beam.runners.flink.FlinkPortableRunnerResult
-
- portableMetrics() - Method in interface org.apache.beam.runners.fnexecution.jobsubmission.PortablePipelineResult
-
Returns the object to access monitoring infos from the pipeline.
- PortableMetrics - Class in org.apache.beam.runners.portability
-
- PortablePipelineJarCreator - Class in org.apache.beam.runners.fnexecution.jobsubmission
-
- PortablePipelineJarCreator(Class) - Constructor for class org.apache.beam.runners.fnexecution.jobsubmission.PortablePipelineJarCreator
-
- PortablePipelineJarUtils - Class in org.apache.beam.runners.fnexecution.jobsubmission
-
Contains common code for writing and reading portable pipeline jars.
- PortablePipelineJarUtils() - Constructor for class org.apache.beam.runners.fnexecution.jobsubmission.PortablePipelineJarUtils
-
- PortablePipelineOptions - Interface in org.apache.beam.sdk.options
-
Pipeline options common to all portable runners.
- PortablePipelineOptions.RetrievalServiceType - Enum in org.apache.beam.sdk.options
-
Enumeration of the different implementations of the artifact retrieval service.
- PortablePipelineResult - Interface in org.apache.beam.runners.fnexecution.jobsubmission
-
- PortablePipelineRunner - Interface in org.apache.beam.runners.fnexecution.jobsubmission
-
Runs a portable Beam pipeline on some execution engine.
- PortableRunner - Class in org.apache.beam.runners.portability
-
- PortableRunnerRegistrar - Class in org.apache.beam.runners.portability
-
Registrar for the portable runner.
- PortableRunnerRegistrar() - Constructor for class org.apache.beam.runners.portability.PortableRunnerRegistrar
-
- positional() - Method in class org.apache.beam.sdk.extensions.sql.impl.QueryPlanner.QueryParameters
-
- POutput - Interface in org.apache.beam.sdk.values
-
The interface for things that might be output from a
PTransform
.
- precisionForRelativeError(double) - Static method in class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct
-
Computes the precision based on the desired relative error.
- prepare(JobApi.PrepareJobRequest, StreamObserver<JobApi.PrepareJobResponse>) - Method in class org.apache.beam.runners.fnexecution.jobsubmission.InMemoryJobService
-
- prepare(JobApi.PrepareJobRequest, StreamObserver<JobApi.PrepareJobResponse>) - Method in class org.apache.beam.runners.portability.testing.TestJobService
-
- prepareCall(String) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- prepareCall(String, int, int) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- prepareCall(String, int, int, int) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- prepareFilesToStage(SparkPipelineOptions) - Static method in interface org.apache.beam.runners.spark.SparkPipelineOptions
-
Classpath contains non jar files (eg.
- prepareFilesToStageForRemoteClusterExecution(SparkStructuredStreamingPipelineOptions) - Static method in class org.apache.beam.runners.spark.structuredstreaming.translation.PipelineTranslator
-
Local configurations work in the same JVM and have no problems with improperly formatted files
on classpath (eg.
- prepareForProcessing() - Method in class org.apache.beam.sdk.transforms.DoFn
-
- prepareStatement(String) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- prepareStatement(String, int, int) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- prepareStatement(String, int, int, int) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- prepareStatement(String, int) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- prepareStatement(String, int[]) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- prepareStatement(String, String[]) - Method in class org.apache.beam.sdk.extensions.sql.impl.CalciteConnectionWrapper
-
- prepareWrite(WritableByteChannel) - Method in class org.apache.beam.sdk.io.FileBasedSink.Writer
-
Called with the channel that a subclass will write its header, footer, and values to.
- PrepareWrite<InputT,DestinationT,OutputT> - Class in org.apache.beam.sdk.io.gcp.bigquery
-
- PrepareWrite(DynamicDestinations<InputT, DestinationT>, SerializableFunction<InputT, OutputT>) - Constructor for class org.apache.beam.sdk.io.gcp.bigquery.PrepareWrite
-
- primary() - Method in class org.apache.beam.sdk.io.gcp.spanner.MutationGroup
-
- PrimitiveParDoSingleFactory<InputT,OutputT> - Class in org.apache.beam.runners.dataflow
-
- PrimitiveParDoSingleFactory() - Constructor for class org.apache.beam.runners.dataflow.PrimitiveParDoSingleFactory
-
- PrimitiveParDoSingleFactory.ParDoSingle<InputT,OutputT> - Class in org.apache.beam.runners.dataflow
-
A single-output primitive
ParDo
.
- PrimitiveParDoSingleFactory.PayloadTranslator - Class in org.apache.beam.runners.dataflow
-
- PrimitiveParDoSingleFactory.Registrar - Class in org.apache.beam.runners.dataflow
-
- printDatasetContent(Dataset<WindowedValue>) - Static method in class org.apache.beam.runners.spark.structuredstreaming.translation.TranslationContext
-
- printHelp(PrintStream) - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
-
Outputs the set of registered options with the PipelineOptionsFactory with a description for
each one if available to the output stream.
- printHelp(PrintStream, Class<? extends PipelineOptions>) - Static method in class org.apache.beam.sdk.options.PipelineOptionsFactory
-
Outputs the set of options available to be set for the passed in
PipelineOptions
interface.
- process(List<JobMessage>) - Method in interface org.apache.beam.runners.dataflow.util.MonitoringUtil.JobMessagesHandler
-
Process the rows.
- process(List<JobMessage>) - Method in class org.apache.beam.runners.dataflow.util.MonitoringUtil.LoggingHandler
-
- processBundle(Iterable<? extends InputT>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- processBundle(InputT...) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- ProcessBundleDescriptors - Class in org.apache.beam.runners.fnexecution.control
-
Utility methods for creating BeamFnApi.ProcessBundleDescriptor
instances.
- ProcessBundleDescriptors() - Constructor for class org.apache.beam.runners.fnexecution.control.ProcessBundleDescriptors
-
- ProcessBundleDescriptors.BagUserStateSpec<K,V,W extends BoundedWindow> - Class in org.apache.beam.runners.fnexecution.control
-
A container type storing references to the key, value, and window
Coder
used when
handling bag user state requests.
- ProcessBundleDescriptors.ExecutableProcessBundleDescriptor - Class in org.apache.beam.runners.fnexecution.control
-
- ProcessBundleDescriptors.SideInputSpec<T,W extends BoundedWindow> - Class in org.apache.beam.runners.fnexecution.control
-
A container type storing references to the value, and window
Coder
used when handling
side input state requests.
- ProcessBundleDescriptors.TimerSpec<K,V,W extends BoundedWindow> - Class in org.apache.beam.runners.fnexecution.control
-
A container type storing references to the key, timer and payload coders and the remote input
destination used when handling timer requests.
- ProcessContext() - Constructor for class org.apache.beam.sdk.transforms.DoFn.ProcessContext
-
- ProcessContinuation() - Constructor for class org.apache.beam.sdk.transforms.DoFn.ProcessContinuation
-
- processElement(DoFn<KV<K, Iterable<KV<Instant, WindowedValue<KV<K, V>>>>>, OutputT>.ProcessContext, BoundedWindow) - Method in class org.apache.beam.runners.dataflow.BatchStatefulParDoOverrides.BatchStatefulDoFn
-
- processElement(DoFn<Iterable<T>, T>.ProcessContext, BoundedWindow) - Method in class org.apache.beam.runners.dataflow.DataflowRunner.StreamingPCollectionViewWriterFn
-
- processElement(WindowedValue<InputT>) - Method in class org.apache.beam.runners.flink.metrics.DoFnRunnerWithMetricsUpdate
-
- processElement(DoFn<KV<Row, Row>, Row>.ProcessContext) - Method in class org.apache.beam.sdk.extensions.sql.impl.transform.BeamJoinTransforms.SideInputJoinDoFn
-
- processElement(DoFn<KV<Row, CoGbkResult>, Row>.ProcessContext) - Method in class org.apache.beam.sdk.extensions.sql.impl.transform.BeamSetOperatorsTransforms.SetOperatorFilteringDoFn
-
- processElement(DoFn<Row, Void>.ProcessContext) - Method in class org.apache.beam.sdk.extensions.sql.impl.transform.BeamSqlOutputToConsoleFn
-
- processElement(DoFn<T, Void>.ProcessContext) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.Write.PubsubBoundedWriter
-
- processElement(InputT) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- processElement(DoFn<ValueWithRecordId<T>, T>.ProcessContext) - Method in class org.apache.beam.sdk.values.ValueWithRecordId.StripIdsDoFn
-
- processElementWithRunner(DoFnRunner<KV<?, ?>, OutputT>, WindowedValue<KV<?, ?>>) - Method in class org.apache.beam.runners.jet.processors.StatefulParDoP
-
- ProcessEnvironment - Class in org.apache.beam.runners.fnexecution.environment
-
Environment for process-based execution.
- ProcessEnvironmentFactory - Class in org.apache.beam.runners.fnexecution.environment
-
- ProcessEnvironmentFactory.Provider - Class in org.apache.beam.runners.fnexecution.environment
-
Provider of ProcessEnvironmentFactory.
- ProcessFunction<InputT,OutputT> - Interface in org.apache.beam.sdk.transforms
-
A function that computes an output value of type OutputT
from an input value of type
InputT
and is Serializable
.
- ProcessingTimeEvent() - Constructor for class org.apache.beam.sdk.testing.TestStream.ProcessingTimeEvent
-
- ProcessingTimePolicy() - Constructor for class org.apache.beam.sdk.io.kafka.TimestampPolicyFactory.ProcessingTimePolicy
-
- ProcessingTimeWatermarkPolicy() - Constructor for class org.apache.beam.sdk.io.kinesis.WatermarkPolicyFactory.ProcessingTimeWatermarkPolicy
-
- ProcessManager - Class in org.apache.beam.runners.fnexecution.environment
-
A simple process manager which forks processes and kills them if necessary.
- ProcessManager.RunningProcess - Class in org.apache.beam.runners.fnexecution.environment
-
- processTimestampedElement(TimestampedValue<InputT>) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- ProcessWatcher(Process) - Constructor for class org.apache.beam.runners.apex.ApexYarnLauncher.ProcessWatcher
-
- processWindowedElement(InputT, Instant, BoundedWindow) - Method in class org.apache.beam.sdk.transforms.DoFnTester
-
- ProducerRecordCoder<K,V> - Class in org.apache.beam.sdk.io.kafka
-
- ProducerRecordCoder(Coder<K>, Coder<V>) - Constructor for class org.apache.beam.sdk.io.kafka.ProducerRecordCoder
-
- productArity() - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.helpers.EncoderHelpers.DecodeUsingBeamCoder
-
- productArity() - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.helpers.EncoderHelpers.EncodeUsingBeamCoder
-
- productElement(int) - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.helpers.EncoderHelpers.DecodeUsingBeamCoder
-
- productElement(int) - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.helpers.EncoderHelpers.EncodeUsingBeamCoder
-
- PROJECT_ID_REGEXP - Static variable in class org.apache.beam.runners.dataflow.DataflowRunner
-
Project IDs must contain lowercase letters, digits, or dashes.
- projectPathFromId(String) - Static method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient
-
- projectPathFromPath(String) - Static method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient
-
- ProjectSupport - Enum in org.apache.beam.sdk.extensions.sql.meta
-
- properties(JSONObject) - Method in class org.apache.beam.sdk.extensions.sql.meta.Table.Builder
-
- properties() - Method in class org.apache.beam.sdk.io.clickhouse.ClickHouseIO.Write
-
- PROPERTY_BEAM_TEST_PIPELINE_OPTIONS - Static variable in class org.apache.beam.sdk.testing.TestPipeline
-
- propertyName() - Method in class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
-
Returns the property name associated with this provider.
- propertyName() - Method in class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
-
Returns the property name that corresponds to this provider.
- PropertyNames - Class in org.apache.beam.runners.dataflow.util
-
Constant property names used by the SDK in CloudWorkflow specifications.
- PropertyNames() - Constructor for class org.apache.beam.runners.dataflow.util.PropertyNames
-
- ProtobufCoderProviderRegistrar - Class in org.apache.beam.sdk.extensions.protobuf
-
- ProtobufCoderProviderRegistrar() - Constructor for class org.apache.beam.sdk.extensions.protobuf.ProtobufCoderProviderRegistrar
-
- ProtoCoder<T extends Message> - Class in org.apache.beam.sdk.extensions.protobuf
-
A
Coder
using Google Protocol Buffers binary format.
- ProtoCoder(Class<T>, Set<Class<?>>) - Constructor for class org.apache.beam.sdk.extensions.protobuf.ProtoCoder
-
Private constructor.
- ProtoDomain - Class in org.apache.beam.sdk.extensions.protobuf
-
ProtoDomain is a container class for Protobuf descriptors.
- ProtoDynamicMessageSchema<T> - Class in org.apache.beam.sdk.extensions.protobuf
-
- ProtoMessageSchema - Class in org.apache.beam.sdk.extensions.protobuf
-
- ProtoMessageSchema() - Constructor for class org.apache.beam.sdk.extensions.protobuf.ProtoMessageSchema
-
- ProtoSchemaLogicalTypes - Class in org.apache.beam.sdk.extensions.protobuf
-
- ProtoSchemaLogicalTypes() - Constructor for class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes
-
- ProtoSchemaLogicalTypes.DurationConvert - Class in org.apache.beam.sdk.extensions.protobuf
-
- ProtoSchemaLogicalTypes.Fixed32 - Class in org.apache.beam.sdk.extensions.protobuf
-
A Fixed32 type.
- ProtoSchemaLogicalTypes.Fixed64 - Class in org.apache.beam.sdk.extensions.protobuf
-
A Fixed64 type.
- ProtoSchemaLogicalTypes.SFixed32 - Class in org.apache.beam.sdk.extensions.protobuf
-
A SFixed32 type.
- ProtoSchemaLogicalTypes.SFixed64 - Class in org.apache.beam.sdk.extensions.protobuf
-
An SFixed64 type.
- ProtoSchemaLogicalTypes.SInt32 - Class in org.apache.beam.sdk.extensions.protobuf
-
A SInt32 type.
- ProtoSchemaLogicalTypes.SInt64 - Class in org.apache.beam.sdk.extensions.protobuf
-
A SIn64 type.
- ProtoSchemaLogicalTypes.TimestampConvert - Class in org.apache.beam.sdk.extensions.protobuf
-
- ProtoSchemaLogicalTypes.UInt32 - Class in org.apache.beam.sdk.extensions.protobuf
-
A UInt32 type.
- ProtoSchemaLogicalTypes.UInt64 - Class in org.apache.beam.sdk.extensions.protobuf
-
A UIn64 type.
- Provider(PipelineOptions) - Constructor for class org.apache.beam.runners.fnexecution.environment.DockerEnvironmentFactory.Provider
-
- Provider(PipelineOptions) - Constructor for class org.apache.beam.runners.fnexecution.environment.EmbeddedEnvironmentFactory.Provider
-
- Provider() - Constructor for class org.apache.beam.runners.fnexecution.environment.ExternalEnvironmentFactory.Provider
-
- Provider(PipelineOptions) - Constructor for class org.apache.beam.runners.fnexecution.environment.ProcessEnvironmentFactory.Provider
-
- Provider(InstructionRequestHandler) - Constructor for class org.apache.beam.runners.fnexecution.environment.StaticRemoteEnvironmentFactory.Provider
-
- PTransform<InputT extends PInput,OutputT extends POutput> - Class in org.apache.beam.sdk.transforms
-
A
PTransform<InputT, OutputT>
is an operation that takes an
InputT
(some subtype
of
PInput
) and produces an
OutputT
(some subtype of
POutput
).
- PTransform() - Constructor for class org.apache.beam.sdk.transforms.PTransform
-
- PTransform(String) - Constructor for class org.apache.beam.sdk.transforms.PTransform
-
- publish(PubsubClient.TopicPath, List<PubsubClient.OutgoingMessage>) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient
-
Publish outgoingMessages
to Pubsub topic
.
- publish(PubsubClient.TopicPath, List<PubsubClient.OutgoingMessage>) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubGrpcClient
-
- publish(PubsubClient.TopicPath, List<PubsubClient.OutgoingMessage>) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubJsonClient
-
- publish(PubsubClient.TopicPath, List<PubsubClient.OutgoingMessage>) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubTestClient
-
- publish(List<PubsubMessage>) - Method in class org.apache.beam.sdk.io.gcp.pubsub.TestPubsub
-
- PublishResponseCoder - Class in org.apache.beam.sdk.io.aws2.sns
-
Custom Coder for handling publish result.
- PublishResultCoder - Class in org.apache.beam.sdk.io.aws.sns
-
Custom Coder for handling publish result.
- PUBSUB_ID_ATTRIBUTE - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- PUBSUB_SERIALIZED_ATTRIBUTES_FN - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- PUBSUB_SUBSCRIPTION - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- PUBSUB_SUBSCRIPTION_OVERRIDE - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- PUBSUB_TIMESTAMP_ATTRIBUTE - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- PUBSUB_TOPIC - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- PUBSUB_TOPIC_OVERRIDE - Static variable in class org.apache.beam.runners.dataflow.util.PropertyNames
-
- PubsubClient - Class in org.apache.beam.sdk.io.gcp.pubsub
-
An (abstract) helper class for talking to Pubsub via an underlying transport.
- PubsubClient() - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient
-
- PubsubClient.OutgoingMessage - Class in org.apache.beam.sdk.io.gcp.pubsub
-
A message to be sent to Pubsub.
- PubsubClient.ProjectPath - Class in org.apache.beam.sdk.io.gcp.pubsub
-
Path representing a cloud project id.
- PubsubClient.PubsubClientFactory - Interface in org.apache.beam.sdk.io.gcp.pubsub
-
Factory for creating clients.
- PubsubClient.SubscriptionPath - Class in org.apache.beam.sdk.io.gcp.pubsub
-
Path representing a Pubsub subscription.
- PubsubClient.TopicPath - Class in org.apache.beam.sdk.io.gcp.pubsub
-
Path representing a Pubsub topic.
- PubsubCoderProviderRegistrar - Class in org.apache.beam.sdk.io.gcp.pubsub
-
- PubsubCoderProviderRegistrar() - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubCoderProviderRegistrar
-
- PubsubGrpcClient - Class in org.apache.beam.sdk.io.gcp.pubsub
-
A helper class for talking to Pubsub via grpc.
- PubsubIO - Class in org.apache.beam.sdk.io.gcp.pubsub
-
Read and Write
PTransform
s for Cloud Pub/Sub streams.
- PubsubIO.PubsubSubscription - Class in org.apache.beam.sdk.io.gcp.pubsub
-
Class representing a Cloud Pub/Sub Subscription.
- PubsubIO.PubsubTopic - Class in org.apache.beam.sdk.io.gcp.pubsub
-
Class representing a Cloud Pub/Sub Topic.
- PubsubIO.Read<T> - Class in org.apache.beam.sdk.io.gcp.pubsub
-
- PubsubIO.Write<T> - Class in org.apache.beam.sdk.io.gcp.pubsub
-
- PubsubIO.Write.PubsubBoundedWriter - Class in org.apache.beam.sdk.io.gcp.pubsub
-
Writer to Pubsub which batches messages from bounded collections.
- PubsubIOTableConfiguration() - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.pubsub.PubsubJsonTableProvider.PubsubIOTableConfiguration
-
- PubsubJsonClient - Class in org.apache.beam.sdk.io.gcp.pubsub
-
A Pubsub client using JSON transport.
- PubsubJsonTableProvider - Class in org.apache.beam.sdk.extensions.sql.meta.provider.pubsub
-
- PubsubJsonTableProvider() - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.pubsub.PubsubJsonTableProvider
-
- PubsubJsonTableProvider.PubsubIOTableConfiguration - Class in org.apache.beam.sdk.extensions.sql.meta.provider.pubsub
-
- PubsubMessage - Class in org.apache.beam.sdk.io.gcp.pubsub
-
Class representing a Pub/Sub message.
- PubsubMessage(byte[], Map<String, String>) - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessage
-
- PubsubMessage(byte[], Map<String, String>, String) - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessage
-
- PubsubMessagePayloadOnlyCoder - Class in org.apache.beam.sdk.io.gcp.pubsub
-
A coder for PubsubMessage treating the raw bytes being decoded as the message's payload.
- PubsubMessagePayloadOnlyCoder() - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessagePayloadOnlyCoder
-
- PubsubMessageToRow - Class in org.apache.beam.sdk.extensions.sql.meta.provider.pubsub
-
- PubsubMessageToRow() - Constructor for class org.apache.beam.sdk.extensions.sql.meta.provider.pubsub.PubsubMessageToRow
-
- PubsubMessageWithAttributesAndMessageIdCoder - Class in org.apache.beam.sdk.io.gcp.pubsub
-
A coder for PubsubMessage including attributes and the message id from the PubSub server.
- PubsubMessageWithAttributesAndMessageIdCoder() - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessageWithAttributesAndMessageIdCoder
-
- PubsubMessageWithAttributesCoder - Class in org.apache.beam.sdk.io.gcp.pubsub
-
A coder for PubsubMessage including attributes.
- PubsubMessageWithAttributesCoder() - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessageWithAttributesCoder
-
- PubsubMessageWithMessageIdCoder - Class in org.apache.beam.sdk.io.gcp.pubsub
-
A coder for PubsubMessage treating the raw bytes being decoded as the message's payload, with the
message id from the PubSub server.
- PubsubMessageWithMessageIdCoder() - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessageWithMessageIdCoder
-
- PubsubOptions - Interface in org.apache.beam.sdk.io.gcp.pubsub
-
Properties that can be set when using Google Cloud Pub/Sub with the Apache Beam SDK.
- PubsubTestClient - Class in org.apache.beam.sdk.io.gcp.pubsub
-
A (partial) implementation of
PubsubClient
for use by unit tests.
- PubsubTestClient() - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubTestClient
-
- PubsubTestClient.PubsubTestClientFactory - Interface in org.apache.beam.sdk.io.gcp.pubsub
-
Closing the factory will validate all expected messages were processed.
- PubsubUnboundedSink - Class in org.apache.beam.sdk.io.gcp.pubsub
-
A PTransform which streams messages to Pubsub.
- PubsubUnboundedSink(PubsubClient.PubsubClientFactory, ValueProvider<PubsubClient.TopicPath>, String, String, int) - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSink
-
- PubsubUnboundedSink(PubsubClient.PubsubClientFactory, ValueProvider<PubsubClient.TopicPath>, String, String, int, int, int) - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSink
-
- PubsubUnboundedSource - Class in org.apache.beam.sdk.io.gcp.pubsub
-
- PubsubUnboundedSource(PubsubClient.PubsubClientFactory, ValueProvider<PubsubClient.ProjectPath>, ValueProvider<PubsubClient.TopicPath>, ValueProvider<PubsubClient.SubscriptionPath>, String, String, boolean) - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSource
-
Construct an unbounded source to consume from the Pubsub subscription
.
- PubsubUnboundedSource(Clock, PubsubClient.PubsubClientFactory, ValueProvider<PubsubClient.ProjectPath>, ValueProvider<PubsubClient.TopicPath>, ValueProvider<PubsubClient.SubscriptionPath>, String, String, boolean) - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSource
-
Construct an unbounded source to consume from the Pubsub subscription
.
- PubsubUnboundedSource(PubsubClient.PubsubClientFactory, ValueProvider<PubsubClient.ProjectPath>, ValueProvider<PubsubClient.TopicPath>, ValueProvider<PubsubClient.SubscriptionPath>, String, String, boolean, boolean) - Constructor for class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSource
-
Construct an unbounded source to consume from the Pubsub subscription
.
- pull(long, PubsubClient.SubscriptionPath, int, boolean) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient
-
Request the next batch of up to batchSize
messages from subscription
.
- pull(long, PubsubClient.SubscriptionPath, int, boolean) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubGrpcClient
-
- pull(long, PubsubClient.SubscriptionPath, int, boolean) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubJsonClient
-
- pull(long, PubsubClient.SubscriptionPath, int, boolean) - Method in class org.apache.beam.sdk.io.gcp.pubsub.PubsubTestClient
-
- pull() - Method in class org.apache.beam.sdk.io.gcp.pubsub.TestPubsub
-
- pull(int) - Method in class org.apache.beam.sdk.io.gcp.pubsub.TestPubsub
-
- PUSH_DOWN_OPTION - Static variable in class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestTableProvider
-
- put(String, InstructionRequestHandler) - Method in interface org.apache.beam.runners.fnexecution.control.ControlClientPool.Sink
-
- put(K2, V2) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
-
- put(K, V) - Method in interface org.apache.beam.sdk.state.MapState
-
Associates the specified value with the specified key in this state.
- putAll(Map<? extends K2, ? extends V2>) - Method in class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
-
- putArtifact(StreamObserver<ArtifactApi.PutArtifactResponse>) - Method in class org.apache.beam.runners.fnexecution.artifact.AbstractArtifactStagingService
-
- putDataset(PValue, Dataset<WindowedValue<T>>) - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.TranslationContext
-
- putDatasetWildcard(PValue, Dataset<WindowedValue<?>>) - Method in class org.apache.beam.runners.spark.structuredstreaming.translation.TranslationContext
-
TODO: All these 3 methods (putDataset*) are temporary and they are used only for generics type
checking.
- putIfAbsent(K, V) - Method in interface org.apache.beam.sdk.state.MapState
-
A deferred read-followed-by-write.
- PValue - Interface in org.apache.beam.sdk.values
-
For internal use.
- PValueBase - Class in org.apache.beam.sdk.values
-
For internal use.
- PValueBase(Pipeline) - Constructor for class org.apache.beam.sdk.values.PValueBase
-
- PValueBase() - Constructor for class org.apache.beam.sdk.values.PValueBase
-
No-arg constructor to allow subclasses to implement Serializable
.