All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
Class |
Description |
AbstractAutoCloseableRegistry<R extends AutoCloseable,C extends R,T,E extends Exception> |
This is the abstract base class for registries that allow to register instances of Closeable , which are all closed if this registry is closed.
|
AbstractDeserializationSchema<T> |
The deserialization schema describes how to turn the byte messages delivered by certain data
sources (for example Apache Kafka) into data types (Java/Scala objects) that are processed by
Flink.
|
AbstractID |
A statistically unique identification number.
|
AbstractParameterTool |
|
AbstractRichFunction |
An abstract stub implementation for rich user-defined functions.
|
AbstractRuntimeUDFContext |
A standalone implementation of the RuntimeContext , created by runtime UDF operators.
|
AbstractUdfOperator<OUT,FT extends org.apache.flink.api.common.functions.Function> |
Abstract superclass for all contracts that represent actual operators.
|
Accumulator<V,R extends Serializable> |
Accumulators collect distributed statistics or aggregates in a from user functions and operators.
|
AccumulatorHelper |
|
AggregatingStateDescriptor<IN,ACC,OUT> |
A StateDescriptor for AggregatingState .
|
Aggregator<T extends Value> |
Aggregators are a means of aggregating values across parallel instances of a function.
|
AggregatorRegistry |
|
AggregatorWithName<T extends Value> |
Simple utility class holding an Aggregator with the name it is registered under.
|
AlgorithmOptions |
Configuration parameters for join/sort algorithms.
|
Archiveable<T extends Serializable> |
|
ArchivedExecutionConfig |
Serializable class which is created when archiving the job.
|
ArrayUtils |
Utility class for Java arrays.
|
AscendingTimestampsWatermarks<T> |
A watermark generator that assumes monotonically ascending timestamps within the stream split and
periodically generates watermarks based on that assumption.
|
AtomicType<T> |
An atomic type is a type that is treated as one indivisible unit and where the entire type acts
as a key.
|
Attribute |
Attribute contains the information about the process logic of a process function.
|
Attribute.Builder |
|
AutoCloseableAsync |
Closeable interface which allows to close a resource in a non blocking fashion.
|
AutoCloseableRegistry |
This class allows to register instances of AutoCloseable , which are all closed if this
registry is closed.
|
AverageAccumulator |
An accumulator that computes the average value.
|
AvroUtils |
Utility methods for dealing with Avro types.
|
BackPressuringExecutor |
An executor decorator that allows only a certain number of concurrent executions.
|
BaseStatistics |
Interface describing the basic statistics that can be obtained from the input.
|
BasicArrayTypeInfo<T,C> |
Type information for arrays boxed primitive types.
|
BasicTypeComparator<T extends Comparable<T>> |
|
BasicTypeDescriptorImpl<T> |
|
BasicTypeInfo<T> |
Type information for primitive types (int, long, double, byte, ...), String, Date, Void,
BigInteger, and BigDecimal.
|
BatchExecutionOptions |
Configuration options for the batch job execution.
|
BatchShuffleMode |
Defines how data is exchanged between tasks in batch ExecutionOptions.RUNTIME_MODE if the
shuffling behavior has not been set explicitly for an individual exchange.
|
BigDecComparator |
Comparator for comparing BigDecimal values.
|
BigDecParser |
|
BigDecSerializer |
Serializer for serializing/deserializing BigDecimal values including null values.
|
BigDecSerializer.BigDecSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
BigIntComparator |
Comparator for comparing BigInteger values.
|
BigIntParser |
|
BigIntSerializer |
Serializer for serializing/deserializing BigInteger values including null values.
|
BigIntSerializer.BigIntSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
BinaryInputFormat<T> |
Base class for all input formats that use blocks of fixed size.
|
BinaryOperatorInformation<IN1,IN2,OUT> |
A class for holding information about a single input operator, such as input/output
TypeInformation.
|
BinaryOutputFormat<T> |
|
BlobServerOptions |
Configuration options for the BlobServer and BlobCache.
|
BlockElement |
Part of description that represents a block e.g. some text, linebreak or a list.
|
BlockInfo |
A block of 24 bytes written at the end of a block in a binary file, and containing i) the
number of records in the block, ii) the accumulated number of records, and iii) the offset of the
first record in the block.
|
BlockLocation |
A BlockLocation lists hosts, offset and length of block.
|
BooleanComparator |
|
BooleanParser |
|
BooleanPrimitiveArrayComparator |
|
BooleanPrimitiveArraySerializer |
A serializer for boolean arrays.
|
BooleanPrimitiveArraySerializer.BooleanPrimitiveArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
BooleanSerializer |
Type serializer for Boolean .
|
BooleanSerializer.BooleanSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
BooleanValue |
Boxed serializable and comparable boolean type, representing the primitive type boolean .
|
BooleanValueComparator |
Specialized comparator for BooleanValue based on CopyableValueComparator.
|
BooleanValueParser |
|
BooleanValueSerializer |
|
BooleanValueSerializer.BooleanValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
Boundedness |
The boundedness of a stream.
|
BoundedOutOfOrdernessWatermarks<T> |
A WatermarkGenerator for situations where records are out of order, but you can place an upper
bound on how far the events are out of order.
|
BroadcastVariableInitializer<T,O> |
A broadcast variable initializer can be used to transform a broadcast variable into another
format during initialization.
|
BulkIterationBase<T> |
|
BulkIterationBase.PartialSolutionPlaceHolder<OT> |
Specialized operator to use as a recognizable place-holder for the input to the step function
when composing the nested data flow.
|
BulkIterationBase.TerminationCriterionAggregationConvergence |
Convergence for the termination criterion is reached if no tuple is output at current
iteration for the termination criterion branch
|
BulkIterationBase.TerminationCriterionAggregator |
Aggregator that basically only adds 1 for every output tuple of the termination criterion
branch
|
BulkIterationBase.TerminationCriterionMapper<X> |
Special Mapper that is added before a termination criterion and is only a container for an
special aggregator
|
BulkWriter<T> |
An encoder that encodes data in a bulk fashion, encoding many records together at a time.
|
BulkWriter.Factory<T> |
|
ByteArrayInputStreamWithPos |
Un-synchronized stream similar to Java's ByteArrayInputStream that also exposes the current
position.
|
ByteArrayOutputStreamWithPos |
Un-synchronized stream similar to Java's ByteArrayOutputStream that also exposes the current
position.
|
ByteBufferReadable |
An interface mark that a filesystem supports to read bytes from a ByteBuffer and its
given position.
|
ByteBufferReadableClosingFSDataInputStream |
|
ByteComparator |
|
ByteParser |
|
BytePrimitiveArrayComparator |
|
BytePrimitiveArraySerializer |
A serializer for byte arrays.
|
BytePrimitiveArraySerializer.BytePrimitiveArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
ByteSerializer |
Type serializer for Byte .
|
ByteSerializer.ByteSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
ByteValue |
Boxed serializable and comparable byte type, representing the primitive type byte (signed
8 bit integer).
|
ByteValueComparator |
Specialized comparator for ByteValue based on CopyableValueComparator.
|
ByteValueParser |
Parses a decimal text field into a ByteValue .
|
ByteValueSerializer |
|
ByteValueSerializer.ByteValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
Bzip2InputStreamFactory |
Factory for Bzip2 decompressors.
|
CacheSupportedPipelineExecutor |
The pipeline executor that support caching intermediate dataset.
|
CharComparator |
|
CharPrimitiveArrayComparator |
|
CharPrimitiveArraySerializer |
A serializer for char arrays.
|
CharPrimitiveArraySerializer.CharPrimitiveArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
CharSerializer |
Type serializer for Character .
|
CharSerializer.CharSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
CharValue |
Boxed serializable and comparable character type, representing the primitive type char .
|
CharValueComparator |
Specialized comparator for CharValue based on CopyableValueComparator.
|
CharValueSerializer |
|
CharValueSerializer.CharValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
CheckpointableInputFormat<S extends InputSplit,T extends Serializable> |
An interface that describes InputFormat s that allow checkpointing/restoring their state.
|
CheckpointingMode |
The checkpointing mode defines what consistency guarantees the system gives in the presence of
failures.
|
CheckpointingOptions |
A collection of all configuration options that relate to checkpoints and savepoints.
|
CheckpointListener |
This interface is typically only needed for transactional interaction with the "outside world",
like committing external side effects on checkpoints.
|
CheckpointType |
Describes the type in which a checkpoint should be taken.
|
ChildFirstClassLoader |
A variant of the URLClassLoader that first loads from the URLs and only after that from the
parent.
|
ChillSerializerRegistrar |
Interface for flink-core to interact with the FlinkChillPackageRegistrar in flink-streaming-java.
|
ClassLoaderUtil |
Utilities for information with respect to class loaders, specifically class loaders for the
dynamic loading of user defined classes.
|
CleanupOptions |
ConfigOption collection for the configuration of repeatable cleanup of resource cleanup
after a job reached a globally-terminated state.
|
CleanupWhenUnsuccessful |
OutputFormat s may implement this interface to run a cleanup hook when the execution is
not successful.
|
Clock |
A clock that gives access to time.
|
CloseableIterable<T> |
This interface represents an iterable that is also closeable.
|
CloseableIterable.Empty<T> |
Empty iterator.
|
CloseableIterator<T> |
|
CloseableIterator.IteratorAdapter<E> |
|
CloseableRegistry |
|
CloseShieldOutputStream |
A proxy output stream that prevents the underlying output stream from being closed.
|
ClosingFSDataInputStream |
|
ClosingFSDataOutputStream |
|
ClosureCleaner |
The closure cleaner is a utility that tries to truncate the closure (enclosing instance) of
non-static inner classes (created for inline transformation functions).
|
ClusterOptions |
Options which control the cluster behaviour.
|
ClusterOptions.UncaughtExceptionHandleMode |
|
ClusterOptions.UserSystemExitMode |
The mode of how to handle user code attempting to exit JVM.
|
CoGroupFunction<IN1,IN2,O> |
The interface for CoGroup functions.
|
CoGroupOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> |
|
CoGroupRawOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> |
|
CoGroupRawOperatorBase.SimpleListIterable<IN> |
|
CollectionExecutor |
Execution utility for serial, local, collection-based executions of Flink programs.
|
CollectionUtil |
Simple utility to work with Java collections.
|
Collector<T> |
Collects a record and forwards it.
|
CombineFunction<IN,OUT> |
Generic interface used for combine functions ("combiners").
|
Committer<CommT> |
The Committer is responsible for committing the data staged by the CommittingSinkWriter in the second step of a two-phase commit protocol.
|
Committer.CommitRequest<CommT> |
A request to commit a specific committable.
|
CommitterFromPersistRecoverableFsDataOutputStream<RESUME_RECOVERABLE extends RecoverableWriter.ResumeRecoverable> |
|
CommitterInitContext |
The interface exposes some runtime info for creating a Committer .
|
CommittingSinkWriter<InputT,CommittableT> |
A SinkWriter that performs the first part of a two-phase commit protocol.
|
CommonRangeBoundaries<T> |
|
CompilerHints |
A class encapsulating compiler hints describing the behavior of the user function.
|
CompletedStateFuture<T> |
A StateFuture that has already been completed when it is created.
|
ComponentClassLoader |
A URLClassLoader that restricts which classes can be loaded to those contained within the
given classpath, except classes from a given set of packages that are either loaded owner or
component-first.
|
CompositeSerializer<T> |
Base class for composite serializers.
|
CompositeSerializer.PrecomputedParameters |
This class holds composite serializer parameters which can be precomputed in advanced for
better performance.
|
CompositeType<T> |
Base type information class for Tuple and Pojo types
|
CompositeType.FlatFieldDescriptor |
|
CompositeType.InvalidFieldReferenceException |
|
CompositeType.TypeComparatorBuilder<T> |
|
CompositeTypeComparator<T> |
|
CompositeTypeSerializerSnapshot<T,S extends TypeSerializer<T>> |
A CompositeTypeSerializerSnapshot is a convenient serializer snapshot class that can be
used by simple serializers which 1) delegates its serialization to multiple nested serializers,
and 2) may contain some extra static information that needs to be persisted as part of its
snapshot.
|
CompositeTypeSerializerSnapshot.OuterSchemaCompatibility |
Indicates schema compatibility of the serializer configuration persisted as the outer
snapshot.
|
CompositeTypeSerializerUtil |
|
CompositeTypeSerializerUtil.IntermediateCompatibilityResult<T> |
|
CompressedSerializedValue<T> |
An extension of SerializedValue that compresses the value after the serialization.
|
CompressionUtils |
Utils used to extract compressed files.
|
ConfigConstants |
This class contains all constants for the configuration.
|
ConfigOption<T> |
A ConfigOption describes a configuration parameter.
|
ConfigOptions |
|
ConfigOptions.ListConfigOptionBuilder<E> |
|
ConfigOptions.OptionBuilder |
|
ConfigOptions.TypedConfigOptionBuilder<T> |
|
Configuration |
Lightweight configuration object which stores key/value pairs.
|
ConfigurationException |
Exception which occurs when creating a configuration object fails.
|
ConfigurationFileMigrationUtils |
Utility class for migrating legacy Flink configuration file flink-conf.yaml to the new
format starting from Flink 2.0.
|
ConfigurationUtils |
|
ConfigUtils |
General utilities for parsing values to configuration options.
|
ConnectionLimitingFactory |
|
ConvergenceCriterion<T extends Value> |
Used to check for convergence.
|
CopyableValue<T> |
Interface to be implemented by basic types that support to be copied efficiently.
|
CopyableValueComparator<T extends CopyableValue<T> & Comparable<T>> |
Comparator for all Value types that extend Key
|
CopyableValueSerializer<T extends CopyableValue<T>> |
|
CopyableValueSerializer.CopyableValueSerializerSnapshot<T extends CopyableValue<T>> |
|
CopyingIterator<E> |
Wraps an iterator to return deep copies of the original iterator's elements.
|
CopyingListCollector<T> |
A Collector that collects deep copies of its elements in a list.
|
CoreOptions |
The set of configuration options for core parameters.
|
CPUResource |
Represents CPU resource.
|
CrossFunction<IN1,IN2,OUT> |
Interface for Cross functions.
|
CrossOperatorBase<IN1,IN2,OUT,FT extends CrossFunction<IN1,IN2,OUT>> |
|
CrossOperatorBase.CrossHint |
The cross hint tells the system which sizes to expect from the data sets
|
CrossOperatorBase.CrossWithLarge |
Marker interface to declare the second input as the larger one.
|
CrossOperatorBase.CrossWithSmall |
Marker interface to declare the second input as the smaller one.
|
DataDistribution |
|
DataInputDeserializer |
A simple and efficient deserializer for the DataInput interface.
|
DataInputView |
This interface defines a view over some memory that can be used to sequentially read the contents
of the memory.
|
DataInputViewStream |
|
DataInputViewStreamWrapper |
|
DataOutputSerializer |
A simple and efficient serializer for the DataOutput interface.
|
DataOutputView |
This interface defines a view over some memory that can be used to sequentially write contents to
the memory.
|
DataOutputViewStream |
|
DataOutputViewStreamWrapper |
|
DataStreamV2SinkUtils |
Utils to create the DataStream V2 supported Sink .
|
DataStreamV2SourceUtils |
Utils to create the DataStream V2 supported Source .
|
DateComparator |
|
DateSerializer |
|
DateSerializer.DateSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
Deadline |
|
DefaultExecutorServiceLoader |
|
DefaultInputSplitAssigner |
|
DefaultJobExecutionStatusEvent |
|
DefaultOpenContext |
|
DefaultPluginManager |
|
DeflateInflaterInputStreamFactory |
Factory for input streams that decompress the "deflate" compression format.
|
DelegatingConfiguration |
A configuration that manages a subset of keys with a common prefix from a given configuration.
|
DelegationTokenProvider |
Delegation token provider API.
|
DelegationTokenProvider.ObtainedDelegationTokens |
Container for obtained delegation tokens.
|
DelegationTokenReceiver |
Delegation token receiver API.
|
DelimitedInputFormat<OT> |
Base implementation for input formats that split the input at a delimiter into records.
|
DeltaIterationBase<ST,WT> |
A DeltaIteration is similar to a BulkIterationBase , but maintains state across the
individual iteration steps.
|
DeltaIterationBase.SolutionSetPlaceHolder<ST> |
Specialized operator to use as a recognizable place-holder for the solution set input to the
step function.
|
DeltaIterationBase.WorksetPlaceHolder<WT> |
Specialized operator to use as a recognizable place-holder for the working set input to the
step function.
|
DeploymentOptions |
|
DeploymentOptionsInternal |
Internal options used during deployment.
|
DescribedEnum |
|
Description |
|
Description.DescriptionBuilder |
|
DeserializationException |
An exception specifying that the deserialization caused an error.
|
DeserializationSchema<T> |
The deserialization schema describes how to turn the byte messages delivered by certain data
sources (for example Apache Kafka) into data types (Java/Scala objects) that are processed by
Flink.
|
DeserializationSchema.InitializationContext |
|
DetachedJobExecutionResult |
The JobExecutionResult returned by a context environment when executing a job in detached
mode.
|
DirectoryBasedPluginFinder |
This class is used to create a collection of PluginDescriptor based on directory
structure for a given plugin root folder.
|
Disposable |
Interface for classes that can be disposed, i.e. that have a dedicated lifecycle step to
"destroy" the object.
|
DistributedCache |
DistributedCache provides static methods to write the registered cache files into job
configuration or decode them from job configuration.
|
DistributedCache.DistributedCacheEntry |
|
DoubleComparator |
|
DoubleCounter |
An accumulator that sums up double values.
|
DoubleMaximum |
An accumulator that finds the maximum double value.
|
DoubleMinimum |
An accumulator that finds the minimum double value.
|
DoubleParser |
Parses a text field into a Double.
|
DoublePrimitiveArrayComparator |
|
DoublePrimitiveArraySerializer |
A serializer for double arrays.
|
DoublePrimitiveArraySerializer.DoublePrimitiveArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
DoubleSerializer |
Type serializer for Double .
|
DoubleSerializer.DoubleSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
DoubleSumAggregator |
|
DoubleValue |
Boxed serializable and comparable double precision floating point type, representing the
primitive type double .
|
DoubleValueComparator |
Specialized comparator for DoubleValue based on CopyableValueComparator.
|
DoubleValueParser |
Parses a text field into a DoubleValue.
|
DoubleValueSerializer |
|
DoubleValueSerializer.DoubleValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
DoubleZeroConvergence |
|
DualInputOperator<IN1,IN2,OUT,FT extends org.apache.flink.api.common.functions.Function> |
Abstract operator superclass for all operators that have two inputs, like "Join", "CoGroup", or
"Cross".
|
DualInputSemanticProperties |
Container for the semantic properties associated to a dual input operator.
|
DynamicCodeLoadingException |
An exception that is thrown if the dynamic instantiation of code fails.
|
DynamicFilteringInfo |
A decorative interface that indicates it holds the dynamic partition filtering data.
|
DynamicParallelismInference |
Sources that implement this interface will dynamically infer the source’s parallelism when it is
unspecified.
|
DynamicParallelismInference.Context |
A context that provides dynamic parallelism decision infos.
|
Either<L,R> |
This type represents a value of one two possible types, Left or Right (a disjoint union),
inspired by Scala's Either type.
|
Either.Left<L,R> |
|
Either.Right<L,R> |
|
EitherSerializer<L,R> |
|
EitherTypeInfo<L,R> |
|
EitherTypeInfoFactory<L,R> |
|
Encoder<IN> |
A Encoder is used by the streaming file sink to perform the actual writing of the
incoming elements to the files in a bucket.
|
EntropyInjectingFileSystem |
An interface to be implemented by a FileSystem that is aware of entropy injection.
|
EntropyInjector |
|
EnumComparator<T extends Enum<T>> |
|
EnumSerializer<T extends Enum<T>> |
|
EnumSerializer.EnumSerializerSnapshot<T extends Enum<T>> |
|
EnumTypeInfo<T extends Enum<T>> |
|
ExceptionUtils |
A collection of utility functions for dealing with exceptions and exception workflows.
|
ExecutionConfig |
A config to define the behavior of the program execution.
|
ExecutionConfig.ClosureCleanerLevel |
Configuration settings for the closure cleaner.
|
ExecutionConfig.GlobalJobParameters |
Abstract class for a custom user configuration object registered at the execution config.
|
ExecutionOptions |
ConfigOption s specific for a single execution of a user program.
|
Executors |
|
ExecutorThreadFactory |
A thread factory intended for use by critical thread pools.
|
ExecutorThreadFactory.Builder |
|
ExecutorUtils |
|
ExponentialBackoffRetryStrategy |
An implementation of RetryStrategy that retries that has an exponential backoff with a
cap.
|
ExternalizedCheckpointRetention |
Cleanup behaviour for externalized checkpoints when the job is cancelled.
|
ExternallyInducedSourceReader<T,SplitT extends SourceSplit> |
Sources that implement this interface delay checkpoints when receiving a trigger message from the
checkpoint coordinator to the point when their input data/events indicate that a checkpoint
should be triggered.
|
ExternalResource |
An external resource.
|
ExternalResourceDriver |
Driver which takes the responsibility to manage and provide the information of external resource.
|
ExternalResourceDriverFactory |
|
ExternalResourceInfo |
Contains the information of an external resource.
|
ExternalResourceOptions |
Configuration options for external resources and external resource drivers.
|
FailureEnricher |
Failure Enricher enabling custom logic and attaching metadata in the form of labels to each type
of failure as tracked in the JobMaster.
|
FailureEnricher.Context |
|
FailureEnricher.Context.FailureType |
Type of failure.
|
FailureEnricherFactory |
|
FallbackKey |
A key with FallbackKeys will fall back to the FallbackKeys if it itself is not configured.
|
FatalExitExceptionHandler |
Handler for uncaught exceptions that will log the exception and kill the process afterwards.
|
FieldList |
Immutable ordered list of fields IDs.
|
FieldParser<T> |
A FieldParser is used parse a field from a sequence of bytes.
|
FieldParser.ParseErrorState |
An enumeration of different types of errors that may occur.
|
FieldSerializer |
This class is for the serialization of java.lang.reflect.Field, which doesn't implement
Serializable, therefore readObject/writeObject need to be implemented in classes where there is a
field of type java.lang.reflect.Field.
|
FieldSet |
Immutable unordered collection of fields IDs.
|
FileInputFormat<OT> |
|
FileInputFormat.FileBaseStatistics |
Encapsulation of the basic statistics the optimizer obtains about a file.
|
FileInputFormat.InputSplitOpenThread |
Obtains a DataInputStream in an thread that is not interrupted.
|
FileInputSplit |
A file input split provides information on a particular part of a file, possibly hosted on a
distributed file system and replicated among several hosts.
|
FileLock |
A file lock used for avoiding race condition among multiple threads/processes.
|
FileOutputFormat<IT> |
The abstract base class for all Rich output formats that are file based.
|
FileOutputFormat.OutputDirectoryMode |
Behavior for creating output directories.
|
FilePathFilter |
|
FilePathFilter.DefaultFilter |
The default file path filtering method and is used if no other such function is provided.
|
FileStatus |
Interface that represents the client side information for a file independent of the file system.
|
FileSystem |
Abstract base class of all file systems used by Flink.
|
FileSystem.FSKey |
An identifier of a file system, via its scheme and its authority.
|
FileSystem.WriteMode |
The possible write modes.
|
FileSystemFactory |
A factory to create file systems.
|
FileSystemKind |
An enumeration defining the kind and characteristics of a FileSystem .
|
FileSystemSafetyNet |
The FileSystemSafetyNet can be used to guard a thread against FileSystem stream resource
leaks.
|
FileUtils |
This is a utility class to deal files and directories.
|
FilterFunction<T> |
A filter function is a predicate applied individually to each record.
|
FilterOperatorBase<T,FT extends FlatMapFunction<T,T>> |
|
FinalizeOnMaster |
This interface may be implemented by OutputFormat s to have the master finalize them
globally.
|
FinalizeOnMaster.FinalizationContext |
A context that provides parallelism and finished attempts infos.
|
FirstAttemptInitializationContext |
|
FixedRetryStrategy |
An implementation of RetryStrategy that retries at a fixed delay.
|
FlatJoinFunction<IN1,IN2,OUT> |
Interface for Join functions.
|
FlatMapFunction<T,O> |
Base interface for flatMap functions.
|
FlatMapOperatorBase<IN,OUT,FT extends FlatMapFunction<IN,OUT>> |
|
FlinkConnectorRateLimiter |
An interface to create a ratelimiter
|
FlinkException |
Base class of all Flink-specific checked exceptions.
|
FlinkExpectedException |
This class is just used to pass diagnostic message of some excepted procedure.
|
FlinkRuntimeException |
Base class of all Flink-specific unchecked exceptions.
|
FlinkSecurityManager |
FlinkSecurityManager to control certain behaviors that can be captured by Java system
security manager.
|
FlinkUserCodeClassLoader |
|
FlinkUserCodeClassLoaders |
Gives the URLClassLoader a nicer name for debugging purposes.
|
FlinkUserCodeClassLoaders.ParentFirstClassLoader |
Regular URLClassLoader that first loads from the parent and only after that from the URLs.
|
FlinkUserCodeClassLoaders.ResolveOrder |
|
FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader |
Ensures that holding a reference on the context class loader outliving the scope of user code
does not prevent the user classloader to be garbage collected (FLINK-16245).
|
FloatComparator |
|
FloatParser |
Parses a text field into a Float .
|
FloatPrimitiveArrayComparator |
|
FloatPrimitiveArraySerializer |
A serializer for float arrays.
|
FloatPrimitiveArraySerializer.FloatPrimitiveArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
FloatSerializer |
Type serializer for Float .
|
FloatSerializer.FloatSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
FloatValue |
Boxed serializable and comparable single precision floating point type, representing the
primitive type float .
|
FloatValueComparator |
Specialized comparator for FloatValue based on CopyableValueComparator.
|
FloatValueParser |
|
FloatValueSerializer |
|
FloatValueSerializer.FloatValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
Formatter |
Allows providing multiple formatters for the description.
|
FractionalTypeInfo<T> |
Type information for numeric fractional primitive types (double, float).
|
FromDataSource<T> |
DataStream v2 source that emit data from pre-provided data.
|
FSDataInputStream |
Interface for a data input stream to a file on a FileSystem .
|
FSDataInputStreamWrapper |
|
FSDataOutputStream |
An output stream to a file that is created via a FileSystem .
|
FSDataOutputStreamWrapper |
|
FunctionUtils |
Utility class that contains helper methods to work with Flink Function class.
|
FunctionUtils |
Utility class for Flink's functions.
|
FutureConsumerWithException<T,E extends Throwable> |
|
FutureTaskWithException<V> |
FutureTask that also implements RunnableWithException .
|
FutureUtils |
|
FutureUtils.ConjunctFuture<T> |
A future that is complete once multiple other futures completed.
|
FutureUtils.RetryException |
|
GatedRateLimiter |
An implementation of RateLimiter that completes defined number of futures in-between the
external notification events.
|
GenericArraySerializer<C> |
A serializer for arrays of objects.
|
GenericArraySerializerSnapshot<C> |
|
GenericCsvInputFormat<OT> |
|
GenericDataSinkBase<IN> |
Operator for nodes that act as data sinks, storing the data they receive.
|
GenericDataSourceBase<OUT,T extends InputFormat<OUT,?>> |
Abstract superclass for data sources in a Pact plan.
|
GenericDataSourceBase.SplitDataProperties<T> |
|
GenericInputFormat<OT> |
Generic base class for all Rich inputs that are not based on files.
|
GenericInputSplit |
A generic input split that has only a partition number.
|
GenericPairComparator<T1,T2> |
|
GenericTypeComparator<T extends Comparable<T>> |
TypeComparator for all types that extend Comparable.
|
GenericTypeInfo<T> |
|
GenericTypeSerializerSnapshot<T,S extends TypeSerializer> |
|
GlobalConfiguration |
Global configuration object for Flink.
|
GlobFilePathFilter |
Class for determining if a particular file should be included or excluded based on a set of
include and exclude glob filters.
|
GroupCombineFunction<IN,OUT> |
Generic interface used for combine functions ("combiners").
|
GroupCombineOperatorBase<IN,OUT,FT extends GroupCombineFunction<IN,OUT>> |
Base operator for the combineGroup transformation.
|
GroupReduceFunction<T,O> |
The interface for group reduce functions.
|
GroupReduceOperatorBase<IN,OUT,FT extends GroupReduceFunction<IN,OUT>> |
|
GuavaFlinkConnectorRateLimiter |
|
GuavaRateLimiter |
An implementation of RateLimiter based on Guava's RateLimiter.
|
GzipInflaterInputStreamFactory |
Factory for input streams that decompress the GZIP compression format.
|
HeartbeatManagerOptions |
The set of configuration options relating to heartbeat manager settings.
|
HighAvailabilityOptions |
The set of configuration options relating to high-availability settings.
|
Histogram |
Histogram accumulator, which builds a histogram in a distributed manner.
|
HistoryServerOptions |
The set of configuration options relating to the HistoryServer.
|
HtmlFormatter |
Formatter that transforms Description into Html representation.
|
ICloseableRegistry |
This class allows to register instances of Closeable , which are all closed if this
registry is closed.
|
IFileSystem |
Interface of all file systems used by Flink.
|
IgnoreShutdownRejectedExecutionHandler |
Rejected executions are ignored or logged in debug if the executor is shutdown .
|
IllegalConfigurationException |
An IllegalConfigurationException is thrown when the values in a given Configuration are not valid.
|
IncrementalDelayRetryStrategy |
An implementation of RetryStrategy that retries at an incremental delay with a cap.
|
IndexedCombinedWatermarkStatus |
Represents combined value and status of a watermark for a set number of input partial watermarks.
|
InflaterInputStreamFactory<T extends InputStream> |
|
IngestionTimeAssigner<T> |
A timestamp assigner that assigns timestamps based on the machine's wall clock.
|
InitContext |
|
InitializeOnMaster |
This interface may be implemented by OutputFormat s to have the master initialize them
globally.
|
InlineElement |
Part of description that represents an element inside a block e.g. a link.
|
InnerJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> |
|
InputFormat<OT,T extends InputSplit> |
The base interface for data sources that produces records.
|
InputSplit |
This interface must be implemented by all kind of input splits that can be assigned to input
formats.
|
InputSplitAssigner |
An input split assigner distributes the InputSplit s among the instances on which a data
source exists.
|
InputSplitSource<T extends InputSplit> |
|
InputStatus |
An InputStatus indicates the availability of data from an asynchronous input.
|
InputStreamFSInputWrapper |
|
InputTypeConfigurable |
OutputFormat s can implement this interface to be
configured with the data type they will operate on.
|
InstantComparator |
Comparator for comparing Java Instant.
|
InstantiationUtil |
Utility class to create instances from class objects and checking failure reasons.
|
InstantiationUtil.ClassLoaderObjectInputStream |
A custom ObjectInputStream that can load classes using a specific ClassLoader.
|
InstantiationUtil.FailureTolerantObjectInputStream |
|
InstantSerializer |
Serializer for serializing/deserializing Instant values including null values.
|
InstantSerializer.InstantSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
IntComparator |
|
IntCounter |
An accumulator that sums up Integer values.
|
IntegerTypeInfo<T> |
Type information for numeric integer primitive types: int, long, byte, short, character.
|
InternalCheckpointListener |
|
InternalStateFuture<T> |
The Internal definition of StateFuture , add some method that will be used by framework.
|
IntMaximum |
An accumulator that finds the maximum integer value.
|
IntMinimum |
An accumulator that finds the minimum integer value.
|
IntParser |
Parses a decimal text field into a IntValue.
|
IntPrimitiveArrayComparator |
|
IntPrimitiveArraySerializer |
A serializer for int arrays.
|
IntPrimitiveArraySerializer.IntPrimitiveArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
IntSerializer |
Type serializer for Integer (and int , via auto-boxing).
|
IntSerializer.IntSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
IntValue |
Boxed serializable and comparable integer type, representing the primitive type int .
|
IntValueComparator |
Specialized comparator for IntValue based on CopyableValueComparator.
|
IntValueParser |
Parses a decimal text field into a IntValue.
|
IntValueSerializer |
|
IntValueSerializer.IntValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
InvalidProgramException |
An exception thrown to indicate that the composed program is invalid.
|
InvalidTypesException |
A special case of the InvalidProgramException , indicating that the types used in an
operation are invalid or inconsistent.
|
IOReadableWritable |
This interface must be implemented by every class whose objects have to be serialized to their
binary representation and vice-versa.
|
IOUtils |
An utility class for I/O related functionality.
|
IterableIterator<E> |
|
IterableUtils |
A collection of utilities that expand the usage of Iterable .
|
IterationOperator |
|
IterationRuntimeContext |
A specialization of the RuntimeContext available in iterative computations of the DataSet
API.
|
IteratorSourceEnumerator<SplitT extends IteratorSourceSplit<?,?>> |
|
IteratorSourceReader<E,IterT extends Iterator<E>,SplitT extends IteratorSourceSplit<E,IterT>> |
|
IteratorSourceReaderBase<E,O,IterT extends Iterator<E>,SplitT extends IteratorSourceSplit<E,IterT>> |
|
IteratorSourceSplit<E,IterT extends Iterator<E>> |
A SourceSplit that represents a sequence of elements captured in an iterator.
|
JacksonMapperFactory |
Factory for Jackson mappers.
|
JarUtils |
Utility functions for jar files.
|
JavaEitherSerializerSnapshot<L,R> |
|
JavaSerializer<T> |
This is a reimplementation of Kryo's JavaSerializer , that additionally makes sure the ObjectInputStream used for deserialization specifically uses Kryo's registered classloader.
|
JavaToValueConverter |
|
JMXServerOptions |
The set of configuration options relating to JMX server.
|
JMXService |
Provide a JVM-wide singleton JMX Service.
|
JobClient |
A client that is scoped to a specific job.
|
JobEventStoreOptions |
Configuration options for the job events.
|
JobExecutionResult |
The result of a job execution.
|
JobExecutionStatusEvent |
Job execution status event.
|
JobID |
Unique (at least statistically unique) identifier for a Flink Job.
|
JobInfo |
The JobInfo represents the meta information of current job.
|
JobInfoImpl |
The default implementation of JobInfo .
|
JobListener |
A listener that is notified on specific job status changed, which should be firstly registered by
#registerJobListener of execution environments.
|
JobManagerOptions |
Configuration options for the JobManager.
|
JobManagerOptions.HybridPartitionDataConsumeConstraint |
Constraints of upstream hybrid partition data consumption by downstream.
|
JobManagerOptions.JobStoreType |
Type of job store implementation.
|
JobManagerOptions.SchedulerType |
Type of scheduler implementation.
|
JobStatus |
Possible states of a job once it has been accepted by the dispatcher.
|
JobStatusChangedEvent |
Basic job status event.
|
JobStatusChangedListener |
When job is created or its status is changed, Flink will generate job event and notify job status
changed listener.
|
JobStatusChangedListenerFactory |
Factory for job status changed listener.
|
JobStatusChangedListenerFactory.Context |
|
JobStatusChangedListenerUtils |
|
JobStatusHook |
Hooks on job status changing.
|
JobSubmissionResult |
The result of submitting a job to a JobManager.
|
JoinFunction<IN1,IN2,OUT> |
Interface for Join functions.
|
JoinHashMap<BT> |
|
JoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> |
|
JoinOperatorBase.JoinHint |
An enumeration of hints, optionally usable to tell the system how exactly execute the join.
|
Key<T> |
Deprecated.
|
KeyedStateStore |
This interface contains methods for registering keyed state with a managed store.
|
KeyFieldOutOfBoundsException |
An exception specifying that a required key field was not set in a record, i.e. was null
.
|
Keys<T> |
|
Keys.ExpressionKeys<T> |
Represents (nested) field access through string and integer-based keys
|
Keys.IncompatibleKeysException |
|
Keys.SelectorFunctionKeys<T,K> |
|
KryoRegistration |
A KryoRegistration resembles a registered class and its serializer in Kryo.
|
KryoRegistration.SerializerDefinitionType |
IMPORTANT: the order of the enumerations must not change, since their ordinals are used for
serialization.
|
KryoSerializer<T> |
A type serializer that serializes its type using the Kryo serialization framework
(https://github.com/EsotericSoftware/kryo).
|
KryoSerializerSnapshot<T> |
|
KryoUtils |
Convenience methods for Kryo
|
LambdaUtil |
This class offers utility functions for Java's lambda features.
|
LegacySerializerSnapshotTransformer<T> |
|
LimitedConnectionsFileSystem |
A file system that limits the number of concurrently open input streams, output streams, and
total streams for a target file system.
|
LimitedConnectionsFileSystem.ConnectionLimitingSettings |
A simple configuration data object capturing the settings for limited connections.
|
LimitedConnectionsFileSystem.StreamTimeoutException |
A special IOException, indicating a timeout in the data output stream.
|
LineBreakElement |
|
LinkedOptionalMap<K,V> |
A LinkedOptionalMap is an order preserving map (like LinkedHashMap ) where keys have a
unique string name, but are optionally present, and the values are optional.
|
LinkedOptionalMap.ConsumerWithException<K,V,E extends Throwable> |
|
LinkedOptionalMap.KeyValue<K,V> |
Key-value pairs stored by the underlying map.
|
LinkedOptionalMap.MergeResult<K,V> |
|
LinkedOptionalMapSerializer |
|
LinkElement |
|
ListAccumulator<T> |
This accumulator stores a collection of objects.
|
ListCollector<T> |
A Collector that puts the collected elements into a given list.
|
ListElement |
|
ListKeyGroupedIterator<E> |
The KeyValueIterator returns a key and all values that belong to the key (share the same key).
|
ListSerializer<T> |
|
ListSerializerSnapshot<T> |
|
ListStateDescriptor<T> |
|
ListTypeDescriptorImpl<T> |
|
ListTypeInfo<T> |
|
ListValue<V extends Value> |
Generic list base type for PACT programs that implements the Value and List interfaces.
|
LocalBlockLocation |
Implementation of the BlockLocation interface for a local file system.
|
LocalDataInputStream |
The LocalDataInputStream class is a wrapper class for a data input stream to the
local file system.
|
LocalDataOutputStream |
The LocalDataOutputStream class is a wrapper class for a data output stream to the
local file system.
|
LocalDateComparator |
This class can not extend BasicTypeComparator , because LocalDate is a Comparable of
ChronoLocalDate instead of Comparable of LocalDate.
|
LocalDateSerializer |
|
LocalDateSerializer.LocalDateSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
LocalDateTimeComparator |
This class can not extend BasicTypeComparator , because LocalDateTime is a Comparable of
ChronoLocalDateTime instead of Comparable of LocalDateTime.
|
LocalDateTimeSerializer |
|
LocalDateTimeSerializer.LocalDateTimeSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
LocalFileStatus |
The class LocalFileStatus provides an implementation of the FileStatus
interface for the local file system.
|
LocalFileSystem |
The class LocalFileSystem is an implementation of the FileSystem interface for
the local file system of the machine where the JVM runs.
|
LocalFileSystemFactory |
|
LocalRecoverableFsDataOutputStream |
|
LocalRecoverableWriter |
|
LocalTimeComparator |
|
LocalTimeSerializer |
|
LocalTimeSerializer.LocalTimeSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
LocalTimeTypeInfo<T extends Temporal> |
Type information for Java LocalDate/LocalTime/LocalDateTime.
|
LocatableInputSplit |
A locatable input split is an input split referring to input data which is located on one or more
hosts.
|
LocatableInputSplitAssigner |
The locatable input split assigner assigns to each host splits that are local, before assigning
splits that are not local.
|
LocatedFileStatus |
A LocatedFileStatus is a FileStatus that contains additionally the location
information of the file directly.
|
LongComparator |
|
LongCounter |
An accumulator that sums up long values.
|
LongMaximum |
An accumulator that finds the maximum long value.
|
LongMinimum |
An accumulator that finds the minimum long value.
|
LongParser |
Parses a decimal text field into a LongValue.
|
LongPrimitiveArrayComparator |
|
LongPrimitiveArraySerializer |
A serializer for long arrays.
|
LongPrimitiveArraySerializer.LongPrimitiveArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
LongSerializer |
Type serializer for Long .
|
LongSerializer.LongSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
LongSumAggregator |
|
LongValue |
Boxed serializable and comparable long integer type, representing the primitive type
long .
|
LongValueComparator |
Specialized comparator for LongValue based on CopyableValueComparator.
|
LongValueParser |
Parses a decimal text field into a LongValue.
|
LongValueSequenceIterator |
The LongValueSequenceIterator is an iterator that returns a sequence of numbers (as
LongValue )s.
|
LongValueSerializer |
|
LongValueSerializer.LongValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
LongZeroConvergence |
|
MailboxExecutor |
Executor like interface for a build around a mailbox-based execution
model.
|
MailboxExecutor.MailOptions |
Extra options to configure enqueued mails.
|
MailOptionsImpl |
Options to configure behaviour of executing mailbox mails.
|
ManagedMemoryUseCase |
Use cases of managed memory.
|
ManagedMemoryUseCase.Scope |
Scope at which memory is managed for a use case.
|
ManualClock |
A Clock implementation which allows to advance time manually.
|
MapFunction<T,O> |
Base interface for Map functions.
|
MapOperatorBase<IN,OUT,FT extends MapFunction<IN,OUT>> |
|
MapPartitionFunction<T,O> |
Interface for "mapPartition" functions.
|
MapPartitionOperatorBase<IN,OUT,FT extends MapPartitionFunction<IN,OUT>> |
|
MapSerializer<K,V> |
|
MapSerializerSnapshot<K,V> |
|
MapStateDescriptor<UK,UV> |
|
MapTypeDescriptorImpl<K,V> |
Implementation of TypeDescriptor to create MapTypeInfo .
|
MapTypeInfo<K,V> |
|
MapValue<K extends Value,V extends Value> |
Generic map base type for PACT programs that implements the Value and Map interfaces.
|
MaskUtils |
Utilities for reading and writing binary masks.
|
MathUtils |
Collection of simple mathematical routines.
|
MdcUtils |
Utility class to manage common Flink attributes in MDC (only JobID ATM).
|
MdcUtils.MdcCloseable |
|
MemorySegment |
This class represents a piece of memory managed by Flink.
|
MemorySegmentFactory |
|
MemorySegmentInputStreamWithPos |
Un-synchronized input stream using the given memory segment.
|
MemorySegmentProvider |
The provider used for requesting and releasing batch of memory segments.
|
MemorySegmentSource |
Interface describing entities that can provide memory segments.
|
MemorySegmentWritable |
Provides the interface for write(Segment).
|
MemoryUtils |
Utility class for memory operations.
|
MetricOptions |
Configuration options for metrics and metric reporters.
|
MetricOptions.JobStatusMetrics |
Enum describing the different kinds of job status metrics.
|
MetricOptions.JobStatusMetricsSettings |
Describes which job status metrics have been enabled.
|
MissingTypeInfo |
A special type information signifying that the type extraction failed.
|
MultipleParameterTool |
This class provides simple utility methods for reading and parsing program arguments from
different sources.
|
MultisetTypeInfo<T> |
|
MutableObjectIterator<E> |
A simple iterator interface.
|
MutableURLClassLoader |
URL class loader that exposes the `addURL` method in URLClassLoader.
|
NestedSerializersSnapshotDelegate |
A NestedSerializersSnapshotDelegate represents the snapshots of multiple serializers that are
used by an outer serializer.
|
NettyShuffleEnvironmentOptions |
The set of configuration options relating to network stack.
|
NettyShuffleEnvironmentOptions.CompressionCodec |
Supported compression codec.
|
NetUtils |
Utility for various network related tasks (such as finding free ports).
|
NetUtils.Port |
Port wrapper class which holds a FileLock until it releases.
|
NetUtils.SocketFactory |
A factory for a local socket from port number.
|
NeverCompleteFuture |
A future that never completes.
|
NoFetchingInput |
|
NonParallelInput |
This interface acts as a marker for input formats for inputs which cannot be split.
|
NonSerializableUserCodeException |
An special case of the InvalidProgramException , indicating that a part of the program
that needs to be serializable (for shipping) is not serializable.
|
NoOpFunction |
|
NoOpRateLimiter |
A convenience implementation of RateLimiter that does not throttle requests.
|
NormalizableKey<T> |
The base interface for normalizable keys.
|
NormalizedKeyUtil |
|
Nothing |
A type for (synthetic) operators that do not output data.
|
NothingTypeInfo |
Placeholder type information for the Nothing type.
|
NoWatermarksGenerator<E> |
|
NullableSerializer<T> |
Serializer wrapper to add support of null value serialization.
|
NullableSerializer.NullableSerializerSnapshot<T> |
Snapshot for serializers of nullable types, containing the snapshot of its original
serializer.
|
NullAwareComparator<T> |
Null-aware comparator that wraps a comparator which does not support null references.
|
NullByteKeySelector<T> |
Used as a dummy KeySelector to allow using keyed operators for non-keyed use cases.
|
NullKeyFieldException |
An exception specifying that a required key field was not set in a record, i.e. was null
.
|
NullValue |
Null base type for programs that implements the Key interface.
|
NullValueComparator |
Specialized comparator for NullValue based on CopyableValueComparator.
|
NullValueSerializer |
|
NullValueSerializer.NullValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
NumberSequenceIterator |
The NumberSequenceIterator is an iterator that returns a sequence of numbers (as
Long )s.
|
NumberSequenceSource |
A data source that produces a sequence of numbers (longs).
|
NumberSequenceSource.NumberSequenceSplit |
A split of the source, representing a number sub-sequence.
|
NumericTypeInfo<T> |
Type information for numeric primitive types: int, long, double, byte, short, float, char.
|
ObjectArrayTypeInfo<T,C> |
|
OffsetAwareOutputStream |
|
OpenContext |
|
OperatingSystem |
An enumeration indicating the operating system that the JVM runs on.
|
Operator<OUT> |
Abstract base class for all operators.
|
OperatorInformation<OUT> |
A class for holding information about an operator, such as input/output TypeInformation.
|
OperatorStateStore |
This interface contains methods for registering operator state with a managed store.
|
OperatorValidationUtils |
Utils for checking operators' resource and parallelism settings.
|
OptimizerOptions |
Configuration options for the optimizer.
|
OptionalConsumer<T> |
Utility class which allows to run code depending on whether the optional has a value or is empty.
|
OptionalFailure<T> |
Wrapper around an object representing either a success (with a given value) or a failure cause.
|
OptionalUtils |
|
Order |
Enumeration representing order.
|
Ordering |
This class represents an ordering on a set of fields.
|
OuterJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> |
|
OuterJoinOperatorBase.OuterJoinType |
|
OutputFormat<IT> |
The base interface for outputs that consumes records.
|
OutputFormat.InitializationContext |
The context exposes some runtime info for initializing output format.
|
OutputFormatBase<OUT,V> |
OutputFormatBase is the common abstract class for output formats.
|
OutputStreamAndPath |
An output stream and a path.
|
OutputTag<T> |
An OutputTag is a typed and named tag to use for tagging side outputs of an operator.
|
OutputTypeConfigurable<OUT> |
Stream operators can implement this interface if they need access to the output type information
at org.apache.flink.streaming.api.graph.StreamGraph generation.
|
ParameterTool |
This class provides simple utility methods for reading and parsing program arguments from
different sources.
|
ParseException |
Exception indicating that the parsing of input contents has failed because the data does not
match the configured parser.
|
Partitioner<K> |
Function to implement a custom partition assignment for keys.
|
PartitionOperatorBase<IN> |
|
PartitionOperatorBase.PartitionMethod |
|
Path |
|
PathsCopyingFileSystem |
|
PathsCopyingFileSystem.CopyRequest |
A pair of source and destination to duplicate a file.
|
Pipeline |
Common interface for Flink pipelines.
|
PipelineExecutor |
The entity responsible for executing a Pipeline , i.e. a user job.
|
PipelineExecutorFactory |
|
PipelineExecutorServiceLoader |
An interface to be implemented by the entity responsible for finding the correct PipelineExecutor to execute a given Pipeline .
|
PipelineOptions |
|
PipelineOptions.VertexDescriptionMode |
The mode how we organize description of a vertex.
|
PipelineOptionsInternal |
Pipeline options that are not meant to be used by the user.
|
Plan |
This class represents Flink programs, in the form of dataflow plans.
|
Plugin |
Interface for plugins.
|
PluginConfig |
Stores the configuration for plugins mechanism.
|
PluginDescriptor |
Descriptive meta information for a plugin.
|
PluginFileSystemFactory |
|
PluginFinder |
Implementations of this interface provide mechanisms to locate plugins and create corresponding
PluginDescriptor objects.
|
PluginLoader |
|
PluginManager |
PluginManager is responsible for managing cluster plugins which are loaded using separate class
loaders so that their dependencies don't interfere with Flink's dependencies.
|
PluginUtils |
Utility functions for the plugin mechanism.
|
PojoComparator<T> |
|
PojoField |
Represent a field definition for PojoTypeInfo type of objects.
|
PojoSerializer<T> |
|
PojoSerializerSnapshot<T> |
|
PojoTypeInfo<T> |
TypeInformation for "Java Beans"-style types.
|
PojoTypeInfo.NamedFlatFieldDescriptor |
|
PortRange |
Represents a port range and provides access to an iterator of the given range.
|
PostVersionedIOReadableWritable |
|
Preconditions |
A collection of static utility methods to validate input.
|
PrimitiveArrayComparator<T,C extends BasicTypeComparator> |
|
PrimitiveArrayTypeInfo<T> |
|
PrintSinkOutputWriter<IN> |
Print sink output writer for DataStream and DataSet print API.
|
ProcessingTimeService |
|
ProcessingTimeService.ProcessingTimeCallback |
|
ProcessorArchitecture |
The processor architecture of the this system.
|
ProcessorArchitecture.MemoryAddressSize |
The memory address size of the processor.
|
ProgramDescription |
Implementing this interface allows a Program to have a description of the plan which can be shown
to the user.
|
PropertiesUtil |
Simple utilities for getting typed values from Properties.
|
QueryableStateOptions |
Deprecated.
|
RangeBoundaries<T> |
RangeBoundaries is used to split the records into multiple ranges.
|
RateLimitedSourceReader<E,SplitT extends SourceSplit> |
Wraps the actual SourceReader and rate limits its data emission.
|
RateLimiter |
The interface to rate limit execution of methods.
|
RateLimiterStrategy |
A factory for RateLimiters which apply rate-limiting to a source sub-task.
|
ReadableConfig |
Read access to a configuration object.
|
ReaderInfo |
A container class hosting the information of a SourceReader .
|
ReaderOutput<T> |
The interface provided by the Flink runtime to the SourceReader to emit records, and
optionally watermarks, to downstream operators for message processing.
|
Record |
The Record represents a multi-valued data record.
|
RecordTimestampAssigner<E> |
|
RecoverableFsDataOutputStream |
An output stream to a file system that can be recovered at well defined points.
|
RecoverableFsDataOutputStream.Committer |
A committer can publish the file of a stream that was closed.
|
RecoverableWriter |
|
RecoverableWriter.CommitRecoverable |
A handle to an in-progress stream with a defined and persistent amount of data.
|
RecoverableWriter.ResumeRecoverable |
A handle to an in-progress stream with a defined and persistent amount of data.
|
RecoveryClaimMode |
Defines state files ownership when Flink restore from a given savepoint or retained checkpoint.
|
ReduceOperatorBase<T,FT extends org.apache.flink.api.common.functions.ReduceFunction<T>> |
Base data flow operator for Reduce user-defined functions.
|
ReduceOperatorBase.CombineHint |
An enumeration of hints, optionally usable to tell the system exactly how to execute the
combiner phase of a reduce.
|
ReducingStateDescriptor<T> |
|
RefCounted |
Interface to simply add reference counting functionality.
|
RefCountedBufferingFileStream |
|
RefCountedFile |
A reference counted file which is deleted as soon as no caller holds a reference to the wrapped
File .
|
RefCountedFileWithStream |
A reference counted file which is deleted as soon as no caller holds a reference to the wrapped
File .
|
RefCountedFSOutputStream |
|
RefCountedTmpFileCreator |
|
Reference<T> |
Wrapper class that allows to express whether the value is borrowed or owned.
|
ReflectionUtil |
Utility for reflection operations on classes and generic type parametrization.
|
ReflectionUtil.FullTypeInfo |
Container for the full type information of a type.
|
RelativeClock |
A clock that gives access to relative time, similar to System#nanoTime(), however the progress of
the relative time doesn't have to reflect the progress of a wall clock.
|
ReplicatingInputFormat<OT,S extends InputSplit> |
A ReplicatingInputFormat replicates any InputFormat to all parallel instances of a
DataSource, i.e., the full input of the replicated InputFormat is completely processed by each
parallel instance of the DataSource.
|
ReplicatingInputSplitAssigner |
Assigns each InputSplit to each requesting parallel instance.
|
ResettableValue<T extends Value> |
|
Resource<T extends Resource<T>> |
Base class for resources one can specify.
|
ResourceGuard |
This class is a guard for shared resources with the following invariants.
|
ResourceManagerOptions |
The set of configuration options relating to the ResourceManager.
|
ResourceSpec |
Describe the different resource factors of the operator with UDF.
|
ResourceSpec.Builder |
|
RestartStrategyDescriptionUtils |
Utility class for describing restart strategies.
|
RestartStrategyOptions |
Config options for restart strategies.
|
RestartStrategyOptions.RestartStrategyType |
The restart strategy type.
|
RestOptions |
Configuration parameters for REST communication.
|
ResultTypeQueryable<T> |
This interface can be implemented by functions and input formats to tell the framework about
their produced data type.
|
RetryStrategy |
Interface that encapsulates retry logic.
|
RichAggregateFunction<IN,ACC,OUT> |
Rich variant of the AggregateFunction .
|
RichCoGroupFunction<IN1,IN2,OUT> |
|
RichCrossFunction<IN1,IN2,OUT> |
|
RichFilterFunction<T> |
|
RichFlatJoinFunction<IN1,IN2,OUT> |
|
RichFlatMapFunction<IN,OUT> |
|
RichFunction |
An base interface for all rich user-defined functions.
|
RichGroupCombineFunction<IN,OUT> |
|
RichGroupReduceFunction<IN,OUT> |
|
RichInputFormat<OT,T extends InputSplit> |
An abstract stub implementation for Rich input formats.
|
RichJoinFunction<IN1,IN2,OUT> |
|
RichMapFunction<IN,OUT> |
|
RichMapPartitionFunction<I,O> |
|
RichOutputFormat<IT> |
An abstract stub implementation for Rich output formats.
|
RichReduceFunction<T> |
Rich variant of the ReduceFunction .
|
Row |
A row is a fixed-length, null-aware composite type for storing multiple values in a deterministic
field order.
|
RowComparator |
|
RowKind |
Lists all kinds of changes that a row can describe in a changelog.
|
RowSerializer |
|
RowSerializer.RowSerializerSnapshot |
|
RowTypeInfo |
|
RowUtils |
Utilities to deal with Row instances.
|
RpcOptions |
RPC configuration options.
|
RuntimeComparatorFactory<T> |
|
RuntimeContext |
A RuntimeContext contains information about the context in which functions are executed.
|
RuntimeContextInitializationContextAdapters |
|
RuntimePairComparatorFactory<T1,T2> |
|
RuntimeSerializerFactory<T> |
|
RuntimeUDFContext |
A standalone implementation of the RuntimeContext , created by runtime UDF operators.
|
SafetyNetCloseableRegistry |
|
SafetyNetWrapperFileSystem |
|
SameTypePairComparator<T> |
|
SavepointFormatType |
Describes the binary format in which a savepoint should be taken.
|
ScheduledExecutor |
Extension for the Executor interface which is enriched by method for scheduling tasks in
the future.
|
ScheduledExecutorServiceAdapter |
|
SchedulerExecutionMode |
Enum for controlling whether REACTIVE mode is enabled or not.
|
SecurityOptions |
The set of configuration options relating to security.
|
SeekableDataInputView |
|
SeekableDataOutputView |
|
SemanticProperties |
Container for the semantic properties associated to an operator.
|
SemanticProperties.EmptySemanticProperties |
|
SemanticProperties.InvalidSemanticAnnotationException |
|
SeparateThreadExecutor |
An Executor that runs every runnable in a separate thread.
|
SerializableObject |
A simple object that only implements Serializable , so it can be used in
serializable classes.
|
SerializableOptional<T extends Serializable> |
|
SerializableSerializer<T extends com.esotericsoftware.kryo.Serializer<?> & Serializable> |
The wrapper to make serializer serializable.
|
SerializableTimestampAssigner<T> |
|
SerializationSchema<T> |
The serialization schema describes how to turn a data object into a different serialized
representation.
|
SerializationSchema.InitializationContext |
|
SerializedInputFormat<T extends IOReadableWritable> |
Reads elements by deserializing them with their regular serialization/deserialization
functionality.
|
SerializedListAccumulator<T> |
This accumulator stores a collection of objects in serialized form, so that the stored objects
are not affected by modifications to the original objects.
|
SerializedOutputFormat<T extends IOReadableWritable> |
Stores elements by serializing them with their regular serialization/deserialization
functionality.
|
SerializedThrowable |
Utility class for dealing with user-defined Throwable types that are serialized (for example
during RPC/Actor communication), but cannot be resolved with the default class loader.
|
SerializedValue<T> |
This class is used to transfer (via serialization) objects whose classes are not available in the
system class loader.
|
SerializerConfig |
A config to define the behavior for serializers in Flink job, it manages the registered types and
serializers.
|
SerializerConfigImpl |
|
SerializerFactory |
|
Serializers |
Class containing utilities for the serializers of the Flink Runtime.
|
Serializers.DummyAvroKryoSerializerClass<T> |
This is used in case we don't have Avro on the classpath.
|
Serializers.DummyAvroRegisteredClass |
This is used in case we don't have Avro on the classpath.
|
Serializers.SpecificInstanceCollectionSerializer<T extends Collection> |
Special serializer for Java collections enforcing certain instance types.
|
Serializers.SpecificInstanceCollectionSerializerForArrayList |
Special serializer for Java's ArrayList used for Avro's GenericData.Array.
|
ShortComparator |
|
ShortParser |
Parses a decimal text field into a Short .
|
ShortPrimitiveArrayComparator |
|
ShortPrimitiveArraySerializer |
A serializer for short arrays.
|
ShortPrimitiveArraySerializer.ShortPrimitiveArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
ShortSerializer |
Type serializer for Byte .
|
ShortSerializer.ShortSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
ShortValue |
Boxed serializable and comparable short integer type, representing the primitive type
short .
|
ShortValueComparator |
Specialized comparator for ShortValue based on CopyableValueComparator.
|
ShortValueParser |
|
ShortValueSerializer |
|
ShortValueSerializer.ShortValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
ShutdownHookUtil |
Utils class for dealing with JVM shutdown hooks.
|
SimpleAccumulator<T extends Serializable> |
Similar to Accumulator, but the type of items to add and the result value must be the same.
|
SimpleStringEncoder<IN> |
A simple Encoder that uses toString() on the input elements and writes them to
the output bucket file separated by newline.
|
SimpleStringSchema |
Very simple serialization schema for strings.
|
SimpleTypeSerializerSnapshot<T> |
A simple base class for TypeSerializerSnapshots, for serializers that have no parameters.
|
SimpleUserCodeClassLoader |
Simple UserCodeClassLoader implementation which assumes that the provided class loader
will never be released and, hence, will never execute the release hooks.
|
SimpleVersionedSerialization |
|
SimpleVersionedSerializer<E> |
A simple serializer interface for versioned serialization.
|
SimpleVersionedSerializerAdapter<T> |
|
SimpleVersionedSerializerTypeSerializerProxy<T> |
|
SingleInputOperator<IN,OUT,FT extends org.apache.flink.api.common.functions.Function> |
Abstract superclass for all operators that have one input like "map" or "reduce".
|
SingleInputSemanticProperties |
Container for the semantic properties associated to a single input operator.
|
SingleInputSemanticProperties.AllFieldsForwardedProperties |
|
SingleThreadAccessCheckingTypeSerializer<T> |
|
SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot<T> |
|
Sink<InputT> |
Base interface for developing a sink.
|
SinkUtils |
Utility class for sinks.
|
SinkWriter<InputT> |
The SinkWriter is responsible for writing data.
|
SinkWriter.Context |
|
SlotSharingGroup |
Describe the name and the different resource components of a slot sharing group.
|
SlotSharingGroup.Builder |
|
SlotSharingGroupUtils |
|
SlowTaskDetectorOptions |
Configuration options to detect slow tasks.
|
SortPartitionOperatorBase<IN> |
|
Source<T,SplitT extends SourceSplit,EnumChkT> |
The interface for Source.
|
SourceEvent |
An base class for the events passed between the SourceReaders and Enumerators.
|
SourceOutput<T> |
The SourceOutput is the gateway for a SourceReader ) to emit the produced records
and watermarks.
|
SourceReader<T,SplitT extends SourceSplit> |
The interface for a source reader which is responsible for reading the records from the source
splits assigned by SplitEnumerator .
|
SourceReaderContext |
The interface that exposes some context from runtime to the SourceReader .
|
SourceReaderFactory<T,SplitT extends SourceSplit> |
A factory for creating source reader instances.
|
SourceSplit |
An interface for all the Split types to extend.
|
SplitEnumerator<SplitT extends SourceSplit,CheckpointT> |
The interface for a split enumerator responsible for discovering the source splits, and assigning
them to the SourceReader .
|
SplitEnumeratorContext<SplitT extends SourceSplit> |
|
SplitsAssignment<SplitT extends SourceSplit> |
A class containing the splits assignment to the source readers.
|
SplittableIterator<T> |
Abstract base class for iterators that can split themselves into multiple disjoint iterators.
|
SqlDateParser |
Parses a text field into a Date .
|
SqlDateSerializer |
|
SqlDateSerializer.SqlDateSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
SqlTimeParser |
Parses a text field into a Time .
|
SqlTimeSerializer |
|
SqlTimeSerializer.SqlTimeSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
SqlTimestampComparator |
Comparator for comparing Java SQL Timestamps.
|
SqlTimestampParser |
|
SqlTimestampSerializer |
|
SqlTimestampSerializer.SqlTimestampSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
SqlTimeTypeInfo<T> |
Type information for Java SQL Date/Time/Timestamp.
|
StateBackendOptions |
A collection of all configuration options that relate to state backend.
|
StateChangelogOptions |
A collection of all configuration options that relate to changelog.
|
StateDescriptor<S extends org.apache.flink.api.common.state.State,T> |
Base class for state descriptors.
|
StateDescriptor.Type |
An enumeration of the types of supported states.
|
StatefulSinkWriter<InputT,WriterStateT> |
A SinkWriter whose state needs to be checkpointed.
|
StateFutureImpl<T> |
The default implementation of StateFuture .
|
StateFutureImpl.AsyncFrameworkExceptionHandler |
Handle exceptions thrown by async state callback framework.
|
StateFutureImpl.CallbackRunner |
The entry for a state future to submit task to mailbox.
|
StateFutureUtils |
A collection of utilities that expand the usage of StateFuture .
|
StateLatencyTrackOptions |
A collection of all configuration options that relate to the latency tracking for state access.
|
StateMigrationException |
Base class for state migration related exceptions.
|
StateRecoveryOptions |
|
StateTtlConfig |
Configuration of state TTL logic.
|
StateTtlConfig.Builder |
|
StateTtlConfig.CleanupStrategies |
TTL cleanup strategies.
|
StateTtlConfig.IncrementalCleanupStrategy |
Configuration of cleanup strategy while taking the full snapshot.
|
StateTtlConfig.RocksdbCompactFilterCleanupStrategy |
Configuration of cleanup strategy using custom compaction filter in RocksDB.
|
StateTtlConfig.StateVisibility |
This option configures whether expired user value can be returned or not.
|
StateTtlConfig.TtlTimeCharacteristic |
This option configures time scale to use for ttl.
|
StateTtlConfig.UpdateType |
This option value configures when to update last access timestamp which prolongs state TTL.
|
StringArraySerializer |
A serializer for String arrays.
|
StringArraySerializer.StringArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
StringBasedID |
Base class for typed IDs that are internally represented by a string.
|
StringComparator |
|
StringParser |
Converts a variable length field of a byte array into a String .
|
StringSerializer |
Type serializer for String .
|
StringSerializer.StringSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
StringUtils |
Utility class to convert objects into strings in vice-versa.
|
StringValue |
Mutable string data type that implements the Key interface.
|
StringValueComparator |
Specialized comparator for StringValue based on CopyableValueComparator.
|
StringValueParser |
Converts a variable length field of a byte array into a StringValue .
|
StringValueSerializer |
|
StringValueSerializer.StringValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
StringValueUtils |
|
StringValueUtils.WhitespaceTokenizer |
A tokenizer for string values that uses whitespace characters as token delimiters.
|
SubmoduleClassLoader |
Loads all classes from the submodule jar, except for explicitly white-listed packages.
|
SupportsBatchSnapshot |
|
SupportsCommitter<CommittableT> |
A mixin interface for a Sink which supports exactly-once semantics using a two-phase
commit protocol.
|
SupportsConcurrentExecutionAttempts |
The interface indicates that it supports multiple attempts executing at the same time.
|
SupportsHandleExecutionAttemptSourceEvent |
|
SupportsIntermediateNoMoreSplits |
|
SupportsWriterState<InputT,WriterStateT> |
|
SupportsWriterState.WithCompatibleState |
A mix-in for SupportsWriterState that allows users to migrate from a sink with a
compatible state to this sink.
|
SystemClock |
A clock that returns the time of the system / process.
|
TaskInfo |
The TaskInfo represents the meta information of current task.
|
TaskInfoImpl |
|
TaskManagerExceptionUtils |
Exception utils to handle and enrich exceptions occurring in TaskManager.
|
TaskManagerOptions |
The set of configuration options relating to TaskManager and Task settings.
|
TaskManagerOptions.SystemOutMode |
|
TaskManagerOptions.TaskManagerLoadBalanceMode |
|
TaskManagerOptionsInternal |
TaskManager options that are not meant to be used by the user.
|
TemporaryClassLoaderContext |
Sets a context class loader in a "try-with-resources" pattern.
|
TernaryBoolean |
A ternary boolean, which can have the values 'true', 'false', or 'undefined'.
|
TextElement |
|
TextElement.TextStyle |
Styles that can be applied to TextElement e.g. code, bold etc.
|
ThreadUtils |
ThreadUtils collects helper methods in the context of threading.
|
ThrowableCatchingRunnable |
This class catches all the Throwables from the wrapped runnable.
|
TimestampAssigner<T> |
A TimestampAssigner assigns event time timestamps to elements.
|
TimestampAssignerSupplier<T> |
|
TimestampAssignerSupplier.Context |
|
TimestampAssignerSupplier.SupplierFromSerializableTimestampAssigner<T> |
We need an actual class.
|
TimeUtils |
Collection of utilities about time intervals.
|
TraceOptions |
Configuration options for traces and trace reporters.
|
Transformation<T> |
A Transformation represents the operation that creates a DataStream.
|
TraversableOnceException |
An exception, indicating that an Iterable can only be traversed once, but has
been attempted to traverse an additional time.
|
Tuple0Serializer |
|
Tuple0SerializerSnapshot |
|
TupleComparator<T extends org.apache.flink.api.java.tuple.Tuple> |
|
TupleComparatorBase<T> |
|
TupleSerializer<T extends org.apache.flink.api.java.tuple.Tuple> |
|
TupleSerializerBase<T> |
|
TupleSerializerSnapshot<T extends org.apache.flink.api.java.tuple.Tuple> |
Snapshot of a tuple serializer's configuration.
|
TupleTypeInfo<T extends org.apache.flink.api.java.tuple.Tuple> |
|
TupleTypeInfoBase<T> |
|
TupleUnwrappingIterator<T,K> |
An iterator that reads 2-tuples (key value pairs) and returns only the values (second field).
|
TypeComparable<T> |
Wrapper that is used to store elements for which we have a TypeComparator in a Hash Map.
|
TypeComparator<T> |
This interface describes the methods that are required for a data type to be handled by the pact
runtime.
|
TypeComparatorFactory<T> |
|
TypeExtractionException |
Type extraction always contains some uncertainty due to unpredictable JVM differences between
vendors or versions.
|
TypeExtractionUtils |
|
TypeExtractionUtils.LambdaExecutable |
Similar to a Java 8 Executable but with a return type.
|
TypeExtractor |
A utility for reflection analysis on classes, to determine the return type of implementations of
transformation functions.
|
TypeHint<T> |
A utility class for describing generic types.
|
TypeInfo |
|
TypeInfoFactory<T> |
Base class for implementing a type information factory.
|
TypeInformation<T> |
TypeInformation is the core class of Flink's type system.
|
TypeInformationSerializationSchema<T> |
A serialization and deserialization schema that uses Flink's serialization stack to transform
typed from and to byte arrays.
|
TypePairComparator<T1,T2> |
This interface defines the method required by the runtime to use data types in join-like
operations.
|
TypePairComparatorFactory<T1,T2> |
|
Types |
This class gives access to the type information of the most common types for which Flink has
built-in serializers and comparators.
|
TypeSerializer<T> |
This interface describes the methods that are required for a data type to be handled by the Flink
runtime.
|
TypeSerializerFactory<T> |
|
TypeSerializerSchemaCompatibility<T> |
A TypeSerializerSchemaCompatibility represents information about whether or not a TypeSerializer can be safely used to read data written by a previous type serializer.
|
TypeSerializerSingleton<T> |
|
TypeSerializerSnapshot<T> |
A TypeSerializerSnapshot is a point-in-time view of a TypeSerializer 's
configuration.
|
TypeSerializerSnapshotSerializationUtil |
|
TypeSerializerUtils |
|
UnaryOperatorInformation<IN,OUT> |
A class for holding information about a single input operator, such as input/output
TypeInformation.
|
Union<T> |
This operator represents a Union between two inputs.
|
UnionIterator<T> |
An iterator that concatenates a collection of iterators.
|
UnloadableDummyTypeSerializer<T> |
|
UnmodifiableConfiguration |
Unmodifiable version of the Configuration class.
|
UnsupportedFileSystemSchemeException |
An exception to indicate that a specific file system scheme is not supported.
|
UserCodeClassLoader |
UserCodeClassLoader allows to register release hooks for a user code class loader.
|
UserCodeClassWrapper<T> |
This holds a class containing user defined code.
|
UserCodeObjectWrapper<T> |
This holds an actual object containing user defined code.
|
UserCodeWrapper<T> |
UDf operators can have either a class or an object containing the user code, this is the common
interface to access them.
|
UserSystemExitException |
Indicates that user tried to exit JVM.
|
Utils |
Utility class that contains helper methods to work with Java APIs.
|
Utils.ChecksumHashCode |
|
Utils.ChecksumHashCodeHelper<T> |
|
Utils.CollectHelper<T> |
Utility sink function that collects elements into an accumulator, from which it they can be
retrieved by the client.
|
Utils.CountHelper<T> |
Utility sink function that counts elements and writes the count into an accumulator, from
which it can be retrieved by the client.
|
Value |
Basic value interface for types that act as serializable values.
|
ValueComparator<T extends Value & Comparable<T>> |
Comparator for all Value types that extend Key
|
ValueSerializer<T extends Value> |
Serializer for Value types.
|
ValueSerializer.ValueSerializerSnapshot<T extends Value> |
|
ValueStateDescriptor<T> |
|
ValueTypeDescriptorImpl<T extends Value> |
|
ValueTypeInfo<T extends Value> |
Type information for data types that extend the Value interface.
|
Versioned |
This interface is implemented by classes that provide a version number.
|
VersionedIOReadableWritable |
This is the abstract base class for IOReadableWritable which allows to differentiate
between serialization versions.
|
VersionMismatchException |
This exception signals that incompatible versions have been found during serialization.
|
Visitable<T extends Visitable<T>> |
This interface marks types as visitable during a traversal.
|
Visitor<T extends Visitable<T>> |
A visitor encapsulates functionality that is applied to each node in the process of a traversal
of a tree or DAG.
|
VoidSerializer |
Serializer for Void .
|
VoidSerializer.VoidSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
Watermark |
Watermarks are the progress indicators in the data streams.
|
WatermarkAlignmentParams |
Configuration parameters for watermark alignment.
|
WatermarkGenerator<T> |
The WatermarkGenerator generates watermarks either based on events or periodically (in a
fixed interval).
|
WatermarkGeneratorSupplier<T> |
|
WatermarkGeneratorSupplier.Context |
|
WatermarkOutput |
An output for watermarks.
|
WatermarkOutputMultiplexer |
|
WatermarkOutputMultiplexer.WatermarkUpdateListener |
A callback for propagating changes to split based watermarks.
|
WatermarkStrategy<T> |
The WatermarkStrategy defines how to generate Watermark s in the stream sources.
|
WatermarksWithIdleness<T> |
A WatermarkGenerator that adds idleness detection to another WatermarkGenerator.
|
WebOptions |
Configuration options for the WebMonitorEndpoint.
|
WithConfigurationOpenContext |
A special OpenContext for passing configuration to udf.
|
WrappedSink<T> |
A simple Sink implementation that wrap a sink-v2 based sink.
|
WrappedSource<T> |
A simple Source implementation that wrap a FLIP-27 source.
|
WrappingFunction<T extends org.apache.flink.api.common.functions.Function> |
Wrapper around Function .
|
WrappingProxy<T> |
Interface for objects that wrap another object and proxy (possibly a subset) of the methods of
that object.
|
WrappingProxyCloseable<T extends Closeable> |
|
WrappingProxyUtil |
|
WrappingRuntimeException |
A runtime exception that is explicitly used to wrap non-runtime exceptions.
|
WritableConfig |
Write access to a configuration object.
|
WriterInitContext |
The interface exposes some runtime info for creating a SinkWriter .
|
XORShiftRandom |
Implement a random number generator based on the XORShift algorithm discovered by George
Marsaglia.
|
XZInputStreamFactory |
Factory for XZ decompressors.
|
YamlParserUtils |
This class contains utility methods to load standard yaml file and convert object to standard
yaml syntax.
|
ZStandardInputStreamFactory |
Factory for ZStandard decompressors.
|