All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
| Class |
Description |
| AddFields |
A transform to add new nullable fields to a PCollection's schema.
|
| AddFields.Inner<T> |
Inner PTransform for AddFields.
|
| AddHarnessIdInterceptor |
A ClientInterceptor that attaches a provided SDK Harness ID to outgoing messages.
|
| AdvancingPhaser |
A Phaser which never terminates.
|
| AfterAll |
A composite Trigger that fires when all of its sub-triggers are ready.
|
| AfterEach |
A composite Trigger that executes its sub-triggers in order.
|
| AfterFirst |
A composite Trigger that fires once after at least one of its sub-triggers have fired.
|
| AfterPane |
A Trigger that fires at some point after a specified number of input elements have
arrived.
|
| AfterProcessingTime |
A Trigger trigger that fires at a specified point in processing time, relative to when
input first arrives.
|
| AfterSynchronizedProcessingTime |
FOR INTERNAL USE ONLY.
|
| AfterWatermark |
AfterWatermark triggers fire based on progress of the system watermark.
|
| AfterWatermark.AfterWatermarkEarlyAndLate |
|
| AfterWatermark.FromEndOfWindow |
A watermark trigger targeted relative to the end of the window.
|
| ApiSurface |
Represents the API surface of a package prefix.
|
| ApplicationNameOptions |
Options that allow setting the application name.
|
| AppliedCombineFn<K,InputT,AccumT,OutputT> |
|
| AppliedPTransform<InputT extends PInput,OutputT extends POutput,TransformT extends PTransform<? super InputT,OutputT>> |
For internal use only; no backwards-compatibility guarantees.
|
| ApproximateQuantiles |
PTransforms for getting an idea of a PCollection's data distribution using
approximate N-tiles (e.g.
|
| ApproximateQuantiles.ApproximateQuantilesCombineFn<T,ComparatorT extends java.util.Comparator<T> & java.io.Serializable> |
The ApproximateQuantilesCombineFn combiner gives an idea of the distribution of a
collection of values using approximate N-tiles.
|
| ApproximateUnique |
Deprecated.
|
| ApproximateUnique.ApproximateUniqueCombineFn<T> |
CombineFn that computes an estimate of the number of distinct values that were
combined.
|
| ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique |
A heap utility class to efficiently track the largest added elements.
|
| ApproximateUnique.Globally<T> |
PTransform for estimating the number of distinct elements in a PCollection.
|
| ApproximateUnique.PerKey<K,V> |
PTransform for estimating the number of distinct values associated with each key in a
PCollection of KVs.
|
| ArtifactResolver |
An interface for artifact resolvers.
|
| ArtifactResolver.ResolutionFn |
A lazy transformer for resolving RunnerApi.ArtifactInformation.
|
| AtomicCoder<T> |
A Coder that has no component Coders or other configuration.
|
| AutoValueSchema |
|
| AutoValueSchema.AbstractGetterTypeSupplier |
|
| AutoValueUtils |
Utilities for managing AutoValue schemas.
|
| BackOff |
Back-off policy when retrying an operation.
|
| BackOffUtils |
|
| BadRecord |
|
| BadRecord.Builder |
|
| BadRecord.Failure |
|
| BadRecord.Failure.Builder |
|
| BadRecord.Record |
|
| BadRecord.Record.Builder |
|
| BadRecordRouter |
|
| BadRecordRouter.RecordingBadRecordRouter |
|
| BadRecordRouter.ThrowingBadRecordRouter |
|
| BagState<T> |
|
| BeamFnDataGrpcMultiplexer |
A gRPC multiplexer for a specific Endpoints.ApiServiceDescriptor.
|
| BeamFnDataInboundObserver |
|
| BeamFnDataInboundObserver.CloseException |
|
| BeamFnDataOutboundAggregator |
An outbound data buffering aggregator with size-based buffer and time-based buffer if
corresponding options are set.
|
| BeamUrns |
Returns the standard URN of a given enum annotated with [(standard_urn)].
|
| BigDecimalCoder |
|
| BigEndianIntegerCoder |
|
| BigEndianLongCoder |
|
| BigEndianShortCoder |
|
| BigIntegerCoder |
|
| BitSetCoder |
Coder for BitSet.
|
| BitSetCoder |
Deprecated.
|
| BlockBasedSource<T> |
A BlockBasedSource is a FileBasedSource where a file consists of blocks of
records.
|
| BlockBasedSource.Block<T> |
A Block represents a block of records that can be read.
|
| BlockBasedSource.BlockBasedReader<T> |
|
| BooleanCoder |
|
| BoundedReadFromUnboundedSource<T> |
PTransform that reads a bounded amount of data from an UnboundedSource, specified
as one or both of a maximum number of elements or a maximum period of time to read.
|
| BoundedSource<T> |
A Source that reads a finite amount of input and, because of that, supports some
additional operations.
|
| BoundedSource.BoundedReader<T> |
A Reader that reads a bounded amount of input and supports some additional operations,
such as progress estimation and dynamic work rebalancing.
|
| BoundedTrie |
Internal: For internal use only and not for public consumption.
|
| BoundedTrieResult |
Internal: For internal use only and not for public consumption.
|
| BoundedWindow |
A BoundedWindow represents window information assigned to data elements.
|
| BucketingFunction |
Keep track of the minimum/maximum/sum of a set of timestamped long values.
|
| BufferedElementCountingOutputStream |
Provides an efficient encoding for Iterables containing small values by buffering up to
bufferSize bytes of data before prefixing the count.
|
| BufferingStreamObserver<T extends @NonNull java.lang.Object> |
A thread safe StreamObserver which uses a bounded queue to pass elements to a processing
thread responsible for interacting with the underlying CallStreamObserver.
|
| ByteArrayCoder |
|
| ByteBuddyUtils |
|
| ByteBuddyUtils |
Utilities for working with Byte Buddy.
|
| ByteBuddyUtils.ConvertType |
Give a Java type, returns the Java type expected for use with Row.
|
| ByteBuddyUtils.ConvertValueForGetter |
Takes a StackManipulation that returns a value.
|
| ByteBuddyUtils.ConvertValueForSetter |
Row is going to call the setter with its internal Java type, however the user object being set
might have a different type internally.
|
| ByteBuddyUtils.DefaultTypeConversionsFactory |
|
| ByteBuddyUtils.InjectPackageStrategy |
A naming strategy for ByteBuddy classes.
|
| ByteBuddyUtils.TransformingMap<K1,V1,K2,V2> |
|
| ByteBuddyUtils.TypeConversion<T> |
|
| ByteBuddyUtils.TypeConversionsFactory |
|
| ByteCoder |
A ByteCoder encodes Byte values in 1 byte using Java serialization.
|
| ByteKey |
A class representing a key consisting of an array of bytes.
|
| ByteKeyRange |
A class representing a range of ByteKeys.
|
| ByteKeyRangeTracker |
|
| ByteKeyRangeTracker |
|
| ByteStringOutputStream |
An OutputStream that produces ByteStrings.
|
| CachingFactory<CreatedT extends @NonNull java.lang.Object> |
A wrapper around a Factory that assumes the schema parameter never changes.
|
| CalendarWindows |
A collection of WindowFns that windows values into calendar-based windows such as spans
of days, months, or years.
|
| CalendarWindows.DaysWindows |
A WindowFn that windows elements into periods measured by days.
|
| CalendarWindows.MonthsWindows |
A WindowFn that windows elements into periods measured by months.
|
| CalendarWindows.YearsWindows |
A WindowFn that windows elements into periods measured by years.
|
| CancellableQueue<T extends @NonNull java.lang.Object> |
A simplified ThreadSafe blocking queue that can be cancelled freeing any blocked Threads and preventing future Threads from blocking.
|
| CannotProvideCoderException |
|
| CannotProvideCoderException.ReasonCode |
Indicates the reason that Coder inference failed.
|
| Cast<T> |
Set of utilities for casting rows between schemas.
|
| Cast.CompatibilityError |
Describes compatibility errors during casting.
|
| Cast.Narrowing |
Narrowing changes type without guarantee to preserve data.
|
| Cast.Validator |
Interface for statically validating casts.
|
| Cast.Widening |
Widening changes to type that can represent any possible value of the original type.
|
| ClassLoaderFileSystem |
A read-only FileSystem implementation looking up resources using a ClassLoader.
|
| ClassLoaderFileSystem.ClassLoaderFileSystemRegistrar |
|
| ClassLoaderFileSystem.ClassLoaderResourceId |
|
| ClasspathScanningResourcesDetector |
Attempts to detect all the resources to be staged using classgraph library.
|
| CloseableFnDataReceiver<T> |
A receiver of streamed data that can be closed.
|
| CloseableThrowingConsumer<ExceptionT extends java.lang.Exception,T> |
|
| Coder<T> |
A Coder<T> defines how to encode and decode values of type T into
byte streams.
|
| Coder.Context |
Deprecated.
|
| Coder.NonDeterministicException |
Exception thrown by Coder.verifyDeterministic() if the encoding is not deterministic,
including details of why the encoding is not deterministic.
|
| CoderException |
An Exception thrown if there is a problem encoding or decoding a value.
|
| CoderProperties |
Properties for use in Coder tests.
|
| CoderProperties.TestElementByteSizeObserver |
|
| CoderProvider |
|
| CoderProviderRegistrar |
Coder creators have the ability to automatically have their coders
registered with this SDK by creating a ServiceLoader entry and a concrete implementation
of this interface.
|
| CoderProviders |
Static utility methods for creating and working with CoderProviders.
|
| CoderRegistry |
|
| CoderTranslation |
Converts to and from Beam Runner API representations of Coders.
|
| CoderTranslation.TranslationContext |
Pass through additional parameters beyond the components and payload to be able to translate
specific coders.
|
| CoderTranslator<T extends Coder<?>> |
An interface that translates coders to components and back.
|
| CoderTranslatorRegistrar |
|
| CoderUtils |
Utilities for working with Coders.
|
| CoGbkResult |
|
| CoGbkResult.CoGbkResultCoder |
|
| CoGbkResultSchema |
|
| CoGroup |
A transform that performs equijoins across multiple schema PCollections.
|
| CoGroup.By |
Defines the set of fields to extract for the join key, as well as other per-input join options.
|
| CoGroup.ExpandCrossProduct |
A PTransform that calculates the cross-product join.
|
| CoGroup.Impl |
The implementing PTransform.
|
| CoGroup.Result |
|
| CoGroupByKey<K> |
|
| CollectionCoder<T> |
|
| Combine |
PTransforms for combining PCollection elements globally and per-key.
|
| Combine.AccumulatingCombineFn<InputT,AccumT extends Combine.AccumulatingCombineFn.Accumulator<InputT,AccumT,OutputT>,OutputT> |
|
| Combine.AccumulatingCombineFn.Accumulator<InputT,AccumT,OutputT> |
The type of mutable accumulator values used by this AccumulatingCombineFn.
|
| Combine.BinaryCombineDoubleFn |
An abstract subclass of Combine.CombineFn for implementing combiners that are more easily and
efficiently expressed as binary operations on doubles.
|
| Combine.BinaryCombineFn<V> |
An abstract subclass of Combine.CombineFn for implementing combiners that are more easily
expressed as binary operations.
|
| Combine.BinaryCombineIntegerFn |
An abstract subclass of Combine.CombineFn for implementing combiners that are more easily and
efficiently expressed as binary operations on ints
|
| Combine.BinaryCombineLongFn |
An abstract subclass of Combine.CombineFn for implementing combiners that are more easily and
efficiently expressed as binary operations on longs.
|
| Combine.CombineFn<InputT extends @Nullable java.lang.Object,AccumT extends @Nullable java.lang.Object,OutputT extends @Nullable java.lang.Object> |
A CombineFn<InputT, AccumT, OutputT> specifies how to combine a collection of input
values of type InputT into a single output value of type OutputT.
|
| Combine.Globally<InputT,OutputT> |
Combine.Globally<InputT, OutputT> takes a PCollection<InputT> and returns a
PCollection<OutputT> whose elements are the result of combining all the elements in
each window of the input PCollection, using a specified CombineFn<InputT, AccumT, OutputT>.
|
| Combine.GloballyAsSingletonView<InputT,OutputT> |
Combine.GloballyAsSingletonView<InputT, OutputT> takes a PCollection<InputT>
and returns a PCollectionView<OutputT> whose elements are the result of combining all
the elements in each window of the input PCollection, using a specified CombineFn<InputT, AccumT, OutputT>.
|
| Combine.GroupedValues<K,InputT,OutputT> |
GroupedValues<K, InputT, OutputT> takes a PCollection<KV<K, Iterable<InputT>>>,
such as the result of GroupByKey, applies a specified CombineFn<InputT, AccumT, OutputT> to each of the input KV<K, Iterable<InputT>>
elements to produce a combined output KV<K, OutputT> element, and returns a
PCollection<KV<K, OutputT>> containing all the combined output elements.
|
| Combine.Holder<V> |
Holds a single value value of type V which may or may not be present.
|
| Combine.IterableCombineFn<V> |
|
| Combine.PerKey<K,InputT,OutputT> |
PerKey<K, InputT, OutputT> takes a PCollection<KV<K, InputT>>, groups it by
key, applies a combining function to the InputT values associated with each key to
produce a combined OutputT value, and returns a PCollection<KV<K, OutputT>>
representing a map from each distinct key of the input PCollection to the corresponding
combined value.
|
| Combine.PerKeyWithHotKeyFanout<K,InputT,OutputT> |
|
| Combine.SimpleCombineFn<V> |
Deprecated. |
| CombineContextFactory |
Factory that produces Combine.Context based on different inputs.
|
| CombineFnBase |
For internal use only; no backwards-compatibility guarantees.
|
| CombineFnBase.GlobalCombineFn<InputT,AccumT,OutputT> |
For internal use only; no backwards-compatibility guarantees.
|
| CombineFns |
Static utility methods that create combine function instances.
|
| CombineFns.CoCombineResult |
A tuple of outputs produced by a composed combine functions.
|
| CombineFns.ComposeCombineFnBuilder |
|
| CombineFns.ComposedCombineFn<DataT> |
|
| CombineFns.ComposedCombineFnWithContext<DataT> |
|
| CombineFnTester |
|
| CombineFnUtil |
Static utility methods that create combine function instances.
|
| CombineTranslation |
|
| CombineTranslation.CombineGloballyPayloadTranslator |
|
| CombineTranslation.CombineGroupedValuesPayloadTranslator |
|
| CombineTranslation.CombinePerKeyPayloadTranslator |
|
| CombineTranslation.Registrar |
|
| CombineWithContext |
This class contains combine functions that have access to PipelineOptions and side inputs
through CombineWithContext.Context.
|
| CombineWithContext.CombineFnWithContext<InputT,AccumT,OutputT> |
A combine function that has access to PipelineOptions and side inputs through
CombineWithContext.Context.
|
| CombineWithContext.Context |
Information accessible to all methods in CombineFnWithContext and
KeyedCombineFnWithContext.
|
| CombineWithContext.RequiresContextInternal |
An internal interface for signaling that a GloballyCombineFn or a
PerKeyCombineFn needs to access CombineWithContext.Context.
|
| CombiningState<InputT,AccumT,OutputT> |
A ReadableState cell defined by a Combine.CombineFn, accepting multiple input values,
combining them as specified into accumulators, and producing a single output value.
|
| CompressedSource<T> |
A Source that reads from compressed files.
|
| CompressedSource.CompressedReader<T> |
|
| CompressedSource.CompressionMode |
Deprecated.
|
| CompressedSource.DecompressingChannelFactory |
Factory interface for creating channels that decompress the content of an underlying channel.
|
| Compression |
Various compression types for reading/writing files.
|
| Contextful<ClosureT> |
Pair of a bit of user code (a "closure") and the Requirements needed to run it.
|
| Contextful.Fn<InputT,OutputT> |
A function from an input to an output that may additionally access Contextful.Fn.Context when
computing the result.
|
| Contextful.Fn.Context |
|
| Convert |
A set of utilities for converting between different objects supporting schemas.
|
| ConvertHelpers |
Helper functions for converting between equivalent schema types.
|
| ConvertHelpers.ConvertedSchemaInformation<T> |
Return value after converting a schema.
|
| Count |
|
| Counter |
A metric that reports a single long value and can be incremented or decremented.
|
| CountingSource |
|
| CountingSource.CounterMark |
The checkpoint for an unbounded CountingSource is simply the last value produced.
|
| CountingSource.CounterMarkCoder |
A custom coder for CounterMark.
|
| CrashingRunner |
|
| Create<T> |
Create<T> takes a collection of elements of type T known when the pipeline is
constructed and returns a PCollection<T> containing the elements.
|
| Create.OfValueProvider<T> |
|
| Create.TimestampedValues<T> |
A PTransform that creates a PCollection whose elements have associated
timestamps.
|
| Create.Values<T> |
A PTransform that creates a PCollection from a set of in-memory objects.
|
| Create.WindowedValues<T> |
A PTransform that creates a PCollection whose elements have associated
windowing metadata.
|
| CreateOptions |
An abstract class that contains common configuration options for creating resources.
|
| CreateOptions.Builder<BuilderT extends CreateOptions.Builder<BuilderT>> |
|
| CreateOptions.StandardCreateOptions |
A standard configuration options with builder.
|
| CreateOptions.StandardCreateOptions.Builder |
|
| CreatePCollectionViewTranslation |
Deprecated.
|
| CreatePCollectionViewTranslation.Registrar |
Deprecated.
|
| CustomCoder<T> |
|
| DataEndpoint<T> |
|
| DataStreams |
|
| DataStreams.DataStreamDecoder<T> |
|
| DataStreams.ElementDelimitedOutputStream |
|
| DataStreams.OutputChunkConsumer<T> |
|
| Date |
A date without a time-zone.
|
| DateTime |
A datetime without a time-zone.
|
| DeadLetteredTransform<InputT,OutputT> |
|
| DecodingFnDataReceiver<T> |
A receiver of encoded data, decoding it and passing it onto a downstream consumer.
|
| Deduplicate |
A set of PTransforms which deduplicate input records over a time domain and threshold.
|
| Deduplicate.KeyedValues<K,V> |
Deduplicates keyed values using the key over a specified time domain and threshold.
|
| Deduplicate.Values<T> |
Deduplicates values over a specified time domain and threshold.
|
| Deduplicate.WithRepresentativeValues<T,IdT> |
|
| DeduplicatedFlattenFactory<T> |
|
| Default |
Default represents a set of annotations that can be used to annotate getter properties on
PipelineOptions with information representing the default value to be returned if no
value is specified.
|
| Default.Boolean |
This represents that the default of the option is the specified boolean primitive value.
|
| Default.Byte |
This represents that the default of the option is the specified byte primitive value.
|
| Default.Character |
This represents that the default of the option is the specified char primitive value.
|
| Default.Class |
This represents that the default of the option is the specified Class value.
|
| Default.Double |
This represents that the default of the option is the specified double primitive value.
|
| Default.Enum |
This represents that the default of the option is the specified enum.
|
| Default.Float |
This represents that the default of the option is the specified float primitive value.
|
| Default.InstanceFactory |
|
| Default.Integer |
This represents that the default of the option is the specified int primitive value.
|
| Default.Long |
This represents that the default of the option is the specified long primitive value.
|
| Default.Short |
This represents that the default of the option is the specified short primitive value.
|
| Default.String |
This represents that the default of the option is the specified String value.
|
| DefaultArtifactResolver |
A default artifact resolver.
|
| DefaultCoder |
The DefaultCoder annotation specifies a Coder class to handle encoding and
decoding instances of the annotated class.
|
| DefaultCoder.DefaultCoderProviderRegistrar |
|
| DefaultCoder.DefaultCoderProviderRegistrar.DefaultCoderProvider |
|
| DefaultExpansionServiceClientFactory |
Default factory for ExpansionServiceClient used by External transform.
|
| DefaultFilenamePolicy |
|
| DefaultFilenamePolicy.Params |
|
| DefaultFilenamePolicy.ParamsCoder |
|
| DefaultPipelineOptionsRegistrar |
|
| DefaultSchema |
|
| DefaultSchema.DefaultSchemaProvider |
|
| DefaultSchema.DefaultSchemaProviderRegistrar |
Registrar for default schemas.
|
| DefaultTrigger |
A trigger that is equivalent to Repeatedly.forever(AfterWatermark.pastEndOfWindow()).
|
| DefaultValueFactory<T> |
|
| DelegateCoder<T,IntermediateT> |
A DelegateCoder<T, IntermediateT> wraps a Coder for IntermediateT and
encodes/decodes values of type T by converting to/from IntermediateT and then
encoding/decoding using the underlying Coder<IntermediateT>.
|
| DelegateCoder.CodingFunction<InputT,OutputT> |
|
| DelegatingCounter |
Implementation of Counter that delegates to the instance for the current context.
|
| DelegatingDistribution |
Implementation of Distribution that delegates to the instance for the current context.
|
| DelegatingGauge |
Implementation of Gauge that delegates to the instance for the current context.
|
| DelegatingHistogram |
Implementation of Histogram that delegates to the instance for the current context.
|
| DequeCoder<T extends @NonNull java.lang.Object> |
|
| Description |
Descriptions are used to generate human readable output when the --help command is
specified.
|
| DirectStreamObserver<T> |
A StreamObserver which uses synchronization on the underlying CallStreamObserver
to provide thread safety.
|
| DisplayData |
Static display data associated with a pipeline component.
|
| DisplayData.Builder |
Utility to build up display data from a component and its included subcomponents.
|
| DisplayData.Identifier |
Unique identifier for a display data item within a component.
|
| DisplayData.Item |
Items are the unit of display data.
|
| DisplayData.ItemSpec<T> |
|
| DisplayData.Path |
Structured path of registered display data within a component hierarchy.
|
| DisplayData.Type |
Display data type.
|
| DisplayDataTranslation |
Utilities for going to/from DisplayData protos.
|
| Distinct<T> |
Distinct<T> takes a PCollection<T> and returns a PCollection<T> that has
all distinct elements of the input.
|
| Distinct.WithRepresentativeValues<T,IdT> |
|
| Distribution |
A metric that reports information about the distribution of reported values.
|
| DistributionResult |
|
| DoFn<InputT extends @Nullable java.lang.Object,OutputT extends @Nullable java.lang.Object> |
The argument to ParDo providing the code to use to process elements of the input PCollection.
|
| DoFn.AlwaysFetched |
Annotation for declaring that a state parameter is always fetched.
|
| DoFn.BoundedPerElement |
|
| DoFn.BundleFinalizer |
A parameter that is accessible during @StartBundle, @ProcessElement and @FinishBundle that allows the caller
to register a callback that will be invoked after the bundle has been successfully completed
and the runner has commit the output.
|
| DoFn.BundleFinalizer.Callback |
An instance of a function that will be invoked after bundle finalization.
|
| DoFn.Element |
|
| DoFn.FieldAccess |
Annotation for specifying specific fields that are accessed in a Schema PCollection.
|
| DoFn.FinishBundle |
Annotation for the method to use to finish processing a batch of elements.
|
| DoFn.GetInitialRestriction |
Annotation for the method that maps an element to an initial restriction for a splittable DoFn.
|
| DoFn.GetInitialWatermarkEstimatorState |
Annotation for the method that maps an element and restriction to initial watermark estimator
state for a splittable DoFn.
|
| DoFn.GetRestrictionCoder |
Annotation for the method that returns the coder to use for the restriction of a splittable DoFn.
|
| DoFn.GetSize |
Annotation for the method that returns the corresponding size for an element and restriction
pair.
|
| DoFn.GetWatermarkEstimatorStateCoder |
Annotation for the method that returns the coder to use for the watermark estimator state of a
splittable DoFn.
|
| DoFn.Key |
Parameter annotation for dereferencing input element key in KV pair.
|
| DoFn.MultiOutputReceiver |
Receives tagged output for a multi-output function.
|
| DoFn.NewTracker |
|
| DoFn.NewWatermarkEstimator |
|
| DoFn.OnTimer |
Annotation for registering a callback for a timer.
|
| DoFn.OnTimerFamily |
Annotation for registering a callback for a timerFamily.
|
| DoFn.OnWindowExpiration |
Annotation for the method to use for performing actions on window expiration.
|
| DoFn.OutputReceiver<T> |
Receives values of the given type.
|
| DoFn.ProcessContinuation |
When used as a return value of DoFn.ProcessElement, indicates whether there is more work to
be done for the current element.
|
| DoFn.ProcessElement |
Annotation for the method to use for processing elements.
|
| DoFn.RequiresStableInput |
|
| DoFn.RequiresTimeSortedInput |
Annotation that may be added to a DoFn.ProcessElement method to indicate that the runner
must ensure that the observable contents of the input PCollection is sorted by time, in
ascending order.
|
| DoFn.Restriction |
|
| DoFn.Setup |
Annotation for the method to use to prepare an instance for processing bundles of elements.
|
| DoFn.SideInput |
|
| DoFn.SplitRestriction |
Annotation for the method that splits restriction of a splittable DoFn into multiple parts to
be processed in parallel.
|
| DoFn.StartBundle |
Annotation for the method to use to prepare an instance for processing a batch of elements.
|
| DoFn.StateId |
Annotation for declaring and dereferencing state cells.
|
| DoFn.Teardown |
Annotation for the method to use to clean up this instance before it is discarded.
|
| DoFn.TimerFamily |
|
| DoFn.TimerId |
Annotation for declaring and dereferencing timers.
|
| DoFn.Timestamp |
|
| DoFn.TruncateRestriction |
Annotation for the method that truncates the restriction of a splittable DoFn into a bounded one.
|
| DoFn.UnboundedPerElement |
|
| DoFn.WatermarkEstimatorState |
|
| DoFnInfo<InputT,OutputT> |
Wrapper class holding the necessary information to serialize a DoFn.
|
| DoFnInvoker<InputT,OutputT> |
Interface for invoking the DoFn processing methods.
|
| DoFnInvoker.ArgumentProvider<InputT,OutputT> |
Interface for runner implementors to provide implementations of extra context information.
|
| DoFnInvoker.BaseArgumentProvider<InputT,OutputT> |
|
| DoFnInvoker.DelegatingArgumentProvider<InputT,OutputT> |
|
| DoFnInvoker.FakeArgumentProvider<InputT,OutputT> |
|
| DoFnInvokers |
|
| DoFnOutputReceivers |
|
| DoFnSchemaInformation |
Represents information about how a DoFn extracts schemas.
|
| DoFnSchemaInformation.Builder |
The builder object.
|
| DoFnSignature |
Describes the signature of a DoFn, in particular, which features it uses, which extra
context it requires, types of the input and output elements, etc.
|
| DoFnSignature.BundleMethod |
|
| DoFnSignature.DoFnMethod |
A method delegated to an annotated method of an underlying DoFn.
|
| DoFnSignature.FieldAccessDeclaration |
Decscribes a field access declaration.
|
| DoFnSignature.GetInitialRestrictionMethod |
|
| DoFnSignature.GetInitialWatermarkEstimatorStateMethod |
|
| DoFnSignature.GetRestrictionCoderMethod |
|
| DoFnSignature.GetSizeMethod |
|
| DoFnSignature.GetWatermarkEstimatorStateCoderMethod |
|
| DoFnSignature.LifecycleMethod |
|
| DoFnSignature.MethodWithExtraParameters |
A method delegated to an annotated method of an underlying DoFn that accepts a dynamic
list of parameters.
|
| DoFnSignature.NewTrackerMethod |
|
| DoFnSignature.NewWatermarkEstimatorMethod |
|
| DoFnSignature.OnTimerFamilyMethod |
|
| DoFnSignature.OnTimerMethod |
|
| DoFnSignature.OnWindowExpirationMethod |
|
| DoFnSignature.Parameter |
|
| DoFnSignature.Parameter.BundleFinalizerParameter |
|
| DoFnSignature.Parameter.Cases<ResultT> |
|
| DoFnSignature.Parameter.Cases.WithDefault<ResultT> |
A base class for a visitor with a default method for cases it is not interested in.
|
| DoFnSignature.Parameter.ElementParameter |
|
| DoFnSignature.Parameter.FinishBundleContextParameter |
|
| DoFnSignature.Parameter.KeyParameter |
|
| DoFnSignature.Parameter.OnTimerContextParameter |
|
| DoFnSignature.Parameter.OnWindowExpirationContextParameter |
|
| DoFnSignature.Parameter.OutputReceiverParameter |
|
| DoFnSignature.Parameter.PaneInfoParameter |
|
| DoFnSignature.Parameter.PipelineOptionsParameter |
|
| DoFnSignature.Parameter.ProcessContextParameter |
|
| DoFnSignature.Parameter.RestrictionParameter |
|
| DoFnSignature.Parameter.RestrictionTrackerParameter |
|
| DoFnSignature.Parameter.SchemaElementParameter |
Descriptor for a (@link Parameter} of type DoFn.Element where the type does not match
the DoFn's input type.
|
| DoFnSignature.Parameter.SchemaElementParameter.Builder |
Builder class.
|
| DoFnSignature.Parameter.SideInputParameter |
|
| DoFnSignature.Parameter.SideInputParameter.Builder |
Builder class.
|
| DoFnSignature.Parameter.StartBundleContextParameter |
|
| DoFnSignature.Parameter.StateParameter |
|
| DoFnSignature.Parameter.TaggedOutputReceiverParameter |
|
| DoFnSignature.Parameter.TimeDomainParameter |
|
| DoFnSignature.Parameter.TimerFamilyParameter |
|
| DoFnSignature.Parameter.TimerIdParameter |
|
| DoFnSignature.Parameter.TimerParameter |
|
| DoFnSignature.Parameter.TimestampParameter |
|
| DoFnSignature.Parameter.WatermarkEstimatorParameter |
|
| DoFnSignature.Parameter.WatermarkEstimatorStateParameter |
|
| DoFnSignature.Parameter.WindowParameter |
|
| DoFnSignature.ProcessElementMethod |
|
| DoFnSignature.SplitRestrictionMethod |
|
| DoFnSignature.StateDeclaration |
|
| DoFnSignature.TimerDeclaration |
|
| DoFnSignature.TimerFamilyDeclaration |
|
| DoFnSignature.TruncateRestrictionMethod |
|
| DoFnSignatures |
|
| DoFnTester<InputT,OutputT> |
Deprecated.
|
| DoFnTester.CloningBehavior |
Deprecated.
|
| DoFnWithExecutionInformation |
The data that the Java SDK harness needs to execute a DoFn.
|
| DoubleCoder |
A DoubleCoder encodes Double values in 8 bytes using Java serialization.
|
| DropFields |
A transform to drop fields from a schema.
|
| DropFields.Inner<T> |
Implementation class for DropFields.
|
| DurationCoder |
|
| DynamicFileDestinations |
|
| ElementByteSizeObservableIterable<V,InputT extends ElementByteSizeObservableIterator<V>> |
An abstract class used for iterables that notify observers about size in bytes of their elements,
as they are being iterated over.
|
| ElementByteSizeObservableIterator<V> |
An abstract class used for iterators that notify observers about size in bytes of their elements,
as they are being iterated over.
|
| ElementByteSizeObserver |
An observer that gets notified when additional bytes are read and/or used.
|
| EmptyFlattenAsCreateFactory<T> |
|
| EmptyMatchTreatment |
|
| EmptyOnDeserializationThreadLocal<T> |
A Serializable ThreadLocal which discards any "stored" objects.
|
| EncodableThrowable |
A wrapper around a Throwable for use with coders.
|
| EncodedBoundedWindow |
An encoded BoundedWindow used within Runners to track window information without needing
to decode the window.
|
| EncodedBoundedWindow.Coder |
|
| EnumerationType |
|
| EnumerationType.Value |
This class represents a single enum value.
|
| Environments |
Utilities for interacting with portability environments.
|
| Environments.JavaVersion |
|
| ErrorHandler<ErrorT,OutputT extends POutput> |
An Error Handler is a utility object used for plumbing error PCollections to a configured sink
Error Handlers must be closed before a pipeline is run to properly pipe error collections to the
sink, and the pipeline will be rejected if any handlers aren't closed.
|
| ErrorHandler.BadRecordErrorHandler<OutputT extends POutput> |
|
| ErrorHandler.DefaultErrorHandler<ErrorT,OutputT extends POutput> |
A default, placeholder error handler that exists to allow usage of .addErrorCollection()
without effects.
|
| ErrorHandler.PTransformErrorHandler<ErrorT,OutputT extends POutput> |
|
| ErrorHandler.PTransformErrorHandler.WriteErrorMetrics<ErrorT> |
|
| ErrorHandler.PTransformErrorHandler.WriteErrorMetrics.CountErrors<ErrorT> |
|
| ErrorHandling |
|
| ErrorHandling.Builder |
|
| ExecutableStage |
A combination of PTransforms that can be executed within a single SDK harness.
|
| ExecutableStageTranslation |
Utilities for converting ExecutableStages to and from RunnerApi protocol buffers.
|
| ExecutorOptions |
Options for configuring the ScheduledExecutorService used throughout the Java runtime.
|
| ExecutorOptions.ScheduledExecutorServiceFactory |
Returns the default ScheduledExecutorService to use within the Apache Beam SDK.
|
| ExpansionServiceClient |
A high-level client for a cross-language expansion service.
|
| ExpansionServiceClientFactory |
|
| ExperimentalOptions |
Apache Beam provides a number of experimental features that can be enabled with this flag.
|
| ExplicitShardedFile |
A sharded file where the file names are simply provided.
|
| ExposedByteArrayInputStream |
ByteArrayInputStream that allows accessing the entire internal buffer without copying.
|
| ExposedByteArrayOutputStream |
ByteArrayOutputStream special cased to treat writes of a single byte-array specially.
|
| External |
Cross-language external transform.
|
| External.ExpandableTransform<InputT extends PInput,OutputT extends POutput> |
Base Expandable Transform which calls ExpansionService to expand itself.
|
| External.MultiOutputExpandableTransform<InputT extends PInput> |
Expandable transform for output type of PCollectionTuple.
|
| External.SingleOutputExpandableTransform<InputT extends PInput,OutputT> |
Expandable transform for output type of PCollection.
|
| ExternalTransformBuilder<ConfigT,InputT extends PInput,OutputT extends POutput> |
An interface for building a transform from an externally provided configuration.
|
| ExternalTransformRegistrar |
|
| ExternalTranslation |
Translating External transforms to proto.
|
| ExternalTranslation.ExternalTranslator |
Translator for ExpandableTransform.
|
| ExternalTranslationOptions |
|
| ExternalTranslationOptionsRegistrar |
A registrar for ExternalTranslationOptions.
|
| Factory<T> |
A Factory interface for schema-related objects for a specific Java type.
|
| FailsafeValueInSingleWindow<T,ErrorT> |
An immutable tuple of value, timestamp, window, and pane.
|
| FailsafeValueInSingleWindow.Coder<T,ErrorT> |
|
| Failure |
A generic failure of an SQL transform.
|
| Failure.Builder |
|
| FieldAccessDescriptor |
Used inside of a DoFn to describe which fields in a schema
type need to be accessed for processing.
|
| FieldAccessDescriptor.FieldDescriptor |
Description of a single field.
|
| FieldAccessDescriptor.FieldDescriptor.Builder |
Builder class.
|
| FieldAccessDescriptor.FieldDescriptor.ListQualifier |
Qualifier for a list selector.
|
| FieldAccessDescriptor.FieldDescriptor.MapQualifier |
Qualifier for a map selector.
|
| FieldAccessDescriptor.FieldDescriptor.Qualifier |
OneOf union for a collection selector.
|
| FieldAccessDescriptor.FieldDescriptor.Qualifier.Kind |
The kind of qualifier.
|
| FieldAccessDescriptorParser |
Parser for textual field-access selector.
|
| FieldSpecifierNotationBaseListener |
This class provides an empty implementation of FieldSpecifierNotationListener,
which can be extended to create a listener which only needs to handle a subset
of the available methods.
|
| FieldSpecifierNotationBaseVisitor<T> |
This class provides an empty implementation of FieldSpecifierNotationVisitor,
which can be extended to create a visitor which only needs to handle a subset
of the available methods.
|
| FieldSpecifierNotationLexer |
|
| FieldSpecifierNotationListener |
|
| FieldSpecifierNotationParser |
|
| FieldSpecifierNotationParser.ArrayQualifierContext |
|
| FieldSpecifierNotationParser.ArrayQualifierListContext |
|
| FieldSpecifierNotationParser.DotExpressionComponentContext |
|
| FieldSpecifierNotationParser.DotExpressionContext |
|
| FieldSpecifierNotationParser.FieldSpecifierContext |
|
| FieldSpecifierNotationParser.MapQualifierContext |
|
| FieldSpecifierNotationParser.MapQualifierListContext |
|
| FieldSpecifierNotationParser.QualifiedComponentContext |
|
| FieldSpecifierNotationParser.QualifierListContext |
|
| FieldSpecifierNotationParser.QualifyComponentContext |
|
| FieldSpecifierNotationParser.SimpleIdentifierContext |
|
| FieldSpecifierNotationParser.WildcardContext |
|
| FieldSpecifierNotationVisitor<T> |
|
| FieldTypeDescriptors |
Utilities for converting between Schema field types and TypeDescriptors that
define Java objects which can represent these field types.
|
| FieldValueGetter<ObjectT extends @NonNull java.lang.Object,ValueT> |
For internal use only; no backwards-compatibility guarantees.
|
| FieldValueHaver<ObjectT> |
For internal use only; no backwards-compatibility guarantees.
|
| FieldValueSetter<ObjectT,ValueT> |
For internal use only; no backwards-compatibility guarantees.
|
| FieldValueTypeInformation |
Represents type information for a Java type that will be used to infer a Schema type.
|
| FieldValueTypeInformation.Builder |
|
| FieldValueTypeSupplier |
A naming policy for schema fields.
|
| FileBasedSink<UserT,DestinationT,OutputT> |
Abstract class for file-based output.
|
| FileBasedSink.CompressionType |
Deprecated.
|
| FileBasedSink.DynamicDestinations<UserT,DestinationT,OutputT> |
|
| FileBasedSink.FilenamePolicy |
A naming policy for output files.
|
| FileBasedSink.FileResult<DestinationT> |
Result of a single bundle write.
|
| FileBasedSink.FileResultCoder<DestinationT> |
|
| FileBasedSink.OutputFileHints |
Provides hints about how to generate output files, such as a suggested filename suffix (e.g.
|
| FileBasedSink.WritableByteChannelFactory |
|
| FileBasedSink.WriteOperation<DestinationT,OutputT> |
Abstract operation that manages the process of writing to FileBasedSink.
|
| FileBasedSink.Writer<DestinationT,OutputT> |
|
| FileBasedSource<T> |
A common base class for all file-based Sources.
|
| FileBasedSource.FileBasedReader<T> |
A reader that implements code common to readers of
FileBasedSources.
|
| FileBasedSource.Mode |
A given FileBasedSource represents a file resource of one of these types.
|
| FileChecksumMatcher |
Matcher to verify checksum of the contents of an ShardedFile in E2E test.
|
| FileIO |
General-purpose transforms for working with files: listing files (matching), reading and writing.
|
| FileIO.Match |
|
| FileIO.MatchAll |
|
| FileIO.MatchConfiguration |
Describes configuration for matching filepatterns, such as EmptyMatchTreatment and
continuous watching for matching files.
|
| FileIO.ReadableFile |
A utility class for accessing a potentially compressed file.
|
| FileIO.ReadMatches |
|
| FileIO.ReadMatches.DirectoryTreatment |
Enum to control how directories are handled.
|
| FileIO.Sink<ElementT> |
|
| FileIO.Write<DestinationT,UserT> |
|
| FileIO.Write.FileNaming |
A policy for generating names for shard files.
|
| FilePatternMatchingShardedFile |
A sharded file which matches a given file pattern.
|
| FileStagingOptions |
File staging related options.
|
| FileSystem<ResourceIdT extends ResourceId> |
File system interface in Beam.
|
| FileSystem.LineageLevel |
|
| FileSystemRegistrar |
|
| FileSystems |
|
| FileSystemUtils |
|
| Filter |
A PTransform for filtering a collection of schema types.
|
| Filter<T> |
PTransforms for filtering from a PCollection the elements satisfying a predicate,
or satisfying an inequality with a given value based on the elements' natural ordering.
|
| Filter.Inner<T> |
Implementation of the filter.
|
| FixedBytes |
A LogicalType representing a fixed-length byte array.
|
| FixedPrecisionNumeric |
Fixed precision numeric types used to represent jdbc NUMERIC and DECIMAL types.
|
| FixedString |
A LogicalType representing a fixed-length string.
|
| FixedWindows |
A WindowFn that windows values into fixed-size timestamp-based windows.
|
| FlatMapElements<InputT,OutputT> |
PTransforms for mapping a simple function that returns iterables over the elements of a
PCollection and merging the results.
|
| FlatMapElements.FlatMapWithFailures<InputT,OutputT,FailureT> |
|
| Flatten |
Flatten<T> takes multiple PCollection<T>s bundled into a
PCollectionList<T> and returns a single PCollection<T> containing all the elements in
all the input PCollections.
|
| Flatten.Iterables<T> |
FlattenIterables<T> takes a PCollection<Iterable<T>> and returns a
PCollection<T> that contains all the elements from each iterable.
|
| Flatten.PCollections<T> |
|
| FlattenTransformProvider |
|
| FlattenTransformProvider.Configuration |
|
| FlattenTransformProvider.Configuration.Builder |
|
| FlattenTranslator |
Utility methods for translating a Window.Assign to and from RunnerApi representations.
|
| FlattenTranslator.Registrar |
|
| FlattenWithHeterogeneousCoders |
|
| FloatCoder |
A FloatCoder encodes Float values in 4 bytes using Java serialization.
|
| FluentBackoff |
A fluent builder for BackOff objects that allows customization of the retry algorithm.
|
| FnDataReceiver<T> |
A receiver of streamed data.
|
| FnService |
An interface sharing common behavior with services used during execution of user Fns.
|
| ForwardingClientResponseObserver<ReqT,RespT> |
A ClientResponseObserver which delegates all StreamObserver calls.
|
| ForwardingPTransform<InputT extends PInput,OutputT extends POutput> |
A base class for implementing PTransform overrides, which behave identically to the
delegate transform but with overridden methods.
|
| FusedPipeline |
A RunnerApi.Pipeline which has been separated into collections of executable components.
|
| Gauge |
A metric that reports the latest value out of reported values.
|
| GaugeResult |
The result of a Gauge metric.
|
| GaugeResult.EmptyGaugeResult |
|
| GcpSecret |
A Secret manager implementation that retrieves secrets from Google Cloud Secret Manager.
|
| GenerateSequence |
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.External |
Exposes GenerateSequence as an external transform for cross-language usage.
|
| GenerateSequence.External.ExternalConfiguration |
Parameters class to expose the transform to an external SDK.
|
| GenerateSequenceSchemaTransformProvider |
|
| GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration |
|
| GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Builder |
|
| GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate |
|
| GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration.Rate.Builder |
|
| GenerateSequenceSchemaTransformProvider.GenerateSequenceSchemaTransform |
|
| GenericDlq |
Helper to generate a DLQ transform to write PCollection to an external system.
|
| GenericDlqProvider |
A Provider for generic DLQ transforms that handle deserialization failures.
|
| GetterBasedSchemaProvider |
Deprecated.
|
| GetterBasedSchemaProviderV2 |
|
| GlobalWindow |
The default window into which all data is placed (via GlobalWindows).
|
| GlobalWindow.Coder |
|
| GlobalWindows |
A WindowFn that assigns all data to the same window.
|
| GreedyPipelineFuser |
Fuses a RunnerApi.Pipeline into some set of single-environment executable transforms.
|
| GreedyStageFuser |
|
| Group |
|
| Group.AggregateCombiner<InputT> |
a PTransform that does a combine using an aggregation built up by calls to
aggregateField and aggregateFields.
|
| Group.ByFields<InputT> |
a PTransform that groups schema elements based on the given fields.
|
| Group.CombineFieldsByFields<InputT> |
a PTransform that does a per-key combine using an aggregation built up by calls to
aggregateField and aggregateFields.
|
| Group.CombineFieldsByFields.Fanout |
|
| Group.CombineFieldsByFields.Fanout.Kind |
|
| Group.CombineFieldsGlobally<InputT> |
a PTransform that does a global combine using an aggregation built up by calls to
aggregateField and aggregateFields.
|
| Group.CombineGlobally<InputT,OutputT> |
|
| Group.Global<InputT> |
A PTransform for doing global aggregations on schema PCollections.
|
| GroupByEncryptedKey<K,V> |
|
| GroupByKey<K,V> |
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.
|
| GroupByKeyTranslation |
Utility methods for translating a GroupByKey to and from RunnerApi
representations.
|
| GroupByKeyTranslation.Registrar |
Registers GroupByKeyTranslation.GroupByKeyTranslator.
|
| GroupingState<InputT,OutputT> |
A ReadableState cell that combines multiple input values and outputs a single value of a
different type.
|
| GroupIntoBatches<K,InputT> |
A PTransform that batches inputs to a desired batch size.
|
| GroupIntoBatches.BatchingParams<InputT> |
Wrapper class for batching parameters supplied by users.
|
| GroupIntoBatchesTranslation |
|
| GroupIntoBatchesTranslation.Registrar |
Registers GroupIntoBatchesTranslation.GroupIntoBatchesTranslator and GroupIntoBatchesTranslation.ShardedGroupIntoBatchesTranslator.
|
| GrowableOffsetRangeTracker |
|
| GrowableOffsetRangeTracker.RangeEndEstimator |
Provides the estimated end offset of the range.
|
| GrpcContextHeaderAccessorProvider |
A HeaderAccessorProvider which intercept the header in a GRPC request and expose the relevant
fields.
|
| GrpcFnServer<ServiceT extends FnService> |
A gRPC Server which manages a single FnService.
|
| HasDefaultTracker<RestrictionT extends HasDefaultTracker<RestrictionT,TrackerT>,TrackerT extends RestrictionTracker<RestrictionT,?>> |
Interface for restrictions for which a default implementation of DoFn.NewTracker is available, depending only on the restriction
itself.
|
| HasDefaultWatermarkEstimator<WatermarkEstimatorStateT,WatermarkEstimatorT extends WatermarkEstimator<WatermarkEstimatorStateT>> |
Interface for watermark estimator state for which a default implementation of DoFn.NewWatermarkEstimator is available, depending only on the watermark estimator state itself.
|
| HasDisplayData |
Marker interface for PTransforms and components to specify display data used
within UIs and diagnostic tools.
|
| HeaderAccessor |
Interface to access headers in the client request.
|
| Hidden |
Methods and/or interfaces annotated with @Hidden will be suppressed from being output
when --help is specified on the command-line.
|
| Histogram |
A metric that reports information about the histogram of reported values.
|
| HistogramData |
A histogram that supports estimated percentile with linear interpolation.
|
| HistogramData.BucketType |
|
| HistogramData.ExponentialBuckets |
|
| HistogramData.HistogramParsingException |
|
| HistogramData.LinearBuckets |
|
| HistogramData.UnsupportedBuckets |
Used for testing unsupported Bucket formats.
|
| Holder<T> |
A trivial boxing of a value, used when nullability needs to be added to a generic type.
|
| IdentityWindowFn<T> |
A WindowFn that leaves all associations between elements and windows unchanged.
|
| IdGenerator |
A generator of unique IDs.
|
| IdGenerators |
|
| IllegalMutationException |
Thrown when a value appears to have been mutated, but that mutation is forbidden.
|
| ImmutableExecutableStage |
|
| Impulse |
For internal use only; no backwards-compatibility guarantees.
|
| ImpulseTranslation |
Utility methods for translating a Impulse to and from RunnerApi representations.
|
| ImpulseTranslation.Registrar |
Registers ImpulseTranslation.ImpulseTranslator.
|
| IncompatibleWindowException |
|
| InferableFunction<InputT,OutputT> |
|
| InProcessServerFactory |
A ServerFactory which creates servers with the InProcessServerBuilder.
|
| InstanceBuilder<T> |
Utility for creating objects dynamically.
|
| InstantCoder |
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.
|
| Internal |
Signifies that a publicly accessible API (public class, method or field) is intended for internal
use only and not for public consumption.
|
| IntervalWindow |
An implementation of BoundedWindow that represents an interval from IntervalWindow.start
(inclusive) to IntervalWindow.end (exclusive).
|
| IntervalWindow.IntervalWindowCoder |
|
| InvalidConfigurationException |
Exception thrown when the configuration for a SchemaIO is invalid.
|
| InvalidLocationException |
Exception thrown when the configuration for a SchemaIO is invalid.
|
| InvalidSchemaException |
Exception thrown when the schema for a SchemaIO is invalid.
|
| IterableCoder<T> |
|
| IterableLikeCoder<T,IterableT extends java.lang.Iterable<T>> |
An abstract base class with functionality for assembling a Coder for a class that
implements Iterable.
|
| JavaBeanSchema |
|
| JavaBeanSchema.GetterTypeSupplier |
|
| JavaBeanSchema.SetterTypeSupplier |
|
| JavaBeanUtils |
A set of utilities to generate getter and setter classes for JavaBean objects.
|
| JavaExplodeTransformProvider |
|
| JavaExplodeTransformProvider.Configuration |
|
| JavaExplodeTransformProvider.Configuration.Builder |
|
| JavaExplodeTransformProvider.ExplodeTransform |
|
| JavaFieldSchema |
|
| JavaFieldSchema.JavaFieldTypeSupplier |
|
| JavaFilterTransformProvider |
|
| JavaFilterTransformProvider.Configuration |
|
| JavaFilterTransformProvider.Configuration.Builder |
|
| JavaFilterTransformProvider.JavaFilterTransform |
|
| JavaMapToFieldsTransformProvider |
|
| JavaMapToFieldsTransformProvider.Configuration |
|
| JavaMapToFieldsTransformProvider.Configuration.Builder |
|
| JavaMapToFieldsTransformProvider.JavaMapToFieldsTransform |
|
| JavaRowUdf |
|
| JavaRowUdf.Configuration |
|
| JavaRowUdf.Configuration.Builder |
|
| Join |
A transform that performs equijoins across two schema PCollections.
|
| Join.FieldsEqual |
Predicate object to specify fields to compare when doing an equi-join.
|
| Join.FieldsEqual.Impl |
Implementation class for FieldsEqual.
|
| Join.Impl<LhsT,RhsT> |
Implementation class .
|
| JsonMatcher<T> |
Matcher to compare a string or byte[] representing a JSON Object, independent of field order.
|
| JsonPayloadSerializerProvider |
|
| JsonToRow |
|
| JsonToRow.JsonToRowWithErrFn |
|
| JsonToRow.JsonToRowWithErrFn.Builder |
|
| JsonToRow.JsonToRowWithErrFn.ParseWithError |
|
| JsonToRow.JsonToRowWithErrFn.ParseWithError.Builder |
|
| JsonToRow.ParseResult |
|
| JsonToRow.ParseResult.Builder |
|
| JsonUtils |
Utils to convert JSON records to Beam Row.
|
| JvmInitializer |
A service interface for defining one-time initialization of the JVM during pipeline execution.
|
| JvmInitializers |
|
| KeyedPCollectionTuple<K> |
|
| KeyedPCollectionTuple.TaggedKeyedPCollection<K,V> |
A utility class to help ensure coherence of tag and input PCollection types.
|
| Keys<K> |
Keys<K> takes a PCollection of KV<K, V>s and returns a
PCollection<K> of the keys.
|
| KV<K,V> |
An immutable key/value pair.
|
| KV.OrderByKey<K extends java.lang.Comparable<? super K>,V> |
A Comparator that orders KVs by the natural ordering of their keys.
|
| KV.OrderByValue<K,V extends java.lang.Comparable<? super V>> |
A Comparator that orders KVs by the natural ordering of their values.
|
| KvCoder<K extends @Nullable java.lang.Object,V extends @Nullable java.lang.Object> |
|
| KvSwap<K,V> |
KvSwap<K, V> takes a PCollection<KV<K, V>> and returns a PCollection<KV<V,
K>>, where all the keys and values have been swapped.
|
| LabeledMetricNameUtils |
Util class for building/parsing labeled MetricName.
|
| LabeledMetricNameUtils.MetricNameBuilder |
Builder class for a labeled MetricName.
|
| LabeledMetricNameUtils.ParsedMetricName |
|
| LargeKeys |
Category tags for tests which validate that a Beam runner can handle keys up to a given size.
|
| LargeKeys.Above100KB |
Tests if a runner supports 100KB keys.
|
| LargeKeys.Above100MB |
Tests if a runner supports 100MB keys.
|
| LargeKeys.Above10KB |
Tests if a runner supports 10KB keys.
|
| LargeKeys.Above10MB |
Tests if a runner supports 10MB keys.
|
| LargeKeys.Above1MB |
Tests if a runner supports 1MB keys.
|
| Latest |
|
| LengthPrefixCoder<T> |
A Coder which is able to take any existing coder and wrap it such that it is only invoked
in the outer context.
|
| Lineage |
Standard collection of metrics used to record source and sinks information for lineage tracking.
|
| Lineage.Type |
Lineage metrics resource types.
|
| ListCoder<T> |
|
| LocalFileSystemRegistrar |
AutoService registrar for the LocalFileSystem.
|
| LocalResources |
Helper functions for producing a ResourceId that references a local file or directory.
|
| LoggingTransformProvider |
|
| LoggingTransformProvider.Configuration |
|
| LoggingTransformProvider.Configuration.Builder |
|
| LoggingTransformProvider.LoggingTransform |
|
| LogicalEndpoint |
A logical endpoint is a pair of an instruction ID corresponding to the BeamFnApi.ProcessBundleRequest and the transform within the processing graph.
|
| LzoCompression |
|
| ManagedChannelFactory |
A Factory which creates ManagedChannel instances.
|
| ManualDockerEnvironmentOptions |
Pipeline options to tune DockerEnvironment.
|
| ManualDockerEnvironmentOptions.Options |
|
| ManualWatermarkEstimator<WatermarkEstimatorStateT> |
|
| MapCoder<K,V> |
A Coder for Maps that encodes them according to provided coders for keys and
values.
|
| MapElements<InputT,OutputT> |
PTransforms for mapping a simple function over the elements of a PCollection.
|
| MapElements.MapWithFailures<InputT,OutputT,FailureT> |
A PTransform that adds exception handling to MapElements.
|
| MapKeys<K1,K2,V> |
MapKeys maps a SerializableFunction<K1,K2> over keys of a
PCollection<KV<K1,V>> and returns a PCollection<KV<K2, V>>.
|
| MapState<K,V> |
|
| MapValues<K,V1,V2> |
MapValues maps a SerializableFunction<V1,V2> over values of a
PCollection<KV<K,V1>> and returns a PCollection<KV<K, V2>>.
|
| MatchResult |
|
| MatchResult.Metadata |
|
| MatchResult.Metadata.Builder |
|
| MatchResult.Status |
|
| Materialization<T> |
For internal use only; no backwards-compatibility guarantees.
|
| Materializations |
For internal use only; no backwards-compatibility guarantees.
|
| Materializations.IterableView<V> |
|
| Materializations.MultimapView<K,V> |
|
| Max |
PTransforms for computing the maximum of the elements in a PCollection, or the
maximum of the values associated with each key in a PCollection of KVs.
|
| Mean |
PTransforms for computing the arithmetic mean (a.k.a.
|
| MemoizingPerInstantiationSerializableSupplier<T> |
A supplier that memoizes within an instantiation across serialization/deserialization.
|
| MemoryMonitorOptions |
Options that are used to control the Memory Monitor.
|
| MergeOverlappingIntervalWindows |
For internal use only; no backwards compatibility guarantees.
|
| MetadataCoder |
|
| MetadataCoderV2 |
|
| Metric |
Marker interface for all user-facing metrics.
|
| MetricFiltering |
Implements matching for metrics filters.
|
| MetricKey |
Metrics are keyed by the step name they are associated with and the name of the metric.
|
| MetricName |
|
| MetricNameFilter |
The name of a metric.
|
| MetricQueryResults |
The results of a query for metrics.
|
| MetricResult<T> |
The results of a single current metric.
|
| MetricResults |
Methods for interacting with the metrics of a pipeline that has been executed.
|
| Metrics |
The Metrics is a utility class for producing various kinds of metrics for reporting
properties of an executing pipeline.
|
| MetricsContainer |
Holds the metrics for a single step.
|
| MetricsEnvironment |
Manages and provides the metrics container associated with each thread.
|
| MetricsEnvironment.MetricsContainerHolder |
|
| MetricsEnvironment.MetricsEnvironmentState |
|
| MetricsFilter |
Simple POJO representing a filter for querying metrics.
|
| MetricsFilter.Builder |
|
| MetricsOptions |
|
| MetricsOptions.NoOpMetricsSink |
A DefaultValueFactory that obtains the class of the NoOpMetricsSink if it
exists on the classpath, and throws an exception otherwise.
|
| MetricsSink |
Interface for all metric sinks.
|
| MicrosInstant |
A timestamp represented as microseconds since the epoch.
|
| MimeTypes |
Constants representing various mime types.
|
| Min |
PTransforms for computing the minimum of the elements in a PCollection, or the
minimum of the values associated with each key in a PCollection of KVs.
|
| ModelCoderRegistrar |
|
| ModelCoders |
Utilities and constants ot interact with coders that are part of the Beam Model.
|
| ModelCoders.KvCoderComponents |
Components of a KV RunnerApi.Coder with names.
|
| ModelCoders.WindowedValueCoderComponents |
Components of a Windowed Value RunnerApi.Coder with names.
|
| MoreFutures |
Utilities to do future programming with Java 8.
|
| MoreFutures.ExceptionOrResult<T> |
An object that represents either a result or an exceptional termination.
|
| MoreFutures.ExceptionOrResult.IsException |
Describes whether the result was an exception.
|
| MoveOptions |
|
| MoveOptions.StandardMoveOptions |
|
| MovingFunction |
Keep track of the moving minimum/maximum/sum of sampled long values.
|
| MultimapState<K,V> |
|
| MutationDetector |
An object for detecting illegal mutations.
|
| MutationDetectors |
|
| NameUtils |
Helpers for extracting the name of objects and classes.
|
| NameUtils.NameOverride |
Classes may implement this interface to change how names are generated for their instances.
|
| NanosDuration |
A duration represented in nanoseconds.
|
| NanosInstant |
A timestamp represented as nanoseconds since the epoch.
|
| NativeTransforms |
An extension point for users to define their own native transforms for usage with specific
runners.
|
| NativeTransforms.IsNativeTransform |
A predicate which returns true if and only if the transform is a native transform.
|
| NeedsRunner |
|
| Networks |
Static utility methods for Network instances that are directed.
|
| Networks.TypeSafeNodeFunction<NodeT,T extends NodeT> |
An abstract class that can be extended to apply a function in a type safe manner.
|
| Never |
|
| Never.NeverTrigger |
The actual trigger class for Never triggers.
|
| NonMergingWindowFn<T,W extends BoundedWindow> |
Abstract base class for WindowFns that do not merge windows.
|
| NoOpCounter |
A no-op implementation of Counter.
|
| NoOpHistogram |
A no-op implementation of Histogram.
|
| NoopLock |
A lock which can always be acquired.
|
| NoSuchSchemaException |
Indicates that we are missing a schema for a type.
|
| NullableCoder<T> |
A NullableCoder encodes nullable values of type T using a nested Coder<T>
that does not tolerate null values.
|
| NumberedShardedFile |
Utility methods for working with sharded files.
|
| OffsetBasedSource<T> |
A BoundedSource that uses offsets to define starting and ending positions.
|
| OffsetBasedSource.OffsetBasedReader<T> |
|
| OffsetRange |
A restriction represented by a range of integers [from, to).
|
| OffsetRange.Coder |
|
| OffsetRangeTracker |
|
| OffsetRangeTracker |
|
| OneOfType |
A logical type representing a union of fields.
|
| OneOfType.Value |
Represents a single OneOf value.
|
| OnTimerInvoker<InputT,OutputT> |
Interface for invoking the DoFn.OnTimer method for a particular timer.
|
| OptionalCoder<T> |
A OptionalCoder encodes optional values of type T using a nested
Coder<T>.
|
| OrderedListState<T> |
A ReadableState cell containing a list of values sorted by timestamp.
|
| OrFinallyTrigger |
A Trigger that executes according to its main trigger until its "finally" trigger fires.
|
| OutboundObserverFactory |
Creates factories which determine an underlying StreamObserver implementation to use in
to interact with fn execution APIs.
|
| OutboundObserverFactory.BasicFactory<ReqT,RespT> |
Creates an outbound observer for the given inbound observer.
|
| OutputBuilder<T> |
A builder for an output, to set all the fields and extended metadata of a Beam value.
|
| OutputBuilderSupplier |
|
| OutputBuilderSuppliers |
|
| PaneInfo |
Provides information about the pane an element belongs to.
|
| PaneInfo.PaneInfoCoder |
A Coder for encoding PaneInfo instances.
|
| PaneInfo.Timing |
Enumerates the possibilities for the timing of this pane firing related to the input and output
watermarks for its computation.
|
| ParDo |
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.MultiOutput<InputT,OutputT> |
A PTransform that, when applied to a PCollection<InputT>, invokes a
user-specified DoFn<InputT, OutputT> on all its elements, which can emit elements to
any of the PTransform's output PCollections, which are bundled into a result
PCollectionTuple.
|
| ParDo.SingleOutput<InputT,OutputT> |
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>.
|
| ParDoTranslation |
Utilities for interacting with ParDo instances and RunnerApi.ParDoPayload protos.
|
| ParDoTranslation.ParDoLike |
These methods drive to-proto translation from Java and from rehydrated ParDos.
|
| ParDoTranslation.ParDoLikeTimerFamilySpecs |
|
| ParDoTranslation.ParDoTranslator |
|
| Partition<T> |
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> |
A function object that chooses an output partition for an element.
|
| Partition.PartitionWithSideInputsFn<T> |
A function object that chooses an output partition for an element.
|
| PartitioningWindowFn<T,W extends BoundedWindow> |
A WindowFn that places each value into exactly one window based on its timestamp and
never merges windows.
|
| PAssert |
An assertion on the contents of a PCollection incorporated into the pipeline.
|
| PAssert.DefaultConcludeTransform |
Default transform to check that a PAssert was successful.
|
| PAssert.GroupThenAssert<T> |
A transform that applies an assertion-checking function over iterables of ActualT to
the entirety of the contents of its input.
|
| PAssert.GroupThenAssertForSingleton<T> |
A transform that applies an assertion-checking function to the sole element of a PCollection.
|
| PAssert.IterableAssert<T> |
Builder interface for assertions applicable to iterables and PCollection contents.
|
| PAssert.MatcherCheckerFn<T> |
Check that the passed-in matchers match the existing data.
|
| PAssert.OneSideInputAssert<ActualT> |
An assertion checker that takes a single PCollectionView<ActualT>
and an assertion over ActualT, and checks it within a Beam pipeline.
|
| PAssert.PAssertionSite |
Track the place where an assertion is defined.
|
| PAssert.PCollectionContentsAssert<T> |
|
| PAssert.PCollectionListContentsAssert<T> |
|
| PAssert.SingletonAssert<T> |
Builder interface for assertions applicable to a single value.
|
| PassThroughLogicalType<T> |
A base class for LogicalTypes that use the same Java type as the underlying base type.
|
| PayloadSerializer |
|
| PayloadSerializerProvider |
|
| PayloadSerializers |
|
| PBegin |
|
| PCollection<T> |
|
| PCollection.IsBounded |
The enumeration of cases for whether a PCollection is bounded.
|
| PCollectionList<T> |
|
| PCollectionRowTuple |
|
| PCollectionTranslation |
Utility methods for translating PCollections to and from Runner API protos.
|
| PCollectionTuple |
|
| PCollectionView<T> |
|
| PCollectionViews |
For internal use only; no backwards compatibility guarantees.
|
| PCollectionViews.HasDefaultValue<T> |
|
| PCollectionViews.InMemoryListFromMultimapViewFn<T> |
Implementation which is able to adapt a multimap materialization to an in-memory
List<T>.
|
| PCollectionViews.InMemoryListViewFn<T> |
Implementation which is able to adapt an iterable materialization to an in-memory
List<T>.
|
| PCollectionViews.InMemoryMapFromVoidKeyViewFn<K,V> |
Implementation which is able to adapt a multimap materialization to an in-memory Map<K,
V>.
|
| PCollectionViews.InMemoryMapViewFn<K,V> |
Implementation which is able to adapt an iterable materialization to an in-memory Map<K,
V>.
|
| PCollectionViews.InMemoryMultimapFromVoidKeyViewFn<K,V> |
Implementation which is able to adapt a multimap materialization to an in-memory Map<K,
Iterable<V>>.
|
| PCollectionViews.InMemoryMultimapViewFn<K,V> |
Implementation which is able to adapt an iterable materialization to an in-memory Map<K,
Iterable<V>>.
|
| PCollectionViews.IsSingletonView<T> |
|
| PCollectionViews.IterableBackedListViewFn<T> |
Implementation which is able to adapt an iterable materialization to a List<T>.
|
| PCollectionViews.IterableViewFn<T> |
Deprecated.
|
| PCollectionViews.IterableViewFn2<T> |
Implementation which is able to adapt an iterable materialization to a Iterable<T>.
|
| PCollectionViews.ListViewFn<T> |
Deprecated.
|
| PCollectionViews.ListViewFn2<T> |
Implementation which is able to adapt a multimap materialization to a List<T>.
|
| PCollectionViews.MapViewFn<K,V> |
Deprecated.
|
| PCollectionViews.MapViewFn2<K,V> |
Implementation which is able to adapt a multimap materialization to a Map<K, V>.
|
| PCollectionViews.MultimapViewFn<K,V> |
Deprecated.
|
| PCollectionViews.MultimapViewFn2<K,V> |
Implementation which is able to adapt a multimap materialization to a Map<K,
Iterable<V>>.
|
| PCollectionViews.SimplePCollectionView<ElemT,PrimitiveViewT,ViewT,W extends BoundedWindow> |
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> |
Deprecated.
|
| PCollectionViews.SingletonViewFn2<T> |
Implementation which is able to adapt an iterable materialization to a T.
|
| PCollectionViews.TypeDescriptorSupplier<T> |
|
| PCollectionViews.ValueOrMetadata<T,MetaT> |
Stores values or metadata about values.
|
| PCollectionViews.ValueOrMetadataCoder<T,MetaT> |
|
| PCollectionViewTranslation |
Utilities for interacting with PCollection view protos.
|
| PDone |
|
| PeriodicImpulse |
A PTransform which produces a sequence of elements at fixed runtime intervals.
|
| PeriodicSequence |
A PTransform which generates a sequence of timestamped elements at given runtime
intervals.
|
| PeriodicSequence.OutputRangeTracker |
|
| PeriodicSequence.SequenceDefinition |
|
| PInput |
The interface for things that might be input to a PTransform.
|
| Pipeline |
|
| Pipeline.PipelineExecutionException |
Thrown during execution of a Pipeline, whenever user code within that Pipeline
throws an exception.
|
| Pipeline.PipelineVisitor |
For internal use only; no backwards-compatibility guarantees.
|
| Pipeline.PipelineVisitor.CompositeBehavior |
Control enum for indicating whether or not a traversal should process the contents of a
composite transform or not.
|
| Pipeline.PipelineVisitor.Defaults |
|
| PipelineDotRenderer |
|
| PipelineNode |
A graph node which contains some pipeline element.
|
| PipelineNode.PCollectionNode |
|
| PipelineNode.PTransformNode |
|
| PipelineOptions |
PipelineOptions are used to configure Pipelines.
|
| PipelineOptions.AtomicLongFactory |
DefaultValueFactory which supplies an ID that is guaranteed to be unique within the
given process.
|
| PipelineOptions.CheckEnabled |
Enumeration of the possible states for a given check.
|
| PipelineOptions.DirectRunner |
A DefaultValueFactory that obtains the class of the DirectRunner if it exists
on the classpath, and throws an exception otherwise.
|
| PipelineOptions.JobNameFactory |
|
| PipelineOptions.UserAgentFactory |
|
| PipelineOptionsFactory |
|
| PipelineOptionsFactory.Builder |
|
| PipelineOptionsRegistrar |
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.
|
| PipelineOptionsTranslation |
Utilities for going to/from Runner API pipeline options.
|
| PipelineOptionsValidator |
|
| PipelineResources |
Utilities for working with classpath resources for pipelines.
|
| PipelineResourcesDetector |
Interface for an algorithm detecting classpath resources for pipelines.
|
| PipelineResourcesDetector.Factory |
Provides pipeline resources detection algorithm.
|
| PipelineResourcesOptions |
Pipeline options dedicated to detecting classpath resources.
|
| PipelineResourcesOptions.ClasspathScanningResourcesDetectorFactory |
|
| PipelineResourcesOptions.PipelineResourcesDetectorFactory |
|
| PipelineResult |
|
| PipelineResult.State |
Possible job states, for both completed and ongoing jobs.
|
| PipelineRunner<ResultT extends PipelineResult> |
|
| PipelineRunnerRegistrar |
For internal use only; no backwards-compatibility guarantees.
|
| PipelineTranslation |
Utilities for going to/from Runner API pipelines.
|
| PipelineValidator |
Validates well-formedness of a pipeline.
|
| POJOUtils |
A set of utilities to generate getter and setter classes for POJOs.
|
| PortablePipelineOptions |
Pipeline options common to all portable runners.
|
| POutput |
The interface for things that might be output from a PTransform.
|
| Preconditions |
Beam-specific variants of Preconditions that throws more
appropriate exception classes while being static analysis friendly.
|
| PrefetchableIterable<T> |
|
| PrefetchableIterables |
This class contains static utility functions that operate on or return objects of type PrefetchableIterable.
|
| PrefetchableIterables.Default<T> |
|
| PrefetchableIterator<T> |
Iterator that supports prefetching the next set of records.
|
| PrefetchableIterators |
|
| PrimitiveCreate<T> |
|
| PrimitiveCreate.Factory<T> |
|
| ProcessFunction<InputT,OutputT> |
A function that computes an output value of type OutputT from an input value of type
InputT and is Serializable.
|
| ProjectionConsumer |
|
| ProjectionProducer<T> |
|
| ProjectionPushdownOptimizer |
|
| ProtoOverrides |
|
| ProtoOverrides.TransformReplacement |
A Function that takes a transform and the existing components and returns the new composite
PTransform and additional components.
|
| Providers |
Helpers for implementing the "Provider" pattern.
|
| Providers.Identifyable |
|
| PTransform<InputT extends PInput,OutputT extends POutput> |
A PTransform<InputT, OutputT> is an operation that takes an InputT (some subtype
of PInput) and produces an OutputT (some subtype of POutput).
|
| PTransformMatcher |
For internal use only; no backwards-compatibility guarantees.
|
| PTransformMatchers |
|
| PTransformOverride |
For internal use only; no backwards-compatibility guarantees.
|
| PTransformOverrideFactory<InputT extends PInput,OutputT extends POutput,TransformT extends PTransform<? super InputT,OutputT>> |
For internal use only; no backwards-compatibility guarantees.
|
| PTransformOverrideFactory.PTransformReplacement<InputT extends PInput,OutputT extends POutput> |
|
| PTransformOverrideFactory.ReplacementOutput |
A mapping between original TaggedPValue outputs and their replacements.
|
| PTransformReplacements |
|
| PTransformTranslation |
Utilities for converting PTransforms to Runner API protocol
buffers.
|
| PTransformTranslation.RawPTransform<InputT extends PInput,OutputT extends POutput> |
A PTransform that indicates its URN and payload directly.
|
| PTransformTranslation.TransformPayloadTranslator<T extends PTransform<?,?>> |
A translator between a Java-based PTransform and a protobuf payload for that transform.
|
| PTransformTranslation.TransformPayloadTranslator.NotSerializable<T extends PTransform<?,?>> |
|
| PTransformTranslation.TransformTranslator<T extends PTransform<?,?>> |
A translator between a Java-based PTransform and a protobuf for that transform.
|
| PValue |
For internal use.
|
| PValueBase |
For internal use.
|
| PValues |
For internal use.
|
| PythonCallable |
A logical type for PythonCallableSource objects.
|
| PythonCallableSource |
A wrapper object storing a Python function definition that can be evaluated to Python callables
in Python SDK.
|
| QueryablePipeline |
A RunnerApi.Pipeline which has additional methods to relate nodes in the graph relative to each
other.
|
| RangeTracker<PositionT> |
A RangeTracker is a thread-safe helper object for implementing dynamic work rebalancing
in position-based BoundedSource.BoundedReader subclasses.
|
| RawUnionValue |
This corresponds to an integer union tag and value.
|
| Read |
|
| Read.Bounded<T> |
|
| Read.Builder |
Helper class for building Read transforms.
|
| Read.Unbounded<T> |
|
| ReadableFileCoder |
|
| ReadableState<T> |
|
| ReadableStates |
For internal use only; no backwards-compatibility guarantees.
|
| ReadAllViaFileBasedSource<T> |
|
| ReadAllViaFileBasedSource.ReadFileRangesFnExceptionHandler |
A class to handle errors which occur during file reads.
|
| ReadAllViaFileBasedSourceTransform<InT,T> |
|
| ReadAllViaFileBasedSourceTransform.AbstractReadFileRangesFn<InT,T> |
|
| ReadAllViaFileBasedSourceTransform.SplitIntoRangesFn |
|
| ReadAllViaFileBasedSourceWithFilename<T> |
Reads each file of the input PCollection and outputs each element as the value of a
KV, where the key is the filename from which that value came.
|
| ReadTranslation |
|
| ReadTranslation.BoundedReadPayloadTranslator |
|
| ReadTranslation.Registrar |
|
| ReadTranslation.UnboundedReadPayloadTranslator |
|
| Redistribute |
A family of PTransforms that returns a PCollection equivalent to its
input but functions as an operational hint to a runner that redistributing the data in some way
is likely useful.
|
| Redistribute.RedistributeArbitrarily<T> |
Noop transform that hints to the runner to try to redistribute the work evenly, or via whatever
clever strategy the runner comes up with.
|
| Redistribute.RedistributeByKey<K,V> |
|
| Redistribute.Registrar |
Registers translators for the Redistribute family of transforms.
|
| ReflectHelpers |
Utilities for working with with Classes and Methods.
|
| ReflectHelpers.ObjectsClassComparator |
A Comparator that uses the object's class' canonical name to compare them.
|
| ReflectUtils |
A set of reflection helper methods.
|
| ReflectUtils.ClassWithSchema |
Represents a class and a schema.
|
| ReflectUtils.TypeDescriptorWithSchema<T> |
Represents a type descriptor and a schema.
|
| Regex |
PTransforms to use Regular Expressions to process elements in a PCollection.
|
| Regex.AllMatches |
Regex.MatchesName<String> takes a PCollection<String> and returns a
PCollection<List<String>> representing the value extracted from all the Regex groups of the
input PCollection to the number of times that element occurs in the input.
|
| Regex.Find |
Regex.Find<String> takes a PCollection<String> and returns a
PCollection<String> representing the value extracted from the Regex groups of the input
PCollection to the number of times that element occurs in the input.
|
| Regex.FindAll |
Regex.Find<String> takes a PCollection<String> and returns a
PCollection<List<String>> representing the value extracted from the Regex groups of the input
PCollection to the number of times that element occurs in the input.
|
| Regex.FindKV |
Regex.MatchesKV<KV<String, String>> takes a PCollection<String> and returns a
PCollection<KV<String, String>> representing the key and value extracted from the Regex
groups of the input PCollection to the number of times that element occurs in the
input.
|
| Regex.FindName |
Regex.Find<String> takes a PCollection<String> and returns a
PCollection<String> representing the value extracted from the Regex groups of the input
PCollection to the number of times that element occurs in the input.
|
| Regex.FindNameKV |
Regex.MatchesKV<KV<String, String>> takes a PCollection<String> and returns a
PCollection<KV<String, String>> representing the key and value extracted from the Regex
groups of the input PCollection to the number of times that element occurs in the
input.
|
| Regex.Matches |
Regex.Matches<String> takes a PCollection<String> and returns a
PCollection<String> representing the value extracted from the Regex groups of the input
PCollection to the number of times that element occurs in the input.
|
| Regex.MatchesKV |
Regex.MatchesKV<KV<String, String>> takes a PCollection<String> and returns a
PCollection<KV<String, String>> representing the key and value extracted from the Regex
groups of the input PCollection to the number of times that element occurs in the
input.
|
| Regex.MatchesName |
Regex.MatchesName<String> takes a PCollection<String> and returns a
PCollection<String> representing the value extracted from the Regex groups of the input
PCollection to the number of times that element occurs in the input.
|
| Regex.MatchesNameKV |
Regex.MatchesNameKV<KV<String, String>> takes a PCollection<String> and returns
a PCollection<KV<String, String>> representing the key and value extracted from the
Regex groups of the input PCollection to the number of times that element occurs in the
input.
|
| Regex.ReplaceAll |
Regex.ReplaceAll<String> takes a PCollection<String> and returns a
PCollection<String> with all Strings that matched the Regex being replaced with the
replacement string.
|
| Regex.ReplaceFirst |
Regex.ReplaceFirst<String> takes a PCollection<String> and returns a
PCollection<String> with the first Strings that matched the Regex being replaced with the
replacement string.
|
| Regex.Split |
Regex.Split<String> takes a PCollection<String> and returns a
PCollection<String> with the input string split into individual items in a list.
|
| RegexMatcher |
Hamcrest matcher to assert a string matches a pattern.
|
| RehydratedComponents |
Vends Java SDK objects rehydrated from a Runner API RunnerApi.Components collection.
|
| Reify |
PTransforms for converting between explicit and implicit form of various Beam
values.
|
| Reiterable<T> |
|
| Reiterator<T> |
An Iterator with the ability to copy its iteration state.
|
| ReleaseInfo |
Properties pertaining to this release of Apache Beam.
|
| RemoteEnvironmentOptions |
Options that are used to control configuration of the remote environment.
|
| RemoteEnvironmentOptions.Options |
|
| RemoteGrpcPortRead |
An execution-time only RunnerApi.PTransform which represents an SDK harness reading from a BeamFnApi.RemoteGrpcPort.
|
| RemoteGrpcPortWrite |
An execution-time only RunnerApi.PTransform which represents a write from within an SDK harness to
a BeamFnApi.RemoteGrpcPort.
|
| RenameFields |
A transform for renaming fields inside an existing schema.
|
| RenameFields.Inner<T> |
The class implementing the actual PTransform.
|
| Repeatedly |
A Trigger that fires according to its subtrigger forever.
|
| ReplacementOutputs |
|
| Requirements |
Describes the run-time requirements of a Contextful, such as access to side inputs.
|
| Reshuffle<K,V> |
For internal use only; no backwards compatibility guarantees.
|
| Reshuffle.AssignShardFn<T> |
|
| Reshuffle.ViaRandomKey<T> |
|
| ReshuffleTranslation |
Utility methods for translating a Reshuffle to and from RunnerApi
representations.
|
| ReshuffleTranslation.Registrar |
Registers ReshuffleTranslation.ReshuffleTranslator.
|
| ReshuffleTrigger<W extends BoundedWindow> |
For internal use only; no backwards compatibility guarantees.
|
| ResolveOptions |
|
| ResolveOptions.StandardResolveOptions |
Defines the standard resolve options.
|
| ResourceHint |
Provides a definition of a resource hint known to the SDK.
|
| ResourceHints |
Pipeline authors can use resource hints to provide additional information to runners about the
desired aspects of the execution environment.
|
| ResourceHintsOptions |
Options that are used to control configuration of the remote environment.
|
| ResourceHintsOptions.EmptyListDefault |
|
| ResourceHintsOptions.Options |
|
| ResourceId |
An identifier which represents a file-like resource.
|
| ResourceIdCoder |
|
| ResourceIdTester |
|
| RestrictionTracker<RestrictionT,PositionT> |
Manages access to the restriction and keeps track of its claimed part for a splittable DoFn.
|
| RestrictionTracker.HasProgress |
All RestrictionTrackers SHOULD implement this interface to improve auto-scaling and
splitting performance.
|
| RestrictionTracker.IsBounded |
|
| RestrictionTracker.Progress |
A representation for the amount of known completed and remaining work.
|
| RestrictionTracker.TruncateResult<RestrictionT> |
A representation of the truncate result.
|
| RestrictionTrackers |
|
| RestrictionTrackers.ClaimObserver<PositionT> |
|
| Row |
Row is an immutable tuple-like schema to represent one element in a PCollection.
|
| Row.Builder |
|
| Row.Equals |
|
| Row.FieldValueBuilder |
Builder for Row that bases a row on another row.
|
| RowCoder |
A sub-class of SchemaCoder that can only encode Row instances.
|
| RowCoderGenerator |
A utility for automatically generating a Coder for Row objects corresponding to a
specific schema.
|
| RowFilter |
A utility that filters fields from Beam Rows.
|
| RowJson |
Jackson serializer and deserializer for Rows.
|
| RowJson.RowJsonDeserializer |
Jackson deserializer for parsing JSON into Rows.
|
| RowJson.RowJsonDeserializer.NullBehavior |
|
| RowJson.RowJsonSerializer |
Jackson serializer for converting Rows to JSON.
|
| RowJson.UnsupportedRowJsonException |
Gets thrown when Row parsing or serialization fails for any reason.
|
| RowJsonUtils |
|
| RowMessages |
|
| RowSchemaInformationProvider |
|
| RowSelector |
A selector interface for extracting fields from a row.
|
| RowStringInterpolator |
A utility that interpolates values in a pre-determined String using an input Beam Row.
|
| RowWithGetters<T extends @NonNull java.lang.Object> |
|
| RowWithStorage |
Concrete subclass of Row that explicitly stores all fields of the row.
|
| RunnerPCollectionView<T> |
|
| Sample |
PTransforms for taking samples of the elements in a PCollection, or samples of
the values associated with each key in a PCollection of KVs.
|
| Sample.FixedSizedSampleFn<T> |
CombineFn that computes a fixed-size sample of a collection of values.
|
| Schema |
|
| Schema.Builder |
Builder class for building Schema objects.
|
| Schema.EquivalenceNullablePolicy |
Control whether nullable is included in equivalence check.
|
| Schema.Field |
Field of a row.
|
| Schema.Field.Builder |
|
| Schema.FieldType |
A descriptor of a single field type.
|
| Schema.LogicalType<InputT,BaseT> |
A LogicalType allows users to define a custom schema type.
|
| Schema.Options |
|
| Schema.Options.Builder |
|
| Schema.TypeName |
An enumerated list of type constructors.
|
| SchemaCaseFormat |
When used on a POJO, Java Bean, or AutoValue class the specified case format will be
used for all the generated Schema fields.
|
| SchemaCoder<T> |
SchemaCoder is used as the coder for types that have schemas registered.
|
| SchemaCreate |
Can be put on a constructor or a static method, in which case that constructor or method will be
used to created instance of the class by Beam's schema code.
|
| SchemaFieldDescription |
When used on a POJO field, a Java Bean getter, or an AutoValue getter, the specified description is used
for the generated schema field.
|
| SchemaFieldName |
When used on a POJO field, a Java Bean getter, or an AutoValue getter, the specified name is used for the
generated schema field.
|
| SchemaFieldNumber |
When used on a POJO field, a Java Bean getter, or an AutoValue getter, the generated field will have the
specified index.
|
| SchemaIgnore |
When used on a POJO field or a JavaBean getter, that field or getter is ignored from the inferred
schema.
|
| SchemaInformationProvider |
|
| SchemaIO |
An abstraction to create schema capable and aware IOs.
|
| SchemaIOProvider |
Provider to create SchemaIO instances for use in Beam SQL and other SDKs.
|
| SchemaLogicalType |
A schema represented as a serialized proto bytes.
|
| SchemaProvider |
Concrete implementations of this class allow creation of schema service objects that vend a
Schema for a specific type.
|
| SchemaProviderRegistrar |
SchemaProvider creators have the ability to automatically have their schemaProvider registered with this SDK by creating a ServiceLoader entry
and a concrete implementation of this interface.
|
| SchemaRegistry |
|
| SchemaTransform |
An abstraction representing schema capable and aware transforms.
|
| SchemaTransformProvider |
Provider to create SchemaTransform instances for use in Beam SQL and other SDKs.
|
| SchemaTransformTranslation |
|
| SchemaTransformTranslation.SchemaTransformPayloadTranslator<T extends SchemaTransform> |
|
| SchemaTranslation |
Utility methods for translating schemas.
|
| SchemaUserTypeCreator |
A creator interface for user types that have schemas.
|
| SchemaUtils |
A set of utility functions for schemas.
|
| SchemaVerification |
|
| SchemaZipFold<T> |
Visitor that zips schemas, and accepts pairs of fields and their types.
|
| SchemaZipFold.Context |
Context referring to a current position in a schema.
|
| SdkComponents |
SDK objects that will be represented at some later point within a RunnerApi.Components object.
|
| SdkHarnessOptions |
Options that are used to control configuration of the SDK harness.
|
| SdkHarnessOptions.BundleProcessorCacheTimeoutFactory |
|
| SdkHarnessOptions.DefaultMaxCacheMemoryUsageMb |
The default implementation which detects how much memory to use for a process wide cache.
|
| SdkHarnessOptions.DefaultMaxCacheMemoryUsageMbFactory |
|
| SdkHarnessOptions.LogLevel |
The set of log levels that can be used in the SDK harness.
|
| SdkHarnessOptions.MaxCacheMemoryUsageMb |
Specifies the maximum amount of memory to use within the current SDK harness instance.
|
| SdkHarnessOptions.SdkHarnessLogLevelOverrides |
Defines a log level override for a specific class, package, or name.
|
| Secret |
A secret management interface used for handling sensitive data.
|
| Select |
A PTransform for selecting a subset of fields from a schema type.
|
| Select.Fields<T> |
|
| Select.Flattened<T> |
|
| SelectHelpers |
Helper methods to select subrows out of rows.
|
| SelectHelpers.RowSelectorContainer |
|
| SerializableBiConsumer<FirstInputT,SecondInputT> |
A union of the BiConsumer and Serializable interfaces.
|
| SerializableBiFunction<FirstInputT,SecondInputT,OutputT> |
A union of the BiFunction and Serializable interfaces.
|
| SerializableCoder<T extends java.io.Serializable> |
A Coder for Java classes that implement Serializable.
|
| SerializableCoder.SerializableCoderProviderRegistrar |
|
| SerializableComparator<T> |
A Comparator that is also Serializable.
|
| SerializableFunction<InputT,OutputT> |
A function that computes an output value of type OutputT from an input value of type
InputT, is Serializable, and does not allow checked exceptions to be declared.
|
| SerializableFunctions |
|
| SerializableMatcher<T> |
A Matcher that is also Serializable.
|
| SerializableMatchers |
|
| SerializableSupplier<T> |
A union of a Supplier and Serializable, enabling configuration with SerializableSupplier
types that are not Serializable.
|
| SerializableThrowable |
A wrapper around Throwable that preserves the stack trace on serialization, unlike
regular Throwable.
|
| SerializableUtils |
Utilities for working with Serializables.
|
| ServerFactory |
A gRPC server factory.
|
| ServerFactory.InetSocketAddressServerFactory |
Creates a gRPC Server using the default server factory.
|
| ServerFactory.UrlFactory |
Factory that constructs client-accessible URLs from a local server address and port.
|
| Sessions |
|
| SetCoder<T> |
|
| Sets |
The PTransforms that allow to compute different set functions across PCollections.
|
| SetState<T> |
|
| ShardedFile |
Bare-bones class for using sharded files.
|
| ShardedKey<K> |
A sharded key consisting of a user key and an opaque shard id represented by bytes.
|
| ShardedKey<K> |
Deprecated.
|
| ShardedKey.Coder<K> |
|
| ShardedKeyCoder<KeyT> |
|
| ShardingFunction<UserT,DestinationT> |
|
| ShardingWritableByteChannel |
Implements a WritableByteChannel that may contain multiple output shards.
|
| ShardNameTemplate |
Standard shard naming templates.
|
| SideInputReference |
A reference to a side input.
|
| SimpleFunction<InputT,OutputT> |
|
| SingleInputOutputOverrideFactory<InputT extends PValue,OutputT extends PValue,TransformT extends PTransform<InputT,OutputT>> |
|
| SinkMetrics |
Standard Sink Metrics.
|
| Sleeper |
Sleeper interface to use for requesting the current thread to sleep as specified in Thread.sleep(long).
|
| SlidingWindows |
A WindowFn that windows values into possibly overlapping fixed-size timestamp-based
windows.
|
| SnappyCoder<T> |
Wraps an existing coder with Snappy compression.
|
| SocketAddressFactory |
Creates a SocketAddress based upon a supplied string.
|
| SortedMapCoder<K extends java.lang.Comparable<? super K>,V> |
A Coder for Maps that encodes them according to provided coders for
keys and values.
|
| Source<T> |
Base class for defining input formats and creating a Source for reading the input.
|
| Source.Reader<T> |
The interface that readers of custom input sources must implement.
|
| SourceMetrics |
|
| SourceTestUtils |
Helper functions and test harnesses for checking correctness of Source implementations.
|
| SourceTestUtils.ExpectedSplitOutcome |
|
| SplitResult<RestrictionT> |
A representation of a split result.
|
| SplittableParDo<InputT,OutputT,RestrictionT,WatermarkEstimatorStateT> |
A utility transform that executes a splittable DoFn by expanding it into a
network of simpler transforms:
Pair each element with an initial restriction
Split each restriction into sub-restrictions
Explode windows, since splitting within each window has to happen independently
Assign a unique key to each element/restriction pair
Process the keyed element/restriction pairs in a runner-specific way with the splittable
DoFn's DoFn.ProcessElement method.
|
| SplittableParDo.OverrideFactory<InputT,OutputT> |
|
| SplittableParDo.PrimitiveBoundedRead<T> |
|
| SplittableParDo.PrimitiveUnboundedRead<T> |
|
| SplittableParDo.ProcessKeyedElements<InputT,OutputT,RestrictionT,WatermarkEstimatorStateT> |
|
| SplittableParDo.ProcessKeyedElementsTranslator |
|
| SplittableParDo.Registrar |
|
| SplittableParDoExpander |
A set of transform replacements for expanding a splittable ParDo into various sub components.
|
| SplittableParDoNaiveBounded |
|
| SplittableParDoNaiveBounded.NaiveProcessFn<InputT,OutputT,RestrictionT,PositionT,WatermarkEstimatorStateT> |
|
| SplittableParDoNaiveBounded.OverrideFactory<InputT,OutputT,RestrictionT,WatermarkEstimatorStateT> |
|
| SqlTypes |
|
| State |
|
| StateBinder |
For internal use only; no backwards-compatibility guarantees.
|
| StateContext<W extends BoundedWindow> |
For internal use only; no backwards-compatibility guarantees.
|
| StateContexts |
For internal use only; no backwards-compatibility guarantees.
|
| StateKeySpec |
|
| StateSpec<StateT extends State> |
A specification of a persistent state cell.
|
| StateSpec.Cases<ResultT> |
Cases for doing a "switch" on the type of StateSpec.
|
| StateSpec.Cases.WithDefault<ResultT> |
A base class for a visitor with a default method for cases it is not interested in.
|
| StateSpecs |
|
| StaticSchemaInference |
A set of utilities for inferring a Beam Schema from static Java types.
|
| StreamingIT |
Deprecated.
|
| StreamingOptions |
Options used to configure streaming.
|
| StreamUtils |
Utility functions for stream operations.
|
| StringCompiler |
|
| StringCompiler.CompileException |
|
| StringDelegateCoder<T> |
A Coder that wraps a Coder<String> and encodes/decodes values via string
representations.
|
| StringSet |
A metric that reports set of unique string values.
|
| StringSetResult |
|
| StringSetResult.EmptyStringSetResult |
|
| StringUtf8Coder |
A Coder that encodes Strings in UTF-8 encoding.
|
| StringUtils |
Utilities for working with JSON and other human-readable string formats.
|
| StructuralByteArray |
A wrapper around a byte[] that uses structural, value-based equality rather than byte[]'s normal
object identity.
|
| StructuredCoder<T> |
|
| SuccessOrFailure |
|
| Sum |
PTransforms for computing the sum of the elements in a PCollection, or the sum of
the values associated with each key in a PCollection of KVs.
|
| SynchronizedStreamObserver<V> |
A StreamObserver which provides synchronous access access to an underlying StreamObserver.
|
| SyntheticComponents |
A utility class to interact with synthetic pipeline components.
|
| SystemDoFnInternal |
Annotation to mark DoFns as an internal component of the Beam SDK.
|
| TaggedPValue |
For internal use only; no backwards-compatibility guarantees.
|
| Tee<T> |
A PTransform that returns its input, but also applies its input to an auxiliary PTransform, akin
to the shell tee command, which is named after the T-splitter used in plumbing.
|
| TestExecutors |
A TestRule that validates that all submitted tasks finished and were completed.
|
| TestExecutors.TestExecutorService |
A union of the ExecutorService and TestRule interfaces.
|
| TestOutputReceiver<T> |
|
| TestPipeline |
A creator of test pipelines that can be used inside of tests that can be configured to run
locally or against a remote pipeline runner.
|
| TestPipeline.AbandonedNodeException |
An exception thrown in case an abandoned PTransform is
detected, that is, a PTransform that has not been run.
|
| TestPipeline.PipelineRunMissingException |
An exception thrown in case a test finishes without invoking Pipeline.run().
|
| TestPipeline.TestValueProviderOptions |
|
| TestPipelineOptions |
|
| TestPipelineOptions.AlwaysPassMatcher |
Matcher which will always pass.
|
| TestPipelineOptions.AlwaysPassMatcherFactory |
|
| TestStream<T> |
A testing input that generates an unbounded PCollection of elements, advancing the
watermark and processing time as elements are emitted.
|
| TestStream.Builder<T> |
|
| TestStream.ElementEvent<T> |
|
| TestStream.Event<T> |
|
| TestStream.EventType |
|
| TestStream.ProcessingTimeEvent<T> |
|
| TestStream.TestStreamCoder<T> |
|
| TestStream.WatermarkEvent<T> |
|
| TestStreams |
Utility methods which enable testing of StreamObservers.
|
| TestStreams.Builder<T> |
A builder for a test CallStreamObserver that performs various callbacks.
|
| TestStreamTranslation |
Utility methods for translating a TestStream to and from RunnerApi
representations.
|
| TextIO |
|
| TextIO.CompressionType |
Deprecated.
|
| TextIO.Read |
|
| TextIO.ReadAll |
Deprecated.
|
| TextIO.ReadFiles |
|
| TextIO.Sink |
|
| TextIO.TypedWrite<UserT,DestinationT> |
|
| TextIO.Write |
|
| TextRowCountEstimator |
This returns a row count estimation for files associated with a file pattern.
|
| TextRowCountEstimator.Builder |
|
| TextRowCountEstimator.LimitNumberOfFiles |
This strategy stops sampling if we sample enough number of bytes.
|
| TextRowCountEstimator.LimitNumberOfTotalBytes |
This strategy stops sampling when total number of sampled bytes are more than some threshold.
|
| TextRowCountEstimator.NoEstimationException |
An exception that will be thrown if the estimator cannot get an estimation of the number of
lines.
|
| TextRowCountEstimator.SampleAllFiles |
This strategy samples all the files.
|
| TextRowCountEstimator.SamplingStrategy |
Sampling Strategy shows us when should we stop reading further files.
|
| TextSource |
|
| TextualIntegerCoder |
A Coder that encodes Integer Integers as the ASCII bytes of their textual,
decimal, representation.
|
| TFRecordIO |
PTransforms for reading and writing TensorFlow TFRecord files.
|
| TFRecordIO.CompressionType |
Deprecated.
|
| TFRecordIO.Read |
|
| TFRecordIO.ReadFiles |
|
| TFRecordIO.Sink |
|
| TFRecordIO.Write |
|
| TFRecordReadSchemaTransformConfiguration |
Configuration for reading from TFRecord.
|
| TFRecordReadSchemaTransformConfiguration.Builder |
|
| TFRecordReadSchemaTransformProvider |
|
| TFRecordReadSchemaTransformProvider.ErrorFn |
|
| TFRecordSchemaTransformTranslation |
|
| TFRecordSchemaTransformTranslation.ReadWriteRegistrar |
|
| TFRecordSchemaTransformTranslation.TFRecordReadSchemaTransformTranslator |
|
| TFRecordSchemaTransformTranslation.TFRecordWriteSchemaTransformTranslator |
|
| TFRecordWriteSchemaTransformConfiguration |
Configuration for reading from TFRecord.
|
| TFRecordWriteSchemaTransformConfiguration.Builder |
|
| TFRecordWriteSchemaTransformProvider |
|
| TFRecordWriteSchemaTransformProvider.ErrorFn |
|
| ThrowingBiConsumer<T1,T2> |
A BiConsumer which can throw Exceptions.
|
| ThrowingBiFunction<T1,T2,T3> |
A BiFunction which can throw Exceptions.
|
| ThrowingConsumer<ExceptionT extends java.lang.Exception,T> |
A Consumer which can throw Exceptions.
|
| ThrowingFunction<T1,T2> |
A Function which can throw Exceptions.
|
| ThrowingRunnable |
A Runnable which can throw Exceptions.
|
| ThrowingRunnable |
Like Runnable but allowed to throw any exception.
|
| ThrowingSupplier<T> |
Like Supplier but allowed to throw any exception.
|
| Time |
A time without a time-zone.
|
| TimeDomain |
TimeDomain specifies whether an operation is based on timestamps of elements or current
"real-world" time as reported while processing.
|
| Timer |
A timer for a specified time domain that can be set to register the desire for further processing
at particular time in its specified time domain.
|
| Timer<K> |
A timer consists of a user key, a dynamic timer tag, a set of windows and either a bit that says
that this timer should be cleared or data representing the firing timestamp, hold timestamp and
pane information that should be used when producing output.
|
| Timer.Coder<K> |
|
| TimerEndpoint<T> |
|
| TimerMap |
|
| TimerReference |
Contains references to components relevant for runners during execution for timers.
|
| Timers |
Interface for interacting with time.
|
| TimerSpec |
A specification for a Timer.
|
| TimerSpecs |
|
| TimestampCombiner |
Policies for combining timestamps that occur within a window.
|
| TimestampedValue<V extends @Nullable java.lang.Object> |
An immutable pair of a value and a timestamp.
|
| TimestampedValue.TimestampedValueCoder<T> |
|
| TimestampObservingWatermarkEstimator<WatermarkEstimatorStateT> |
|
| TimestampPrefixingWindowCoder<T extends BoundedWindow> |
|
| TimestampTransform |
For internal use only; no backwards-compatibility guarantees.
|
| TimestampTransform.AlignTo |
For internal use only; no backwards-compatibility guarantees.
|
| TimestampTransform.Delay |
For internal use only; no backwards-compatibility guarantees.
|
| ToJson<T> |
Creates a PTransform that serializes UTF-8 JSON objects from a Schema-aware
PCollection (i.e.
|
| Top |
PTransforms for finding the largest (or smallest) set of elements in a
PCollection, or the largest (or smallest) set of values associated with each key in a
PCollection of KVs.
|
| Top.Largest<T extends java.lang.Comparable<? super T>> |
Deprecated.
|
| Top.Natural<T extends java.lang.Comparable<? super T>> |
A Serializable Comparator that that uses the compared elements' natural
ordering.
|
| Top.Reversed<T extends java.lang.Comparable<? super T>> |
Serializable Comparator that that uses the reverse of the compared elements'
natural ordering.
|
| Top.Smallest<T extends java.lang.Comparable<? super T>> |
Deprecated.
|
| Top.TopCombineFn<T,ComparatorT extends java.util.Comparator<T> & java.io.Serializable> |
CombineFn for Top transforms that combines a bunch of Ts into a single
count-long List<T>, using compareFn to choose the largest Ts.
|
| ToString |
|
| TransformHierarchy |
For internal use only; no backwards-compatibility guarantees.
|
| TransformInputs |
|
| TransformPayloadTranslatorRegistrar |
A registrar of TransformPayloadTranslator.
|
| TransformUpgrader |
A utility class that allows upgrading transforms of a given pipeline using the Beam Transform
Service.
|
| Trigger |
Triggers control when the elements for a specific key and window are output.
|
| Trigger.OnceTrigger |
For internal use only; no backwards-compatibility guarantees.
|
| TriggerTranslation |
|
| TrivialNativeTransformExpander |
TrivialNativeTransformExpander is used to replace transforms with known URNs with their native
equivalent.
|
| TupleTag<V> |
|
| TupleTagList |
|
| TypeDescriptor<T> |
A description of a Java type, including actual generic parameters where possible.
|
| TypeDescriptors |
A utility class for creating TypeDescriptor objects for different types, such as Java
primitive types, containers and KVs of other TypeDescriptor objects, and
extracting type variables of parameterized types (e.g.
|
| TypeDescriptors.TypeVariableExtractor<InputT,OutputT> |
|
| TypedSchemaTransformProvider<ConfigT> |
|
| TypeParameter<T> |
|
| UnboundedReadFromBoundedSource<T> |
|
| UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter<T> |
A BoundedSource to UnboundedSource adapter.
|
| UnboundedReadFromBoundedSource.BoundedToUnboundedSourceAdapter.Checkpoint<T> |
|
| UnboundedScheduledExecutorService |
An unbounded ScheduledExecutorService based upon the ScheduledThreadPoolExecutor
API contract.
|
| UnboundedSource<OutputT,CheckpointMarkT extends UnboundedSource.CheckpointMark> |
A Source that reads an unbounded amount of input and, because of that, supports some
additional operations such as checkpointing, watermarks, and record ids.
|
| UnboundedSource.CheckpointMark |
|
| UnboundedSource.CheckpointMark.NoopCheckpointMark |
A checkpoint mark that does nothing when finalized.
|
| UnboundedSource.UnboundedReader<OutputT> |
A Reader that reads an unbounded amount of input.
|
| UnconsumedReads |
|
| UnionCoder |
A UnionCoder encodes RawUnionValues.
|
| UnknownCoderWrapper |
Represents a that is not defined in Java SDK, for example, a coder that is
available in an external SDK that cannot be fully interpretted in the Java SDK.
|
| UnknownLogicalType<T> |
A base class for logical types that are not understood by the Java SDK.
|
| UnownedInputStream |
A OutputStream wrapper which protects against the user attempting to modify the
underlying stream by closing it or using mark.
|
| UnownedOutputStream |
A OutputStream wrapper which protects against the user attempting to modify the
underlying stream by closing it.
|
| UnsupportedOverrideFactory<InputT extends PInput,OutputT extends POutput,TransformT extends PTransform<InputT,OutputT>> |
|
| UserCodeException |
An exception that was thrown in user-code.
|
| UserStateReference |
A reference to user state.
|
| UsesAttemptedMetrics |
Category tag for validation tests which utilize Metrics.
|
| UsesBoundedSplittableParDo |
|
| UsesBoundedTrieMetrics |
Category tag for validation tests which utilize BoundedTrie.
|
| UsesBundleFinalizer |
|
| UsesCommittedMetrics |
Category tag for validation tests which utilize Metrics.
|
| UsesCounterMetrics |
Category tag for validation tests which utilize Counter.
|
| UsesCustomWindowMerging |
Category tag for validation tests which utilize custom window merging.
|
| UsesDistributionMetrics |
Category tag for validation tests which utilize Distribution.
|
| UsesExternalService |
Category tag for tests which relies on a pre-defined port, such as expansion service or transform
service.
|
| UsesFailureMessage |
Category tag for tests which validate that currect failure message is provided by failed
pipeline.
|
| UsesGaugeMetrics |
Category tag for validation tests which utilize Gauge.
|
| UsesImpulse |
Category for tests that use Impulse transformations.
|
| UsesJavaExpansionService |
Category tag for tests which use the expansion service in Java.
|
| UsesKeyInParDo |
Category tag for validation tests which use key.
|
| UsesKms |
Category tag for validation tests which utilize --tempRoot from TestPipelineOptions and
and expect a default KMS key enable for the bucket specified.
|
| UsesLoopingTimer |
Category tag for validation tests which utilize looping timers in ParDo.
|
| UsesMapState |
Category tag for validation tests which utilize MapState.
|
| UsesMetricsPusher |
Category tag for validation tests which utilize the metrics pusher feature.
|
| UsesMultimapState |
|
| UsesOnWindowExpiration |
|
| UsesOrderedListState |
|
| UsesParDoLifecycle |
Category tag for the ParDoLifecycleTest for exclusion (BEAM-3241).
|
| UsesPerKeyOrderedDelivery |
Category tag for validation tests which rely on a runner providing per-key ordering.
|
| UsesPerKeyOrderInBundle |
Category tag for validation tests which rely on a runner providing per-key ordering in between
transforms in the same ProcessBundleRequest.
|
| UsesProcessingTimeTimers |
Category tag for validation tests which utilize timers in ParDo.
|
| UsesPythonExpansionService |
Category tag for tests which use the expansion service in Python.
|
| UsesRequiresTimeSortedInput |
|
| UsesSchema |
Category tag for validation tests which utilize schemas.
|
| UsesSdkHarnessEnvironment |
Category tag for tests which validate that the SDK harness executes in a well formed environment.
|
| UsesSetState |
Category tag for validation tests which utilize SetState.
|
| UsesSideInputs |
Category tag for validation tests which use sideinputs.
|
| UsesSideInputsWithDifferentCoders |
Category tag for validation tests which use multiple side inputs with different coders.
|
| UsesStatefulParDo |
Category tag for validation tests which utilize stateful ParDo.
|
| UsesStrictTimerOrdering |
Category for tests that enforce strict event-time ordering of fired timers, even in situations
where multiple tests mutually set one another and watermark hops arbitrarily far to the future.
|
| UsesStringSetMetrics |
Category tag for validation tests which utilize StringSet.
|
| UsesSystemMetrics |
Category tag for tests that use System metrics.
|
| UsesTestStream |
Category tag for tests that use TestStream, which is not a part of the Beam model but a
special feature currently only implemented by the direct runner and the Flink Runner (streaming).
|
| UsesTestStreamWithMultipleStages |
|
| UsesTestStreamWithOutputTimestamp |
Category tag for validation tests which use outputTimestamp.
|
| UsesTestStreamWithProcessingTime |
|
| UsesTimerMap |
Category tag for validation tests which use timerMap.
|
| UsesTimersInParDo |
Category tag for validation tests which utilize timers in ParDo.
|
| UsesTriggeredSideInputs |
Category tag for validation tests which use triggered sideinputs.
|
| UsesUnboundedPCollections |
Category tag for validation tests which utilize at least one unbounded PCollection.
|
| UsesUnboundedSplittableParDo |
|
| UuidLogicalType |
Base class for types representing UUID as two long values.
|
| ValidatesRunner |
Category tag for tests which validate that a Beam runner is correctly implemented.
|
| Validation |
|
| Validation.Required |
This criteria specifies that the value must be not null.
|
| ValueInSingleWindow<T> |
An immutable tuple of value, timestamp, window, and pane.
|
| ValueInSingleWindow.Coder<T> |
|
| ValueProvider<T> |
A ValueProvider abstracts the notion of fetching a value that may or may not be currently
available.
|
| ValueProvider.Deserializer |
For internal use only; no backwards compatibility guarantees.
|
| ValueProvider.NestedValueProvider<T,X> |
|
| ValueProvider.RuntimeValueProvider<T> |
|
| ValueProvider.Serializer |
For internal use only; no backwards compatibility guarantees.
|
| ValueProvider.StaticValueProvider<T> |
|
| ValueProviders |
|
| Values<V> |
Values<V> takes a PCollection of KV<K, V>s and returns a
PCollection<V> of the values.
|
| ValueState<T> |
|
| ValueWithRecordId<ValueT> |
For internal use only; no backwards compatibility guarantees.
|
| ValueWithRecordId.StripIdsDoFn<T> |
DoFn to turn a ValueWithRecordId<T> back to the value T.
|
| ValueWithRecordId.ValueWithRecordIdCoder<ValueT> |
A Coder for ValueWithRecordId, using a wrapped value Coder.
|
| VariableBytes |
A LogicalType representing a variable-length byte array with specified maximum length.
|
| VariableString |
A LogicalType representing a variable-length string with specified maximum length.
|
| VarInt |
Variable-length encoding for integers.
|
| VarIntCoder |
A Coder that encodes Integers using between 1 and 5 bytes.
|
| VarLongCoder |
A Coder that encodes Longs using between 1 and 10 bytes.
|
| View |
|
| View.AsIterable<T> |
For internal use only; no backwards-compatibility guarantees.
|
| View.AsList<T> |
For internal use only; no backwards-compatibility guarantees.
|
| View.AsMap<K,V> |
For internal use only; no backwards-compatibility guarantees.
|
| View.AsMultimap<K,V> |
For internal use only; no backwards-compatibility guarantees.
|
| View.AsSingleton<T> |
For internal use only; no backwards-compatibility guarantees.
|
| View.CreatePCollectionView<ElemT,ViewT> |
For internal use only; no backwards-compatibility guarantees.
|
| View.ToListViewDoFn<T> |
Provides an index to value mapping using a random starting index and also provides an offset
range for each window seen.
|
| ViewFn<PrimitiveViewT,ViewT> |
For internal use only; no backwards-compatibility guarantees.
|
| VoidCoder |
|
| Wait |
Delays processing of each window in a PCollection until signaled.
|
| Wait.OnSignal<T> |
|
| Watch |
Given a "poll function" that produces a potentially growing set of outputs for an input, this
transform simultaneously continuously watches the growth of output sets of all inputs, until a
per-input termination condition is reached.
|
| Watch.Growth<InputT,OutputT,KeyT> |
|
| Watch.Growth.PollFn<InputT,OutputT> |
|
| Watch.Growth.PollResult<OutputT> |
|
| Watch.Growth.TerminationCondition<InputT,StateT> |
A strategy for determining whether it is time to stop polling the current input regardless of
whether its output is complete or not.
|
| Watch.WatchGrowthFn<InputT,OutputT,KeyT,TerminationStateT> |
|
| WatermarkEstimator<WatermarkEstimatorStateT> |
|
| WatermarkEstimators |
|
| WatermarkEstimators |
|
| WatermarkEstimators.Manual |
|
| WatermarkEstimators.MonotonicallyIncreasing |
A watermark estimator that observes timestamps of records output from a DoFn reporting the
timestamp of the last element seen as the current watermark.
|
| WatermarkEstimators.WallTime |
A watermark estimator that tracks wall time.
|
| WatermarkEstimators.WatermarkAndStateObserver<WatermarkEstimatorStateT> |
Interface which allows for accessing the current watermark and watermark estimator state.
|
| WatermarkHoldState |
For internal use only; no backwards-compatibility guarantees.
|
| Weighted |
Interface representing an object that has a weight, in unspecified units.
|
| WeightedList<T> |
Facade for a List that keeps track of weight, for cache limit reasons.
|
| WeightedValue<T> |
A T with an accompanying weight.
|
| Window<T> |
|
| Window.Assign<T> |
|
| Window.ClosingBehavior |
Specifies the conditions under which a final pane will be created when a window is permanently
closed.
|
| Window.OnTimeBehavior |
Specifies the conditions under which an on-time pane will be created when a window is closed.
|
| WindowedValue<T> |
A value along with Beam's windowing information and all other metadata.
|
| WindowedValueMultiReceiver |
Encapsulation of a method of output that can output a value with all of its windowing information
to a tagged destination.
|
| WindowedValueReceiver<OutputT> |
An encapsulated method of output that can output a value with all of its metadata.
|
| WindowedValues |
|
| WindowedValues.Builder<T> |
|
| WindowedValues.FullWindowedValueCoder<T> |
Coder for WindowedValue.
|
| WindowedValues.ParamWindowedValueCoder<T> |
A parameterized coder for WindowedValue.
|
| WindowedValues.SingleWindowedValue |
|
| WindowedValues.ValueOnlyWindowedValueCoder<T> |
Deprecated.
|
| WindowedValues.WindowedValueCoder<T> |
Abstract class for WindowedValue coder.
|
| WindowFn<T,W extends BoundedWindow> |
The argument to the Window transform used to assign elements into windows and to
determine how windows are merged.
|
| WindowFnTestUtils |
|
| WindowingStrategy<T,W extends BoundedWindow> |
A WindowingStrategy describes the windowing behavior for a specific collection of values.
|
| WindowingStrategy.AccumulationMode |
The accumulation modes that can be used with windowing.
|
| WindowingStrategyTranslation |
|
| WindowIntoTranslation |
Utility methods for translating a Window.Assign to and from RunnerApi
representations.
|
| WindowIntoTranslation.Registrar |
|
| WindowIntoTranslation.WindowIntoPayloadTranslator |
|
| WindowMappingFn<TargetWindowT extends BoundedWindow> |
A function that takes the windows of elements in a main input and maps them to the appropriate
window in a PCollectionView consumed as a side input.
|
| WindowTracing |
Logging for window operations.
|
| WithFailures |
A collection of utilities for writing transforms that can handle exceptions raised during
processing of elements.
|
| WithFailures.ExceptionAsMapHandler<T> |
A simple handler that extracts information from an exception to a Map<String, String>
and returns a KV where the key is the input element that failed processing, and the
value is the map of exception attributes.
|
| WithFailures.ExceptionElement<T> |
The value type passed as input to exception handlers.
|
| WithFailures.Result<OutputT extends POutput,FailureElementT> |
An intermediate output type for PTransforms that allows an output collection to live alongside
a collection of elements that failed the transform.
|
| WithFailures.ThrowableHandler<T> |
A handler that holds onto the Throwable that led to the exception, returning it along
with the original value as a KV.
|
| WithKeys<T> |
|
| WithKeys<K,V> |
WithKeys<K, V> takes a PCollection<V>, and either a constant key of type
K or a function from V to K, and returns a PCollection<KV<K, V>>, where
each of the values in the input PCollection has been paired with either the constant key
or a key computed from the value.
|
| WithTimestamps<T> |
|
| WriteFiles<UserT,DestinationT,OutputT> |
|
| WriteFilesResult<DestinationT> |
|
| WriteFilesTranslation |
Utility methods for translating a WriteFiles to and from RunnerApi
representations.
|
| WriteFilesTranslation.Registrar |
Registers WriteFilesTranslation.WriteFilesTranslator.
|
| YamlUtils |
|
| ZipFiles |
Functions for zipping a directory (including a subdirectory) into a ZIP-file or unzipping it
again.
|
| ZstdCoder<T> |
Wraps an existing coder with Zstandard compression.
|