All Classes Interface Summary Class Summary Enum Summary Exception Summary Error Summary Annotation Types Summary
Class |
Description |
AbstractAccessExecutionGraphHandler<R extends ResponseBody,M extends JobMessageParameters> |
AbstractAccessExecutionGraphHandler handles requests that require accessing the job's
AccessExecutionGraph .
|
AbstractAggregatedMetricsHeaders<P extends AbstractAggregatedMetricsParameters<?>> |
|
AbstractAggregatedMetricsParameters<M extends MessageQueryParameter<?>> |
|
AbstractAggregatingMetricsHandler<P extends AbstractAggregatedMetricsParameters<?>> |
Abstract request handler for querying aggregated metrics.
|
AbstractAggregatingState<K,N,IN,ACC,OUT> |
|
AbstractArrowPythonAggregateFunctionOperator |
|
AbstractAsynchronousOperationHandlers<K extends OperationKey,R extends Serializable> |
HTTP handlers for asynchronous operations.
|
AbstractAsyncStateStreamingJoinOperator |
Abstract implementation for streaming unbounded Join operator based on async state api, which
defines some member fields can be shared between different implementations.
|
AbstractAsyncStateStreamOperator<OUT> |
|
AbstractAsyncStateStreamOperatorV2<OUT> |
|
AbstractAsyncStateUdfStreamOperator<OUT,F extends Function> |
This is used as the base class for operators that have a user-defined function.
|
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.
|
AbstractAvroBulkFormat<A,T,SplitT extends FileSourceSplit> |
|
AbstractAzureFSFactory |
Abstract factory for AzureFS.
|
AbstractBeamStateHandler<S> |
Abstract class extends BeamStateHandler , which implements the common handle logic.
|
AbstractBinaryExternalMerger<Entry> |
|
AbstractBlobCache |
Abstract base class for permanent and transient BLOB files.
|
AbstractBroadcastStateTransformation<IN1,IN2,OUT> |
Base class for Broadcast State transformations.
|
AbstractBuffersUsageGauge |
Abstract gauge implementation for calculating the buffer usage percent.
|
AbstractBytesHashMap<K> |
Bytes based hash map.
|
AbstractBytesMultiMap<K> |
A binary map in the structure like Map<K, List<V>> , where there are multiple values under
a single key, and they are all bytes based.
|
AbstractCachedBuildSideJoinDriver<IT1,IT2,OT> |
|
AbstractCatalog |
Abstract class for catalogs.
|
AbstractCatalogStore |
The AbstractCatalogStore class is an abstract base class for implementing a catalog store.
|
AbstractCatalogTable |
An abstract catalog table.
|
AbstractCatalogView |
An abstract catalog view.
|
AbstractChangelogStateBackend |
An abstract base implementation of the StateBackend interface whose subclasses use
delegatedStateBackend and State changes to restore.
|
AbstractChannelReaderInputView |
|
AbstractChannelStateHandle<Info> |
Abstract channel state handle.
|
AbstractChannelStateHandle.StateContentMetaInfo |
Describes the underlying content.
|
AbstractChannelWriterOutputView |
|
AbstractCheckpointHandler<R extends ResponseBody,M extends CheckpointMessageParameters> |
Base class for checkpoint related REST handler.
|
AbstractCheckpointMessage |
The base class of all checkpoint messages.
|
AbstractCheckpointStats |
Base class for checkpoint statistics.
|
AbstractCheckpointStatsHandler<R extends ResponseBody,M extends JobMessageParameters> |
|
AbstractCollectResultBuffer<T> |
A buffer which encapsulates the logic of dealing with the response from the CollectSinkFunction .
|
AbstractColumnReader<VECTOR extends WritableColumnVector> |
|
AbstractCompleteCheckpointStore |
|
AbstractContainerizedClusterClientFactory<ClusterID> |
An abstract ClusterClientFactory containing some common implementations for different
containerized deployment clusters.
|
AbstractCsvInputFormat<T> |
Input format that reads csv.
|
AbstractCustomCommandLine |
Base class for CustomCommandLine implementations which specify a JobManager address and a
ZooKeeper namespace.
|
AbstractDataStream<T> |
Base class for all streams.
|
AbstractDataType<T extends AbstractDataType<T>> |
Highest abstraction that describes the data type of a value in the table ecosystem.
|
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.
|
AbstractDispatcherLeaderProcess |
A base DispatcherLeaderProcess .
|
AbstractDispatcherLeaderProcess.DispatcherGatewayService |
|
AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory |
|
AbstractDispatcherLeaderProcess.State |
The state of the DispatcherLeaderProcess .
|
AbstractEmbeddedDataStreamPythonFunctionOperator<OUT> |
Base class for all Python DataStream operators executed in embedded Python environment.
|
AbstractEmbeddedPythonFunctionOperator<OUT> |
Abstract class for all stream operators to execute Python functions in embedded Python
environment.
|
AbstractEmbeddedSchedulerWorkflowHeaders |
Abstract modify and delete workflow related message headers.
|
AbstractEmbeddedStatelessFunctionOperator |
Base class for all stream operators to execute Python Stateless Functions in embedded Python
environment.
|
AbstractEvent |
This type of event can be used to exchange notification messages between different TaskExecutor objects at runtime using the communication channels.
|
AbstractExecNodeExactlyOnceVisitor |
|
AbstractExecutionGraphHandler<R extends ResponseBody,M extends JobMessageParameters> |
|
AbstractExternalDataStreamPythonFunctionOperator<OUT> |
Base class for all Python DataStream operators executed in Python process.
|
AbstractExternalOneInputPythonFunctionOperator<IN,OUT> |
|
AbstractExternalPythonFunctionOperator<OUT> |
Abstract class for all stream operators to execute Python functions in external environment.
|
AbstractExternalTwoInputPythonFunctionOperator<IN1,IN2,OUT> |
|
AbstractFileIOChannel |
|
AbstractFileSource<T,SplitT extends FileSourceSplit> |
The base class for File Sources.
|
AbstractFileSource.AbstractFileSourceBuilder<T,SplitT extends FileSourceSplit,SELF extends AbstractFileSource.AbstractFileSourceBuilder<T,SplitT,SELF>> |
The generic base builder.
|
AbstractFileStateBackend |
Deprecated.
|
AbstractForStStateKeysIterator<K> |
Base class for iterators over RocksDB column families.
|
AbstractForStSyncState<K,N,V> |
Base class for State implementations that store state in a RocksDB database.
|
AbstractFsCheckpointStorageAccess |
An implementation of durable checkpoint storage to file systems.
|
AbstractHandler<T extends RestfulGateway,R extends RequestBody,M extends MessageParameters> |
Super class for netty-based handlers that work with RequestBody .
|
AbstractHaServices |
Abstract high availability services based on distributed system(e.g.
|
AbstractHashTableProber<PT,BT> |
|
AbstractHeapPriorityQueue<T extends HeapPriorityQueueElement> |
Abstract base class for heap (object array) based implementations of priority queues, with
support for fast deletes via HeapPriorityQueueElement .
|
AbstractHeapPriorityQueueElement |
|
AbstractHeapState<K,N,SV> |
Base class for partitioned State implementations that are backed by a regular heap hash
map.
|
AbstractHeapVector |
Heap vector that nullable shared structure.
|
AbstractID |
A statistically unique identification number.
|
AbstractIncrementalStateHandle |
|
AbstractInput<IN,OUT> |
|
AbstractInvokable |
|
AbstractIterativeTask<S extends Function,OT> |
The abstract base class for all tasks able to participate in an iteration.
|
AbstractJarPlanHeaders |
|
AbstractJobClusterExecutor<ClusterID,ClientFactory extends ClusterClientFactory<ClusterID>> |
Deprecated. |
AbstractJobManagerFileHandler<M extends MessageParameters> |
Base class for serving files from the JobManager.
|
AbstractJobVertexHandler<R extends ResponseBody,M extends JobVertexMessageParameters> |
|
AbstractJsonDeserializationSchema |
Deserialization schema from JSON to Flink Table/SQL internal data structure RowData .
|
AbstractKeyedState<K,N,V> |
The AbstractKeyedState is the root of the abstract state implementation hierarchy,
similar to the State being the root of the public API state hierarchy.
|
AbstractKeyedStateBackend<K> |
Base implementation of KeyedStateBackend.
|
AbstractKeyedStateBackend.PartitionStateFactory |
|
AbstractKeyedStateBackendBuilder<K> |
|
AbstractKubernetesParameters |
|
AbstractKubernetesStepDecorator |
|
AbstractKubernetesWatcher<T extends io.fabric8.kubernetes.api.model.HasMetadata,K extends KubernetesResource<T>> |
Watcher for resources in Kubernetes.
|
AbstractListState<K,N,V> |
|
AbstractManagedMemoryStateBackend |
Abstract base class for state backends that use managed memory.
|
AbstractMapBundleOperator<K,V,IN,OUT> |
|
AbstractMapState<K,N,UK,V> |
|
AbstractMergeInnerJoinIterator<T1,T2,O> |
An implementation of the JoinTaskIterator that
realizes the joining through a sort-merge join strategy.
|
AbstractMergeIterator<T1,T2,O> |
|
AbstractMergeOuterJoinIterator<T1,T2,O> |
An implementation of the JoinTaskIterator that
realizes the outer join through a sort-merge join strategy.
|
AbstractMetricGroup<A extends AbstractMetricGroup<?>> |
Abstract MetricGroup that contains key functionality for adding metrics and groups.
|
AbstractMetricGroup.ChildType |
Enum for indicating which child group should be created.
|
AbstractMetricsHandler<M extends MessageParameters> |
Request handler that returns for a given task a list of all available metrics or the values for a
set of metrics.
|
AbstractMetricsHeaders<M extends MessageParameters> |
|
AbstractMultipleInputTransformation<OUT> |
|
AbstractMutableHashTable<T> |
|
AbstractNonHaServices |
Abstract base class for non high-availability services.
|
AbstractOneInputEmbeddedPythonFunctionOperator<IN,OUT> |
|
AbstractOneInputPythonFunctionOperator<IN,OUT> |
Base class for all one input stream operators to execute Python functions.
|
AbstractOperationHandler |
Abstract operation handler.
|
AbstractOperationHeaders |
Abstract operation related message headers.
|
AbstractOrcColumnVector |
This column vector is used to adapt hive's ColumnVector to Flink's ColumnVector.
|
AbstractOrcFileInputFormat<T,BatchT,SplitT extends FileSourceSplit> |
|
AbstractOrcFileInputFormat.OrcReaderBatch<T,BatchT> |
The OrcReaderBatch class holds the data structures containing the batch data (column
vectors, row arrays, ...) and performs the batch conversion from the ORC representation to
the result format.
|
AbstractOrcFileInputFormat.OrcVectorizedReader<T,BatchT> |
A vectorized ORC reader.
|
AbstractOrcNoHiveVector |
This column vector is used to adapt hive's ColumnVector to Flink's ColumnVector.
|
AbstractOuterJoinDriver<IT1,IT2,OT> |
The abstract outer join driver implements the logic of an outer join operator at runtime.
|
AbstractPagedInputView |
The base class for all input views that are backed by multiple memory pages.
|
AbstractPagedOutputView |
The base class for all output views that are backed by multiple memory pages.
|
AbstractParameterTool |
|
AbstractPartFileWriter<IN,BucketID> |
An abstract writer for the currently open part file in a specific Bucket .
|
AbstractPartitionTracker<K,M> |
Base partition tracker implementation, providing underlying data-structures for storing
partitions, their associated keys and meta-information.
|
AbstractPrometheusReporter |
base prometheus reporter for prometheus metrics.
|
AbstractPythonEnvironmentManager |
The base class of python environment manager which is used to create the PythonEnvironment object
used to execute Python functions.
|
AbstractPythonEnvironmentManager.PythonLeasedResource |
Python lease resource which includes environment variables and working directory of execution
python environment.
|
AbstractPythonFunctionOperator<OUT> |
Base class for all stream operators to execute Python functions.
|
AbstractPythonScalarFunctionOperator |
Base class for all stream operators to execute Python ScalarFunction s.
|
AbstractPythonStreamAggregateOperator |
|
AbstractPythonStreamGroupAggregateOperator |
|
AbstractReader |
A basic reader implementation, which wraps an input gate and handles events.
|
AbstractReducingState<K,N,V> |
|
AbstractRegexParseStrategy |
Strategy to parse statement to Operation by regex.
|
AbstractReporter |
Base interface for custom metric reporters.
|
AbstractResourceManagerDriver<WorkerType extends ResourceIDRetrievable> |
|
AbstractResourceManagerHandler<T extends RestfulGateway,R extends RequestBody,P extends ResponseBody,M extends MessageParameters> |
|
AbstractRestHandler<T extends RestfulGateway,R extends RequestBody,P extends ResponseBody,M extends MessageParameters> |
|
AbstractRetryStrategy |
Retry strategy base class.
|
AbstractRichFunction |
An abstract stub implementation for rich user-defined functions.
|
AbstractRocksDBState<K,N,V> |
Base class for State implementations that store state in a RocksDB database.
|
AbstractRocksStateKeysIterator<K> |
Base class for iterators over RocksDB column families.
|
AbstractRowDataSerializer<T extends RowData> |
Row serializer, provided paged serialize paged method.
|
AbstractRowTimeUnboundedPrecedingOver<K> |
A basic implementation to support unbounded event-time over-window.
|
AbstractRuntimeUDFContext |
A standalone implementation of the RuntimeContext , created by runtime UDF operators.
|
AbstractS3DelegationTokenProvider |
Delegation token provider for S3 filesystems.
|
AbstractS3DelegationTokenReceiver |
Delegation token receiver for S3 filesystems.
|
AbstractS3FileSystemFactory |
Base class for file system factories that create S3 file systems.
|
AbstractServerBase<REQ extends MessageBody,RESP extends MessageBody> |
The base class for every server in the queryable state module.
|
AbstractServerHandler<REQ extends MessageBody,RESP extends MessageBody> |
|
AbstractServiceConnectionManager<S> |
Base class for service connection managers, taking care of the connection handling.
|
AbstractSessionClusterExecutor<ClusterID,ClientFactory extends ClusterClientFactory<ClusterID>> |
|
AbstractShowOperation |
Base class for SHOW operations.
|
AbstractSliceWindowAggProcessor |
|
AbstractSlotPoolServiceFactory |
Abstract SlotPoolServiceFactory.
|
AbstractSqlCallContext |
|
AbstractSqlCallContext.LiteralValueAccessor |
Helper interface for abstracting accessing literals.
|
AbstractSqlGatewayRestHandler<R extends RequestBody,P extends ResponseBody,M extends MessageParameters> |
|
AbstractSqlShowConverter<T extends SqlShowCall> |
An abstract class for SHOW converters.
|
AbstractStateBackend |
An abstract base implementation of the StateBackend interface.
|
AbstractStateChangeFsUploader |
Base implementation of StateChangeUploader.
|
AbstractStateIterator<T> |
A StateIterator implementation to facilitate async data load of iterator.
|
AbstractStatelessFunctionOperator<IN,OUT,UDFIN> |
Base class for all stream operators to execute Python Stateless Functions.
|
AbstractStreamArrowPythonBoundedRangeOperator<K> |
The Abstract class of Stream Arrow Python AggregateFunction Operator for RANGE clause
bounded Over Window Aggregation.
|
AbstractStreamArrowPythonBoundedRowsOperator<K> |
The Abstract class of Stream Arrow Python AggregateFunction Operator for ROWS clause
bounded Over Window Aggregation.
|
AbstractStreamArrowPythonOverWindowAggregateFunctionOperator<K> |
The Abstract class of Stream Arrow Python AggregateFunction Operator for Over Window
Aggregation.
|
AbstractStreamingJoinOperator |
Abstract implementation for streaming unbounded Join operator which defines some member fields
can be shared between different implementations.
|
AbstractStreamingWriter<IN,OUT> |
Operator for file system sink.
|
AbstractStreamOperator<OUT> |
Base class for all stream operators.
|
AbstractStreamOperatorFactory<OUT> |
Base class for all stream operator factories.
|
AbstractStreamOperatorV2<OUT> |
|
AbstractStreamTableEnvironmentImpl |
Abstract class to implement a StreamTableEnvironment .
|
AbstractStreamTaskNetworkInput<T,R extends RecordDeserializer<DeserializationDelegate<StreamElement>>> |
Base class for network-based StreamTaskInput where each channel has a designated RecordDeserializer for spanning records.
|
AbstractSubtaskAttemptHandler<R extends ResponseBody,M extends SubtaskAttemptMessageParameters> |
|
AbstractSubtaskHandler<R extends ResponseBody,M extends SubtaskMessageParameters> |
|
AbstractTaskManagerFileHandler<M extends TaskManagerMessageParameters> |
|
AbstractTestBase |
Base class for unit tests that run multiple tests and want to reuse the same Flink cluster.
|
AbstractTestBaseJUnit4 |
Deprecated.
|
AbstractThreadsafeJobResultStore |
An abstract class for threadsafe implementations of the JobResultStore .
|
AbstractTopNFunction |
Base class for TopN Function.
|
AbstractTtlDecorator<T> |
Base class for TTL logic wrappers.
|
AbstractTwoInputEmbeddedPythonFunctionOperator<IN1,IN2,OUT> |
|
AbstractTwoInputStreamTask<IN1,IN2,OUT> |
|
AbstractTwoInputTransformationTranslator<IN1,IN2,OUT,OP extends Transformation<OUT>> |
A base class with functionality used during translating transformations
with two inputs.
|
AbstractUdfOperator<OUT,FT extends Function> |
Abstract superclass for all contracts that represent actual operators.
|
AbstractUdfStreamOperator<OUT,F extends Function> |
This is used as the base class for operators that have a user-defined function.
|
AbstractUserClassPathJobGraphRetriever |
Abstract class for the JobGraphRetriever which supports getting user classpaths.
|
AbstractValueState<K,N,V> |
|
AbstractWindowAggProcessor<W> |
A base class for window aggregate processors.
|
AbstractWindowProperty |
Deprecated.
|
AbstractWritableVector |
Contains the shared structure for ColumnVector s, including NULL information and
dictionary.
|
AccessExecution |
|
AccessExecutionGraph |
|
AccessExecutionJobVertex |
|
AccessExecutionVertex |
|
Accumulator<V,R extends Serializable> |
Accumulators collect distributed statistics or aggregates in a from user functions and operators.
|
AccumulatorHelper |
|
AccumulatorRegistry |
Main accumulator registry which encapsulates user-defined accumulators.
|
AccumulatorReport |
A report about the current values of all accumulators of the TaskExecutor for a given job.
|
AccumulatorsIncludeSerializedValueQueryParameter |
|
AccumulatorSnapshot |
This class encapsulates a map of accumulators for a single task.
|
Acknowledge |
A generic acknowledgement message.
|
AcknowledgeCheckpoint |
This message is sent from the TaskExecutor to the
JobMaster to signal that the checkpoint of an
individual task is completed.
|
AcknowledgeCheckpointEvent |
|
AcrossCheckpointFileMergingSnapshotManager |
|
ActiveResourceManager<WorkerType extends ResourceIDRetrievable> |
|
ActiveResourceManagerFactory<WorkerType extends ResourceIDRetrievable> |
|
ActorSystemBootstrapTools |
Tools for starting the Actor Systems used to run the JobManager and TaskManager actors.
|
ActorSystemScheduledExecutorAdapter |
|
AdaptedCallContext |
Helper context that deals with adapted arguments.
|
AdaptiveBatchScheduler |
This scheduler decides the parallelism of JobVertex according to the data volume it consumes.
|
AdaptiveBatchSchedulerFactory |
|
AdaptiveScheduler |
A SchedulerNG implementation that uses the declarative resource management and
automatically adapts the parallelism in case not enough resource could be acquired to run at the
configured parallelism, as described in FLIP-160.
|
AdaptiveScheduler.Settings |
Consolidated settings for the adaptive scheduler.
|
AdaptiveSchedulerFactory |
Factory for the adaptive scheduler.
|
AddBoolBeforeReturnRewriter |
|
AddJarOperation |
Operation to describe an ADD JAR statement.
|
AddOne |
Scala UDF for testing.
|
AddPartitionsOperation |
Operation to describe ALTER TABLE ADD PARTITION statement.
|
Address |
|
Address.Builder |
RecordBuilder for Address instances.
|
AddressResolution |
Enum specifying whether address resolution should be tried.
|
AddSplitEvent<SplitT> |
A source event that adds splits to a source reader.
|
AdvancedFunctionsExample |
|
AfterMatchSkipStrategy |
Indicate the skip strategy after a match process.
|
AggCombiner |
An implementation of RecordsCombiner that accumulates input records into the window
accumulator state.
|
AggCombiner.Factory |
|
AggregateApplyAllWindowFunction<W extends Window,T,ACC,V,R> |
|
AggregateApplyWindowFunction<K,W extends Window,T,ACC,V,R> |
|
AggregatedJobMetricsHeaders |
Headers for aggregating job metrics.
|
AggregatedJobMetricsParameters |
Parameters for aggregating job metrics.
|
AggregatedMetric |
Response type for aggregated metrics.
|
AggregatedMetricsResponseBody |
Response type for a collection of aggregated metrics.
|
AggregatedMetricsResponseBody.Deserializer |
|
AggregatedMetricsResponseBody.Serializer |
|
AggregatedSubtaskMetricsHeaders |
Headers for aggregating subtask metrics.
|
AggregatedSubtaskMetricsParameters |
Parameters for aggregating subtask metrics.
|
AggregatedTable |
A table that has been performed on the aggregate function.
|
AggregatedTaskDetailsInfo |
Aggregated info of a set of tasks.
|
AggregatedTaskManagerMetricsHeaders |
Headers for aggregating task manager metrics.
|
AggregateEvictingWindowReaderFunction<IN,ACC,R,OUT,KEY,W extends Window> |
A wrapper for reading an evicting window operator with an aggregate function.
|
AggregateExpression |
Resolved and validated expression for calling an aggregate function.
|
AggregateFunction<IN,ACC,OUT> |
The AggregateFunction is a flexible aggregation function, characterized by the following
features:
The aggregates may use different types for input values, intermediate aggregates, and
result type, to support a wide range of aggregation types.
|
AggregateFunction<T,ACC> |
Base class for a user-defined aggregate function.
|
AggregateFunctionDefinition |
Deprecated.
|
AggregatePhaseStrategy |
|
AggregatePushDownSpec |
|
AggregateQueryOperation |
Relational operation that performs computations on top of subsets of input rows grouped by key.
|
AggregateTaskManagerMetricsParameters |
Parameters for aggregating task manager metrics.
|
AggregateWindowOperator<K,W extends Window> |
|
AggregatingJobsMetricsHandler |
Request handler that returns, aggregated across jobs, a list of all available metrics or the
values for a set of metrics.
|
AggregatingState<IN,OUT> |
|
AggregatingState<IN,OUT> |
|
AggregatingStateAdaptor<K,N,IN,ACC,OUT> |
|
AggregatingStateDeclaration<IN,ACC,OUT> |
This represents a declaration of the aggregating state.
|
AggregatingStateDescriptor<IN,ACC,OUT> |
|
AggregatingStateDescriptor<IN,ACC,OUT> |
|
AggregatingSubtasksMetricsHandler |
Request handler that returns, aggregated across subtasks, a list of all available metrics or the
values for a set of metrics.
|
AggregatingTaskManagersMetricsHandler |
Request handler that returns, aggregated across task managers, a list of all available metrics or
the values for a set of metrics.
|
AggregationFunction<T> |
Holder class for aggregation types that can be used on a windowed stream or keyed stream.
|
AggregationFunction.AggregationType |
Aggregation types that can be used on a windowed stream or keyed stream.
|
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.
|
AggsHandleFunction |
The base class for handling aggregate functions.
|
AggsHandleFunctionBase |
The base class for handling aggregate or table aggregate functions.
|
AIMDScalingStrategy |
AIMDScalingStrategy scales up linearly and scales down multiplicatively.
|
AIMDScalingStrategy.AIMDScalingStrategyBuilder |
|
AirBlockCompressor |
Flink compressor that wraps Compressor .
|
AirBlockDecompressor |
Flink decompressor that wraps Decompressor .
|
AirCompressorFactory |
|
Alert |
Data type for alerts.
|
Alert |
A simple alert event.
|
AlertSink |
Deprecated. |
AlgorithmOptions |
Configuration parameters for join/sort algorithms.
|
AlignedWindowTableFunctionOperator |
The operator for aligned window table function.
|
AllCallbackWrapper<C extends CustomExtension> |
An extension wrap logic for BeforeAllCallback and AfterAllCallback .
|
AllFinishedInputConsumableDecider |
|
AllFinishedInputConsumableDecider.Factory |
|
AllGroupCombineDriver<IN,OUT> |
Non-chained driver for the partial group reduce operator that acts like a combiner with a custom
output type OUT.
|
AllGroupReduceDriver<IT,OT> |
GroupReduceDriver task which is executed by a Task Manager.
|
AllocatedSlotActions |
Interface for components which have to perform actions on allocated slots.
|
AllocatedSlotInfo |
Information about an allocated slot which is owned by a JobMaster.
|
AllocatedSlotPool |
The slot pool is responsible for maintaining a set of AllocatedSlots .
|
AllocatedSlotPool.AllocatedSlotsAndReservationStatus |
A collection of AllocatedSlots and their reservation status.
|
AllocatedSlotPool.FreeSlotInfo |
Information about a free slot.
|
AllocatedSlotReport |
The report of currently allocated slots from a given TaskExecutor by a JobMaster.
|
AllocationID |
Unique identifier for a physical slot allocated by a JobManager via the ResourceManager from a
TaskManager.
|
Allocator |
Implementations are responsible for allocate space.
|
AllowNonRestoredStateQueryParameter |
Query parameter that specifies whether non restored state is allowed if the savepoint contains
state for an operator that is not part of the job.
|
AllReduceDriver<T> |
Reduce task which is executed by a Task Manager.
|
AllToAllBlockingResultInfo |
Information of All-To-All result.
|
AllWindowedStream<T,W extends Window> |
A AllWindowedStream represents a data stream where the stream of elements is split into
windows based on a WindowAssigner .
|
AllWindowFunction<IN,OUT,W extends Window> |
Base interface for functions that are evaluated over non-keyed windows.
|
AllWorkersDoneEvent |
Event sent by the IterationSynchronizationSinkTask to each IterationHead
signaling to start a new superstep.
|
AlterCatalogCommentOperation |
Operation to describe a ALTER CATALOG COMMENT statement.
|
AlterCatalogFunctionOperation |
Operation to describe a ALTER FUNCTION statement for catalog functions.
|
AlterCatalogOptionsOperation |
Operation to describe a ALTER CATALOG SET statement.
|
AlterCatalogResetOperation |
Operation to describe an ALTER CATALOG RESET statement.
|
AlterDatabaseEvent |
When a database is altered, an AlterDatabaseEvent event will be created and fired which
has the old database and new database.
|
AlterDatabaseOperation |
Operation to describe a ALTER DATABASE statement.
|
AlterMaterializedTableChangeOperation |
Alter materialized table with new table definition and table changes represents the modification.
|
AlterMaterializedTableOperation |
Abstract Operation to describe all ALTER MATERIALIZED TABLE statements such as rename table /set
properties.
|
AlterMaterializedTableRefreshOperation |
Operation to describe clause like: ALTER MATERIALIZED TABLE [catalog_name.]
|
AlterMaterializedTableResumeOperation |
Operation to describe a ALTER MATERIALIZED TABLE ...
|
AlterMaterializedTableSuspendOperation |
Operation to describe a ALTER MATERIALIZED TABLE ...
|
AlterModelEvent |
When a model is altered, a AlterModelEvent event will be created and fired.
|
AlterOperation |
A Operation that describes the DDL statements, e.g.
|
AlterPartitionOperation |
Abstract Operation to describe all ALTER TABLE statements that should be applied to partitions.
|
AlterPartitionPropertiesOperation |
Operation to alter the properties of partition.
|
AlterSchemaConverter |
|
AlterTableChangeOperation |
Alter table with new table definition and table changes represents the modification.
|
AlterTableEvent |
When a table is altered, a AlterTableEvent event will be created and fired.
|
AlterTableOperation |
Abstract Operation to describe all ALTER TABLE statements such as rename table /set properties.
|
AlterTableOptionsOperation |
Deprecated.
|
AlterTableRenameOperation |
Operation to describe a ALTER TABLE ..
|
AlterTableSchemaOperation |
Operation to describe altering the schema of a table.
|
AlterViewAsOperation |
Operation to describe an ALTER VIEW ...
|
AlterViewOperation |
Abstract Operation to describe all ALTER VIEW statements.
|
AlterViewPropertiesOperation |
Operation to describe a ALTER VIEW ..
|
AlterViewRenameOperation |
Operation to describe a ALTER VIEW ..
|
AmbiguousTableFactoryException |
Deprecated.
|
AmbiguousTableFactoryException |
Exception for finding more than one TableFactory for the given properties.
|
AnalyzeTableOperation |
Operation to describe an ANALYZE TABLE statement.
|
AnalyzeTableUtil |
ANALYZE TABLE statement Util.
|
AndArgumentTypeStrategy |
Strategy for inferring and validating an argument using a conjunction of multiple ArgumentTypeStrategy s into one like f(NUMERIC && LITERAL)
|
AnotherDummyFSFactory |
Factory of dummy FileSystem.
|
AnswerFormatter |
Answer set format tool class. convert delimiter from spaces or tabs to bar('|') in TPC-DS answer
set. before convert, need to format TPC-DS result as following: 1. split answer set which has
multi query results to multi answer set, includes query14, 23, 24, 39. 2. replace tabs by spaces
in answer set by vim. (1) cd answer_set directory (2) vim 1.ans with command model, :set ts=8
:set noexpandtab :%retab!
|
AnyArgumentTypeStrategy |
Strategy for an argument that can be of any type.
|
ApiAnnotationRules |
Rules for API visibility annotations.
|
ApiExpression |
Java API class that gives access to expression operations.
|
ApiExpressionDefaultVisitor<T> |
|
ApiExpressionUtils |
|
ApiExpressionVisitor<R> |
A visitor for all Expression s that might be created during API translation.
|
ApiSpecGeneratorUtils |
Helper methods for generation API documentation.
|
AppendingState<IN,OUT> |
Base interface for partitioned state that supports adding elements and inspecting the current
state.
|
AppendingState<IN,OUT,SYNCOUT> |
Base interface for partitioned state that supports adding elements and inspecting the current
state.
|
AppendOnlyFirstNFunction |
|
AppendOnlyTopNFunction |
A TopN function could handle insert-only stream.
|
AppendStreamTableSink<T> |
Deprecated.
|
ApplicationClusterDeployer |
An entity responsible for submitting an application for execution in "Application Mode", i.e. on
a dedicated cluster that is created on application submission and torn down upon application
termination, and with its main() executed on the cluster, rather than the client.
|
ApplicationClusterEntryPoint |
Base class for cluster entry points targeting executing applications in "Application Mode".
|
ApplicationConfiguration |
Application-specific configurations.
|
ApplicationDeployer |
An interface to be used by the CliFrontend to submit user programs for execution.
|
ApplicationDispatcherBootstrap |
|
ApplicationDispatcherGatewayServiceFactory |
A DispatcherGatewayServiceFactory used when executing a job in Application Mode, i.e. the user's
main is executed on the same machine as the Dispatcher and the lifecycle of the cluster
is the same as the one of the application.
|
ApplicationDispatcherLeaderProcessFactoryFactory |
|
ApplicationExecutionException |
A FlinkException thrown in case something during application execution went wrong.
|
ApplicationRunner |
An interface to be implemented by the entities responsible for application submission for the
different deployment environments.
|
ApplicationStatus |
The status of an application.
|
ApplyPartitionFunction<OUT> |
A function to be applied to all partitions .
|
ArbitraryWorkerResourceSpecFactory |
|
Archiveable<T extends Serializable> |
|
ArchivedExecution |
ArchivedExecution is a readonly representation of Execution .
|
ArchivedExecutionConfig |
Serializable class which is created when archiving the job.
|
ArchivedExecutionGraph |
An archived execution graph represents a serializable form of an ExecutionGraph .
|
ArchivedExecutionJobVertex |
|
ArchivedExecutionVertex |
|
ArchivedJson |
A simple container for a handler's JSON response and the REST URLs for which the response
would've been returned.
|
ArgumentCount |
Defines the count of accepted arguments (including open intervals) that a function can take.
|
ArgumentCountRange |
|
ArgumentHint |
A hint that provides additional information about an argument.
|
ArgumentMappingTypeStrategy |
Type strategy that returns the n-th input argument, mapping it with the provided function.
|
ArgumentTrait |
|
ArgumentTypeStrategy |
Strategy for inferring and validating a single input argument type of a function call.
|
ArrayAggFunction<T> |
Built-in ARRAY_AGG aggregate function.
|
ArrayAggFunction.ArrayAggAccumulator<T> |
Accumulator for ARRAY_AGG with retraction.
|
ArrayAppendFunction |
|
ArrayAppendPrependTypeStrategy |
Type strategy that returns a DataTypes.ARRAY(DataType) with element type equal to the
type of the first argument if it's not nullable or element to add is not nullable, otherwise it
returns DataTypes.ARRAY(DataType) with type equal to the type of the element to add to
array.
|
ArrayBooleanArrayConverter |
Converter for ArrayType of boolean[] external type.
|
ArrayByteArrayConverter |
Converter for ArrayType of byte[] external type.
|
ArrayColumnVector |
Array column vector.
|
ArrayComparableElementArgumentTypeStrategy |
An ArgumentTypeStrategy that checks if the input argument is an ARRAY type and check
whether its' elements are comparable.
|
ArrayConcatFunction |
|
ArrayConstructor |
Creates arrays of objects.
|
ArrayContainsFunction |
|
ArrayData |
Base interface of an internal data structure representing data of ArrayType .
|
ArrayData.ElementGetter |
Accessor for getting the elements of an array during runtime.
|
ArrayDataSerializer |
|
ArrayDataSerializer |
|
ArrayDataSerializer.ArrayDataSerializerSnapshot |
|
ArrayDataSerializer.ArrayDataSerializerSnapshot |
|
ArrayDistinctFunction |
|
ArrayDoubleArrayConverter |
Converter for ArrayType of double[] external type.
|
ArrayElementTypeStrategy |
|
ArrayExceptFunction |
|
ArrayFloatArrayConverter |
Converter for ArrayType of float[] external type.
|
ArrayFromTuple |
Converts a Tuple to an Object-Array.
|
ArrayIntArrayConverter |
Converter for ArrayType of int[] external type.
|
ArrayIntersectFunction |
|
ArrayJoinFunction |
|
ArrayListConverter<E> |
|
ArrayListSerializer<T> |
|
ArrayListSerializerSnapshot<T> |
|
ArrayLongArrayConverter |
Converter for ArrayType of long[] external type.
|
ArrayMaxFunction |
|
ArrayMinFunction |
|
ArrayObjectArrayConverter<E> |
Converter for ArrayType of nested primitive or object arrays external types.
|
ArrayOfStringArgumentTypeStrategy |
Strategy for an argument that must be an array of strings.
|
ArrayPositionFunction |
|
ArrayPrependFunction |
|
ArrayRemoveFunction |
|
ArrayResultIterator<E> |
|
ArrayReverseFunction |
|
ArrayShortArrayConverter |
Converter for ArrayType of short[] external type.
|
ArraySliceFunction |
|
ArraySortFunction |
Implementation of ARRAY_SORT function.
|
ArrayType |
Logical type of an array of elements with same subtype.
|
ArrayUnionFunction |
|
ArrayUtils |
Utility class for Java arrays.
|
ArrayWriter<T> |
|
ArrayWriter.ArrayWriterForArray |
|
ArrayWriter.ArrayWriterForRow |
|
ArrowArrayColumnVector |
Arrow column vector for Array.
|
ArrowBigIntColumnVector |
Arrow column vector for BigInt.
|
ArrowBinaryColumnVector |
Arrow column vector for Binary.
|
ArrowBooleanColumnVector |
Arrow column vector for Boolean.
|
ArrowDateColumnVector |
Arrow column vector for Date.
|
ArrowDecimalColumnVector |
Arrow column vector for DecimalData.
|
ArrowDoubleColumnVector |
Arrow column vector for Double.
|
ArrowFieldWriter<IN> |
Base class for arrow field writer which is used to convert a field to an Arrow format.
|
ArrowFloatColumnVector |
Arrow column vector for Float.
|
ArrowIntColumnVector |
Arrow column vector for Int.
|
ArrowMapColumnVector |
Arrow column vector for Map.
|
ArrowNullColumnVector |
Arrow column vector for Null.
|
ArrowPythonScalarFunctionOperator |
|
ArrowReader |
|
ArrowRowColumnVector |
Arrow column vector for Row.
|
ArrowSerializer |
The base class ArrowSerializer which will serialize/deserialize RowType data to/from arrow bytes.
|
ArrowSmallIntColumnVector |
Arrow column vector for Int.
|
ArrowSourceFunction |
Deprecated.
|
ArrowTableSource |
|
ArrowTimeColumnVector |
Arrow column vector for Time.
|
ArrowTimestampColumnVector |
Arrow column vector for Timestamp.
|
ArrowTinyIntColumnVector |
Arrow column vector for TinyInt.
|
ArrowUtils |
Utilities for Arrow.
|
ArrowVarBinaryColumnVector |
Arrow column vector for VarBinary.
|
ArrowVarCharColumnVector |
Arrow column vector for VarChar.
|
ArrowWriter<IN> |
Writer which serializes the Flink rows to Arrow format.
|
ArtifactFetchManager |
Class that manages the artifact loading process.
|
ArtifactFetchManager.Result |
Artifact fetch result with all fetched artifact(s).
|
ArtifactFetchOptions |
Artifact Fetch options.
|
ArtifactUtils |
Artifact fetch related utils.
|
ArtificalOperatorStateMapper<IN,OUT> |
A self-verifiable RichMapFunction used to verify checkpointing and restore semantics for
various kinds of operator state.
|
ArtificialKeyedStateMapper<IN,OUT> |
|
ArtificialListStateBuilder<IN,STATE> |
|
ArtificialMapStateBuilder<IN,K,V> |
|
ArtificialStateBuilder<T> |
The state builder wraps the logic of registering state in user functions, as well as how state is
updated per input element..
|
ArtificialValueStateBuilder<IN,STATE> |
|
AscendingTimestampExtractor<T> |
Deprecated. |
AscendingTimestampExtractor.FailingHandler |
Handler that fails the program when timestamp monotony is violated.
|
AscendingTimestampExtractor.IgnoringHandler |
Handler that does nothing when timestamp monotony is violated.
|
AscendingTimestampExtractor.LoggingHandler |
Handler that only logs violations of timestamp monotony, on WARN log level.
|
AscendingTimestampExtractor.MonotonyViolationHandler |
Interface for handlers that handle violations of the monotonous ascending timestamps
property.
|
AscendingTimestamps |
A watermark strategy for ascending rowtime attributes.
|
AscendingTimestampsWatermarks<T> |
A watermark generator that assumes monotonically ascending timestamps within the stream split and
periodically generates watermarks based on that assumption.
|
AssignRangeIndex<IN> |
This mapPartition function require a DataSet with RangeBoundaries as broadcast input, it generate
Tuple2 which includes range index and record itself as output.
|
AssociatedRecords |
|
AsyncCalcSplitRule |
Defines split rules for async calc nodes.
|
AsyncCalcSplitRule.AsyncCalcSplitNestedRule |
Splits nested call <- asyncCall chains so that nothing is immediately waiting on an async
call in a single calc.
|
AsyncCalcSplitRule.AsyncCalcSplitOnePerCalcRule |
Splits async calls if there are multiple across projections, so that there's one per calc.
|
AsyncCalcSplitRule.AsyncCalcSplitOnePerCalcRule.State |
State object used to keep track of whether a match has been found yet.
|
AsyncCalcSplitRule.AsyncRemoteCalcCallFinder |
|
AsyncClient |
A simple asynchronous client that simulates interacting with an unreliable external service.
|
AsyncCodeGenerator |
Generates an AsyncFunction which can be used to evaluate calc projections from an async
scalar function.
|
AsyncDataStream |
|
AsyncDataStream.OutputMode |
Output mode for asynchronous operations.
|
AsyncDynamicTableSink<RequestEntryT extends Serializable> |
|
AsyncDynamicTableSinkBuilder<RequestEntryT extends Serializable,ConcreteBuilderT extends AsyncDynamicTableSinkBuilder<?,?>> |
|
AsyncDynamicTableSinkFactory |
|
AsyncExceptionHandler |
An interface marking a task as capable of handling exceptions thrown by different threads, other
than the one executing the task itself.
|
AsyncExecutionController<K> |
The Async Execution Controller (AEC) receives processing requests from operators, and put them
into execution according to some strategies.
|
AsyncExecutionController.SwitchContextListener<K> |
A listener listens the key context switch.
|
AsyncFunction<IN,OUT> |
A function to trigger Async I/O operation.
|
AsyncFunctionRunner |
Async function runner for AsyncScalarFunction , which
takes the generated function, instantiates it, and then calls its lifecycle methods.
|
AsynchronousBlockReader |
A reader that reads data in blocks from a file channel.
|
AsynchronousBlockWriter |
|
AsynchronousBlockWriterWithCallback |
|
AsynchronousBufferFileReader |
|
AsynchronousBufferFileSegmentReader |
|
AsynchronousBufferFileWriter |
|
AsynchronousBulkBlockReader |
|
AsynchronousException |
An exception for wrapping exceptions that are thrown by an operator in threads other than the
main compute thread of that operator.
|
AsynchronousFileIOChannel<T,R extends org.apache.flink.runtime.io.disk.iomanager.IORequest> |
A base class for readers and writers that accept read or write requests for whole blocks.
|
AsynchronousJobOperationKey |
A pair of JobID and TriggerId used as a key to a hash based collection.
|
AsynchronouslyCreatedResource<T> |
Interface for REST resources that are created asynchronously.
|
AsynchronousOperationInfo |
Basic information object for asynchronous operations.
|
AsynchronousOperationResult<V> |
Result of an asynchronous operation.
|
AsynchronousOperationStatusMessageHeaders<V,M extends MessageParameters> |
Message headers for the status polling of an asynchronous operation.
|
AsynchronousOperationTriggerMessageHeaders<R extends RequestBody,M extends MessageParameters> |
Message headers for the triggering of an asynchronous operation.
|
AsyncIOExample |
|
AsyncKeyedStateBackend<K> |
An async keyed state backend provides methods supporting to access keyed state asynchronously and
in batch.
|
AsyncKeyedStateBackendAdaptor<K> |
|
AsyncLookupFunction |
A wrapper class of AsyncTableFunction for asynchronously lookup rows matching the lookup
keys from external system.
|
AsyncLookupFunctionProvider |
|
AsyncLookupJoinRunner |
The async join runner to lookup the dimension table.
|
AsyncLookupJoinWithCalcRunner |
The async join runner with an additional calculate function on the dimension table.
|
AsyncRetryPredicate<OUT> |
Interface encapsulates an asynchronous retry predicate.
|
AsyncRetryStrategies |
|
AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy<OUT> |
ExponentialBackoffDelayRetryStrategy.
|
AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder<OUT> |
ExponentialBackoffDelayRetryStrategyBuilder for building a
ExponentialBackoffDelayRetryStrategy.
|
AsyncRetryStrategies.FixedDelayRetryStrategy<OUT> |
FixedDelayRetryStrategy.
|
AsyncRetryStrategies.FixedDelayRetryStrategyBuilder<OUT> |
FixedDelayRetryStrategyBuilder for building a FixedDelayRetryStrategy.
|
AsyncRetryStrategy<OUT> |
Interface encapsulates an asynchronous retry strategy.
|
AsyncScalarFunction |
Base class for a user-defined scalar function which returns results asynchronously.
|
AsyncSinkBase<InputT,RequestEntryT extends Serializable> |
A generic sink for destinations that provide an async client to persist data.
|
AsyncSinkBaseBuilder<InputT,RequestEntryT extends Serializable,ConcreteBuilderT extends AsyncSinkBaseBuilder<?,?,?>> |
Abstract builder for constructing a concrete implementation of AsyncSinkBase .
|
AsyncSinkConfigurationValidator |
|
AsyncSinkConnectorOptions |
|
AsyncSinkFatalExceptionClassifiers |
Common retry exception classifiers needed for common errors.
|
AsyncSinkWriter<InputT,RequestEntryT extends Serializable> |
A generic sink writer that handles the general behaviour of a sink such as batching and flushing,
and allows extenders to implement the logic for persisting individual request elements, with
allowance for retries.
|
AsyncSinkWriterConfiguration |
|
AsyncSinkWriterConfiguration.AsyncSinkWriterConfigurationBuilder |
|
AsyncSinkWriterConfiguration.ConfigurationMaxBatchSize |
|
AsyncSinkWriterConfiguration.ConfigurationMaxBatchSizeInBytes |
|
AsyncSinkWriterConfiguration.ConfigurationMaxBufferedRequests |
|
AsyncSinkWriterConfiguration.ConfigurationMaxInFlightRequests |
|
AsyncSinkWriterConfiguration.ConfigurationMaxRecordSizeInBytes |
|
AsyncSinkWriterConfiguration.ConfigurationMaxTimeInBufferMS |
|
AsyncSinkWriterStateSerializer<RequestEntryT extends Serializable> |
|
AsyncSnapshotCallable<T> |
Base class that outlines the strategy for asynchronous snapshots.
|
AsyncStateException |
An exception for wrapping exceptions that are thrown by StateFuture callback framework.
|
AsyncStateProcessing |
This class defines the basic interfaces to process a state in operator/input layer.
|
AsyncStateProcessingOperator |
A more detailed interface based on AsyncStateProcessing , which gives the essential
methods for an operator to perform async state processing.
|
AsyncStateStreamingJoinOperator |
Streaming unbounded Join operator based on async state api, which supports INNER/LEFT/RIGHT/FULL
JOIN.
|
AsyncTableFunction<T> |
Base class for a user-defined asynchronous table function.
|
AsyncTableFunctionProvider<T> |
Deprecated.
|
AsyncUtil |
|
AsyncUtil.Options |
Options for configuring async behavior.
|
AsyncWaitOperator<IN,OUT> |
|
AsyncWaitOperatorFactory<IN,OUT> |
|
AtomicDataType |
A data type that does not contain further data types (e.g.
|
AtomicKvStateRequestStats |
|
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 |
|
AttributeParser |
|
AutoClosablePath |
Utility class to delete a given Path when exiting a try-with-resources statement.
|
AutoClosableProcess |
Utility class to terminate a given Process when exiting a try-with-resources statement.
|
AutoClosableProcess.AutoClosableProcessBuilder |
Builder for most sophisticated processes.
|
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.
|
AuxiliaryConverter |
Converts an expression for a group window function (e.g.
|
AuxiliaryConverter.Impl |
|
AvailabilityNotifier |
AvailabilityNotifier is used to notify that the data from the specific partition and
subpartition in tiered storage is available.
|
AvailabilityProvider |
Interface defining couple of essential methods for listening on data availability using CompletableFuture .
|
AvailabilityProvider.AvailabilityHelper |
A availability implementation for providing the helpful functions of resetting the
available/unavailable states.
|
AverageAccumulator |
An accumulator that computes the average value.
|
AvgAggFunction |
built-in avg aggregate function.
|
AvgAggFunction.ByteAvgAggFunction |
Built-in Byte Avg aggregate function.
|
AvgAggFunction.DecimalAvgAggFunction |
Built-in Decimal Avg aggregate function.
|
AvgAggFunction.DoubleAvgAggFunction |
Built-in Double Avg aggregate function.
|
AvgAggFunction.FloatAvgAggFunction |
Built-in Float Avg aggregate function.
|
AvgAggFunction.IntAvgAggFunction |
Built-in Integer Avg aggregate function.
|
AvgAggFunction.LongAvgAggFunction |
Built-in Long Avg aggregate function.
|
AvgAggFunction.ShortAvgAggFunction |
Built-in Short Avg aggregate function.
|
AvroBuilder<T> |
|
AvroBulkWriter<T> |
A simple BulkWriter implementation that wraps an Avro DataFileWriter .
|
AvroConfluentFormatOptions |
Options for Schema Registry Avro format.
|
AvroDeserializationSchema<T> |
Deserialization schema that deserializes from Avro binary format.
|
AvroFactory<T> |
Creates Avro DatumReader and DatumWriter .
|
AvroFileFormatFactory |
Avro format factory for file system.
|
AvroFormatFactory |
|
AvroFormatOptions |
Options for the avro format.
|
AvroFormatOptions.AvroEncoding |
|
AvroInputFormat<E> |
|
AvroKryoSerializerUtils |
Utilities for integrating Avro serializers in Kryo.
|
AvroKryoSerializerUtils.AvroSchemaSerializer |
Slow serialization approach for Avro schemas.
|
AvroOutputFormat<E> |
|
AvroOutputFormat.Codec |
Wrapper which encapsulates the supported codec and a related serialization byte.
|
AvroParquetReaders |
A convenience builder to create AvroParquetRecordFormat instances for the different kinds
of Avro record types.
|
AvroParquetWriters |
|
AvroRowDataDeserializationSchema |
Deserialization schema from Avro bytes to RowData .
|
AvroRowDataSerializationSchema |
Serialization schema that serializes RowData into Avro bytes.
|
AvroRowDeserializationSchema |
Deserialization schema from Avro bytes to Row .
|
AvroRowSerializationSchema |
Serialization schema that serializes Row into Avro bytes.
|
AvroSchemaConverter |
Converts an Avro schema into Flink's type information.
|
AvroSerializationSchema<T> |
Serialization schema that serializes to Avro binary format.
|
AvroSerializer<T> |
A serializer that serializes types via Avro.
|
AvroSerializerSnapshot<T> |
|
AvroToRowDataConverters |
Tool class used to convert from Avro GenericRecord to RowData .
|
AvroToRowDataConverters.AvroToRowDataConverter |
Runtime converter that converts Avro data structures into objects of Flink Table & SQL
internal data structures.
|
AvroTypeInfo<T extends org.apache.avro.specific.SpecificRecordBase> |
Special type information to generate a special AvroTypeInfo for Avro POJOs (implementing
SpecificRecordBase, the typed Avro POJOs)
|
AvroUtils |
Utility methods for dealing with Avro types.
|
AvroWriterFactory<T> |
|
AvroWriters |
Convenience builder to create AvroWriterFactory instances for the different Avro types.
|
AzureBlobFsRecoverableDataOutputStream |
|
AzureBlobRecoverableWriter |
Recoverable writer for AzureBlob file system.
|
AzureBlobStorageFSFactory |
A factory for the Azure file system over HTTP.
|
AzureDataLakeStoreGen2FSFactory |
Abfs azureFs implementation.
|
BackendBuildingException |
Exceptions which indicate that a state backend building has failed.
|
BackendRestorerProcedure<T extends Closeable & Disposable,S extends StateObject> |
This class implements the logic that creates (and potentially restores) a state backend.
|
BackendWritableBroadcastState<K,V> |
|
BackPressuringExecutor |
An executor decorator that allows only a certain number of concurrent executions.
|
BadRequestException |
Base class for exceptions thrown during querying Flink's managed state.
|
BanJunit4Rules |
Rules for modules already completed the migration of junit5.
|
BarrierAlignmentUtil |
Utility for barrier alignment.
|
BarrierAlignmentUtil.Cancellable |
A handle to a delayed action which can be cancelled.
|
BarrierAlignmentUtil.DelayableTimer |
It can register a task to be executed some time later.
|
BaseBroadcastProcessFunction |
The base class containing the functionality available to all broadcast process function.
|
BaseDatabaseMetaData |
|
BaseExpressions<InType,OutType> |
These are Java and Scala common operations that can be used to construct an Expression
AST for expression operations.
|
BaseHadoopFsRecoverableFsDataOutputStream |
Base class for ABFS and Hadoop recoverable stream.
|
BaseHybridHashTable |
|
BasePathBucketAssigner<T> |
|
BaseResultSet |
Base result set for jdbc driver with not supported features.
|
BaseStatement |
Base statement in flink driver.
|
BaseStatistics |
Interface describing the basic statistics that can be obtained from the input.
|
BaseTopology<VID extends VertexID,RID extends ResultID,V extends Vertex<VID,RID,V,R>,R extends Result<VID,RID,V,R>> |
Base topology for all logical and execution topologies.
|
BaseTwoInputStreamOperatorWithStateRetention |
|
BashJavaUtils |
Utility class for using java utilities in bash scripts.
|
BashJavaUtils.Command |
Commands that BashJavaUtils supports.
|
BasicArrayTypeInfo<T,C> |
Type information for arrays boxed primitive types.
|
BasicRequestInfo |
Dataclass to encapsulate information about starting requests.
|
BasicResultInfo |
Dataclass to encapsulate results from completed requests.
|
BasicTypeComparator<T extends Comparable<T>> |
|
BasicTypeDescriptorImpl<T> |
|
BasicTypeInfo<T> |
Type information for primitive types (int, long, double, byte, ...), String, Date, Void,
BigInteger, and BigDecimal.
|
BatchApproxCountDistinctAggFunctions |
Built-in APPROX_COUNT_DISTINCT aggregate function for Batch sql.
|
BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction<T> |
Base function for APPROX_COUNT_DISTINCT aggregate.
|
BatchApproxCountDistinctAggFunctions.ByteApproxCountDistinctAggFunction |
Built-in byte APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.DateApproxCountDistinctAggFunction |
Built-in Date APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.DecimalApproxCountDistinctAggFunction |
Built-in decimal APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.DoubleApproxCountDistinctAggFunction |
Built-in double APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.FloatApproxCountDistinctAggFunction |
Built-in float APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.IntApproxCountDistinctAggFunction |
Built-in int APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.LongApproxCountDistinctAggFunction |
Built-in long APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.ShortApproxCountDistinctAggFunction |
Built-in Short APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.StringApproxCountDistinctAggFunction |
Built-in string APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.TimeApproxCountDistinctAggFunction |
Built-in Time APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.TimestampApproxCountDistinctAggFunction |
Built-in Timestamp APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.TimestampLtzApproxCountDistinctAggFunction |
Built-in TimestampLtz APPROX_COUNT_DISTINCT aggregate function.
|
BatchArrowPythonGroupAggregateFunctionOperator |
|
BatchArrowPythonGroupWindowAggregateFunctionOperator |
|
BatchArrowPythonOverWindowAggregateFunctionOperator |
|
BatchCallbackRunner |
|
BatchCoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT> |
|
BatchCoBroadcastWithNonKeyedOperator<IN1,IN2,OUT> |
|
BatchCompactCoordinator |
Coordinator for compaction in batch mode.
|
BatchCompactOperator<T> |
CompactOperator for compaction in batch mode.
|
BatchExecBoundedStreamScan |
|
BatchExecCalc |
|
BatchExecCorrelate |
Batch exec node which matches along with join a Java/Scala user defined table function.
|
BatchExecDynamicFilteringDataCollector |
|
BatchExecExchange |
This ExecNode represents a change of partitioning of the input elements for batch.
|
BatchExecExecutionOrderEnforcer |
Batch ExecNode for ExecutionOrderEnforcer.
|
BatchExecExpand |
Batch ExecNode that can expand one row to multiple rows based on given projects.
|
BatchExecGlobalRuntimeFilterBuilder |
Batch ExecNode for global runtime filter builder.
|
BatchExecHashAggregate |
Batch ExecNode for hash-based aggregate operator.
|
BatchExecHashJoin |
|
BatchExecHashWindowAggregate |
Batch ExecNode for hash-based window aggregate operator.
|
BatchExecInputAdapter |
Batch ExecNode for multiple operator fusion codegen input, it is adapter source node.
|
BatchExecLegacySink<T> |
|
BatchExecLegacyTableSourceScan |
|
BatchExecLimit |
|
BatchExecLocalRuntimeFilterBuilder |
Batch ExecNode for local runtime filter builder.
|
BatchExecLookupJoin |
BatchExecNode for temporal table join that implemented by lookup.
|
BatchExecMatch |
Batch ExecNode which matches along with MATCH_RECOGNIZE.
|
BatchExecMultipleInput |
|
BatchExecNestedLoopJoin |
|
BatchExecNode<T> |
|
BatchExecOverAggregate |
Batch ExecNode for sort-based over window aggregate.
|
BatchExecOverAggregateBase |
Batch ExecNode base class for sort-based over window aggregate.
|
BatchExecOverAggregateBase.OverWindowMode |
OverWindowMode describes the mode of a group in over window.
|
BatchExecPythonCalc |
Batch ExecNode for Python ScalarFunctions.
|
BatchExecPythonCorrelate |
Batch exec node which matches along with join a Python user defined table function.
|
BatchExecPythonGroupAggregate |
Batch ExecNode for Python unbounded group aggregate.
|
BatchExecPythonGroupWindowAggregate |
Batch ExecNode for group widow aggregate (Python user defined aggregate function).
|
BatchExecPythonOverAggregate |
Batch ExecNode for sort-based over window aggregate (Python user defined aggregate
function).
|
BatchExecRank |
|
BatchExecRuntimeFilter |
|
BatchExecScriptTransform |
|
BatchExecSink |
|
BatchExecSort |
|
BatchExecSortAggregate |
Batch ExecNode for (global) sort-based aggregate operator.
|
BatchExecSortLimit |
|
BatchExecSortMergeJoin |
|
BatchExecSortWindowAggregate |
Batch ExecNode for sort-based window aggregate operator.
|
BatchExecTableSourceScan |
|
BatchExecUnion |
Batch ExecNode that is not a physical node and just union the inputs' records into one
node.
|
BatchExecutionCheckpointStorage |
|
BatchExecutionInternalTimeService<K,N> |
|
BatchExecutionInternalTimeServiceManager<K> |
|
BatchExecutionKeyedStateBackend<K> |
|
BatchExecutionOptions |
Configuration options for the batch job execution.
|
BatchExecutionStateBackend |
A simple StateBackend which is used in a BATCH style execution.
|
BatchExecutionUtils |
A utility class for applying sorting inputs.
|
BatchExecValues |
Batch ExecNode that read records from given values.
|
BatchExecWindowTableFunction |
Batch ExecNode for window table-valued function.
|
BatchFileWriter<T> |
An operator for writing files in batch mode.
|
BatchGroupedReduceOperator<IN,KEY> |
|
BatchJobRecoveryContext |
Context for batch job recovery.
|
BatchJobRecoveryHandler |
Interface for handling batch job recovery.
|
BatchMultipleInputStreamOperator |
|
BatchMultipleInputStreamOperatorFactory |
|
BatchPartitionCommitterSink |
Committer operator for partition in batch mode.
|
BatchPhysicalConstantTableFunctionScanRule |
Converts FlinkLogicalTableFunctionScan with constant RexCall to
|
BatchPhysicalConstantTableFunctionScanRule.BatchPhysicalConstantTableFunctionScanRuleConfig |
|
BatchPhysicalGlobalRuntimeFilterBuilder |
Batch physical RelNode responsible for aggregating all received filters into a global filter.
|
BatchPhysicalLocalRuntimeFilterBuilder |
Batch physical RelNode responsible for building a local runtime filter based on its local data.
|
BatchPhysicalMatch |
Batch physical RelNode which matches along with MATCH_RECOGNIZE.
|
BatchPhysicalMatchRule |
|
BatchPhysicalPythonAggregateRule |
The physical rule which is responsible for converting FlinkLogicalAggregate to BatchPhysicalPythonGroupAggregate .
|
BatchPhysicalPythonCorrelateRule |
The physical rule is responsible for convert FlinkLogicalCorrelate to BatchPhysicalPythonCorrelate .
|
BatchPhysicalPythonWindowAggregateRule |
The physical rule is responsible for convert FlinkLogicalWindowAggregate to BatchPhysicalPythonGroupWindowAggregate .
|
BatchPhysicalRuntimeFilter |
|
BatchPythonUdfSqlJob |
A simple job used to test submitting the Python UDF job in batch mode.
|
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.
|
BatchShuffleReadBufferPool |
A fixed-size MemorySegment pool used by batch shuffle for shuffle data read (currently
only used by sort-merge blocking shuffle).
|
BatchSink |
Helper for creating batch file sink.
|
BatchTask<S extends Function,OT> |
The base class for all batch tasks.
|
BeamBagStateHandler |
BeamBagStateHandler handles operations on ListState , which backs Beam bag states.
|
BeamDataStreamPythonFunctionRunner |
|
BeamKeyedStateStore |
A BeamStateStore that returns keyed states based on BeamFnApi.StateRequest .
|
BeamMapStateHandler |
BeamMapStateHandler handles operations on a MapState .
|
BeamOperatorStateStore |
A BeamStateStore that returns operator states based on BeamFnApi.StateRequest .
|
BeamPythonFunctionRunner |
|
BeamStateHandler<S> |
Interface for doing actual operations on Flink state based on BeamFnApi.StateRequest .
|
BeamStateRequestHandler |
The handler for Beam state requests sent from Python side, which does actual operations on Flink
state.
|
BeamStateStore |
Interface for getting the underlying state based on Beam state request (keyed state or operator
state).
|
BeamTablePythonFunctionRunner |
|
BeginStatementSetOperation |
Operation to describe a BEGIN STATEMENT SET statement.
|
BiConsumerWithException<T,U,E extends Throwable> |
|
BiFunctionWithException<T,U,R,E extends Throwable> |
|
BigDecComparator |
Comparator for comparing BigDecimal values.
|
BigDecimalTypeInfo |
|
BigDecParser |
|
BigDecSerializer |
Serializer for serializing/deserializing BigDecimal values including null values.
|
BigDecSerializer |
We create the BigDecSerializer instead of using the BigDecSerializer of flink-core module for
performance reasons in Python deserialization.
|
BigDecSerializer.BigDecSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
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.
|
BigIntType |
Logical type of an 8-byte signed integer with values from -9,223,372,036,854,775,808 to
9,223,372,036,854,775,807.
|
BigIntWriter<T> |
|
BigIntWriter.BigIntWriterForArray |
|
BigIntWriter.BigIntWriterForRow |
|
BinaryArrayData |
|
BinaryArrayWriter |
Writer for binary array.
|
BinaryArrayWriter.NullSetter |
Accessor for setting the elements of an array writer to null during runtime.
|
BinaryExternalMerger |
Record merger for sort of BinaryRowData.
|
BinaryExternalSorter |
|
BinaryFormat |
|
BinaryHashBucketArea |
Bucket area for hash table.
|
BinaryHashPartition |
A partition.
|
BinaryHashPartition.BuildSideBuffer |
Build side buffer.
|
BinaryHashPartitioner |
|
BinaryHashTable |
An implementation of a Hybrid Hash Join.
|
BinaryIndexedSortable |
abstract sortable, provide basic compare and swap.
|
BinaryInMemorySortBuffer |
In memory sort buffer for binary row.
|
BinaryInputFormat<T> |
Base class for all input formats that use blocks of fixed size.
|
BinaryKVExternalMerger |
Key-Value style record merger for sort.
|
BinaryKVInMemorySortBuffer |
In memory KV sortable buffer for binary row, it already has records in memory.
|
BinaryMapData |
[4 byte(keyArray size in bytes)] + [Key BinaryArray] + [Value BinaryArray].
|
BinaryMergeIterator<Entry> |
|
BinaryOperatorInformation<IN1,IN2,OUT> |
A class for holding information about a single input operator, such as input/output
TypeInformation.
|
BinaryOutputFormat<T> |
|
BinaryRawValueData<T> |
|
BinaryRowChannelInputViewIterator |
A simple iterator over the input read though an I/O channel.
|
BinaryRowData |
|
BinaryRowDataKeySelector |
A KeySelector which will extract key from RowData.
|
BinaryRowDataSerializer |
|
BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot |
|
BinaryRowDataUtil |
|
BinaryRowWriter |
|
BinarySection |
A basic implementation of BinaryFormat which describe a section of memory.
|
BinarySegmentUtils |
Utilities for binary data segments which heavily uses MemorySegment .
|
BinaryStringData |
|
BinaryStringDataUtil |
|
BinaryType |
Logical type of a fixed-length binary string (=a sequence of bytes).
|
BinaryWriter |
Writer to write a composite data format, like row, array. 1.
|
BinaryWriter<T> |
|
BinaryWriter.BinaryWriterForArray |
|
BinaryWriter.BinaryWriterForRow |
|
BinaryWriter.ValueSetter |
Accessor for setting the elements of an array writer during runtime.
|
BinPacking |
A bin packing implementation.
|
BitSet |
|
BlackHoleTableSinkFactory |
Black hole table sink factory swallowing all input records.
|
BlobCacheService |
The BLOB cache provides access to BLOB services for permanent and transient BLOBs.
|
BlobCacheSizeTracker |
BlobCacheSizeTracker uses LinkedHashMap to maintain the LRU order for the files in the
cache.
|
BlobClient |
The BLOB client can communicate with the BLOB server and either upload (PUT), download (GET), or
delete (DELETE) BLOBs.
|
BlobKey |
A BLOB key uniquely identifies a BLOB.
|
BlobLibraryCacheManager |
Provides facilities to download a set of libraries (typically JAR files) for a job from a PermanentBlobService and create a class loader with references to them.
|
BlobLibraryCacheManager.ClassLoaderFactory |
|
BlobServer |
This class implements the BLOB server.
|
BlobServerOptions |
Configuration options for the BlobServer and BlobCache.
|
BlobServerProtocol |
Defines constants for the protocol between the BLOB server and the caches .
|
BlobService |
A simple store and retrieve binary large objects (BLOBs).
|
BlobStore |
A blob store.
|
BlobStoreService |
Service interface for the BlobStore which allows to close and clean up its data.
|
BlobUtils |
Utility functions related to blobs.
|
BlobUtils |
Utility class to work with blob data.
|
BlobView |
|
BlobWriter |
BlobWriter is used to upload data to the BLOB store.
|
BlockChannelReader<T> |
A reader that reads data in blocks from a file channel.
|
BlockChannelWriter<T> |
A writer that writes data in blocks to a file channel.
|
BlockChannelWriterWithCallback<T> |
|
BlockCompressionFactory |
|
BlockCompressor |
A compressor which compresses a whole byte array each time.
|
BlockDecompressor |
A decompressor which decompresses a block each time.
|
BlockedNode |
This class represents a blocked node record.
|
BlockedNodeRetriever |
This class helps to retrieve the blocked nodes.
|
BlockedTaskManagerChecker |
This checker helps to query whether a given task manager is blocked.
|
BlockElement |
Part of description that represents a block e.g. some text, linebreak or a list.
|
BlockerSync |
A utility to help synchronize two threads in cases where one of them is supposed to reach a
blocking state before the other may continue.
|
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.
|
BlockingBackChannel |
A concurrent datastructure that establishes a backchannel buffer between an iteration head and an
iteration tail.
|
BlockingBackChannelBroker |
Singleton class for the threadsafe handover of BlockingBackChannel s from iteration heads
to iteration tails.
|
BlockingPhysicalFilePool |
|
BlockingQueueBroker |
|
BlockingResultInfo |
The blocking result info, which will be used to calculate the vertex parallelism and input infos.
|
BlocklistContext |
This class is responsible for blocking and unblocking resources.
|
BlocklistDeclarativeSlotPool |
|
BlocklistDeclarativeSlotPoolFactory |
|
BlocklistHandler |
This class is responsible for managing all BlockedNode s and performing them on resources.
|
BlocklistHandler.Factory |
|
BlocklistListener |
A listener that want to be notified when blocklist changes.
|
BlocklistOperations |
Operations to perform on the blocklist.
|
BlocklistTracker |
A tracker for blocklist.
|
BlocklistUtils |
Utility class for blocklist.
|
BlockLocation |
A BlockLocation lists hosts, offset and length of block.
|
BlockResettableMutableObjectIterator<T> |
Implementation of an iterator that fetches a block of data into main memory and offers resettable
access to the data in that block.
|
BlockSplittingRecursiveAllDirEnumerator |
This FileEnumerator enumerates all files under the given paths recursively except the
hidden directories, and creates a separate split for each file block.
|
BlockSplittingRecursiveEnumerator |
This FileEnumerator enumerates all files under the given paths recursively, and creates a
separate split for each file block.
|
BlockStatementGrouper |
Groups end extract single line statements such as operations on fields/local variables, IF and
WHILE statements and extract new method for each group making them smaller.
|
BlockStatementGrouper.RewriteGroupedCode |
This object represents a rewritten code block.
|
BlockStatementRewriter |
Extract branch of IFs, ELSEs statements and WHILEs code blocks into smaller methods.
|
BlockStatementSplitter |
Extract statements from IFs, ELSEs and WHILEs blocks making them smaller.
|
BloomFilter |
BloomFilter is a probabilistic data structure for set membership check.
|
BooleanArrayList |
Minimal implementation of an array-backed list of booleans
|
BooleanColumnReader |
|
BooleanColumnVector |
Boolean column vector.
|
BooleanComparator |
|
BooleanConditions |
Utility class containing an IterativeCondition that always returns true and one
that always returns false .
|
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.
|
BooleanType |
Logical type of a boolean with a (possibly) three-valued logic of TRUE, FALSE, UNKNOWN .
|
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.
|
BooleanWriter<T> |
|
BooleanWriter.BooleanWriterForArray |
|
BooleanWriter.BooleanWriterForRow |
|
BootstrapStreamTaskRunner<IN> |
The runtime for a BootstrapStreamTask .
|
BootstrapTools |
Tools for starting JobManager and TaskManager processes.
|
BoundedBlockingResultPartition |
A output data result of an individual task (one partition of an intermediate result), produced
and communicated in a batch manner: The result must be produced completely before it can be
consumed.
|
BoundedBlockingSubpartitionDirectTransferReader |
The reader (read view) of a BoundedBlockingSubpartition based on FileRegion .
|
BoundedBlockingSubpartitionType |
The type of the BoundedBlockingSubpartition.
|
BoundedFIFOQueue<T> |
BoundedFIFOQueue collects elements up to given amount.
|
BoundedInputStream |
Wrapper around a FSDataInputStream to limit the maximum read offset.
|
BoundedMultiInput |
Interface for multi-input operators that need to be notified about the logical/semantical end of
input.
|
Boundedness |
The boundedness of a stream.
|
BoundedOneInput |
Interface for one-input operators that need to be notified about the logical/semantical end of
input.
|
BoundedOutOfOrdernessTimestampExtractor<T> |
|
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.
|
BoundedOutOfOrderTimestamps |
A watermark strategy for rowtime attributes which are out-of-order by a bounded time interval.
|
BoundedOutOfOrderWatermarkGenerator |
A watermark generator for rowtime attributes which are out-of-order by a bounded time interval.
|
BoxedWrapperRowData |
|
BridgingSqlAggFunction |
Bridges FunctionDefinition to Calcite's representation of an aggregating function (either
a system or user-defined function).
|
BridgingSqlFunction |
Bridges FunctionDefinition to Calcite's representation of a scalar or table function
(either a system or user-defined function).
|
BridgingSqlFunction.WithTableFunction |
|
BridgingSqlProcedure |
Bridges Procedure to Calcite's representation of a function.
|
BroadcastConnectedStream<IN1,IN2> |
|
BroadcastingOutput |
An Output that can be used to emit elements and other messages to multiple outputs.
|
BroadcastPartitioner<T> |
Partitioner that selects all the output channels.
|
BroadcastProcessFunction<IN1,IN2,OUT> |
|
BroadcastRecordWriter<T extends IOReadableWritable> |
A special record-oriented runtime result writer only for broadcast mode.
|
BroadcastState<K,V> |
A type of state that can be created to store the state of a BroadcastStream .
|
BroadcastStateBootstrapFunction<IN> |
Interface for writing elements to broadcast state.
|
BroadcastStateBootstrapFunction.Context |
|
BroadcastStateBootstrapOperator<IN> |
|
BroadcastStateDeclaration<K,V> |
This represents a declaration of the broadcast state.
|
BroadcastStateInputFormat<K,V> |
|
BroadcastStateTransformation<IN1,IN2,OUT> |
|
BroadcastStateTransformationTranslator<IN1,IN2,OUT> |
|
BroadcastStream<T> |
This interface represents a stream that each parallel task processes the same data.
|
BroadcastStream<T> |
|
BroadcastStreamImpl<T> |
|
BroadcastVariableInitializer<T,O> |
A broadcast variable initializer can be used to transform a broadcast variable into another
format during initialization.
|
BroadcastVariableKey |
|
BroadcastVariableManager |
The BroadcastVariableManager is used to manage the materialization of broadcast variables.
|
BroadcastVariableMaterialization<T,C> |
This class represents a single materialization of a broadcast variable and maintains a reference
count for it.
|
Broker<V> |
A concurrent data structure that allows the hand-over of an object between a pair of threads.
|
BTrimFunction |
|
Bucket<IN,BucketID> |
|
BucketAssigner<IN,BucketID> |
A BucketAssigner is used with a file sink to determine the bucket each incoming element should be
put into.
|
BucketAssigner.Context |
Context that the BucketAssigner can use for getting additional data about an input
record.
|
BucketFactory<IN,BucketID> |
|
BucketingSpec |
No properties.
|
BucketLifeCycleListener<IN,BucketID> |
Listener about the status of Bucket .
|
Buckets<IN,BucketID> |
|
BucketWriter<IN,BucketID> |
An interface for factories that create the different writers .
|
BucketWriter.PendingFile |
This represents the file that can not write any data to.
|
Buffer |
Wrapper for pooled MemorySegment instances with reference counting.
|
Buffer.DataType |
Used to identify the type of data contained in the Buffer so that we can get the
information without deserializing the serialized data.
|
BufferAccumulator |
Accumulates received records into buffers.
|
BufferAvailabilityListener |
Listener interface implemented by consumers of ResultSubpartitionView that want to be
notified of availability of further buffers.
|
BufferBuilder |
Not thread safe class for filling in the content of the MemorySegment .
|
BufferBundle<T> |
A BufferBundle is a bundle to buffer the input records in memory and fold data based on
specified pattern to reduce state access.
|
BufferCompressionException |
A BufferCompressionException is thrown when the target data cannot be compressed, such as
insufficient target buffer space for compression, etc.
|
BufferCompressor |
|
BufferConsumer |
Not thread safe class for producing Buffer .
|
BufferConsumerWithPartialRecordLength |
BufferConsumer with partial record length if a record is spanning over buffers
|
BufferDataOverWindowOperator |
the operator for OVER window need cache data by ResettableExternalBuffer for OverWindowFrame .
|
BufferDebloatConfiguration |
|
BufferDebloater |
Class for automatic calculation of the buffer size based on the current throughput and
configuration.
|
BufferDecompressionException |
A BufferDecompressionException is thrown when the target data cannot be decompressed,
such as data corruption, insufficient target buffer space for decompression, etc.
|
BufferDecompressor |
Decompressor for compressed Buffer .
|
BufferedKVExternalSorter |
Sorter for buffered input in the form of Key-Value Style.
|
BufferedRequestState<RequestEntryT extends Serializable> |
|
BufferFileChannelReader |
Helper class to read Buffer s from files into objects.
|
BufferFileReader |
|
BufferFileSegmentReader |
|
BufferFileWriter |
|
BufferHeader |
|
BufferListener |
Interface of the availability of buffers.
|
BufferManager |
The general buffer manager used by InputChannel to request/recycle exclusive or floating
buffers.
|
BufferOrEvent |
Either type for Buffer or AbstractEvent instances tagged with the channel index,
from which they were received.
|
BufferPool |
A dynamically sized buffer pool.
|
BufferPoolFactory |
A factory for buffer pools.
|
BufferProvider |
A buffer provider to request buffers from in a synchronous or asynchronous fashion.
|
BufferReaderWriterUtil |
Putting and getting of a sequence of buffers to/from a FileChannel or a ByteBuffer.
|
BufferRecycler |
|
BufferRecycler.DummyBufferRecycler |
The buffer recycler does nothing for recycled segment.
|
BufferSizeEMA |
Implementation of 'Exponential moving average' algorithm.
|
BufferWithSubpartition |
Buffer and the corresponding subpartition index.
|
BufferWritingResultPartition |
|
BuildFirstCachedJoinDriver<IT1,IT2,OT> |
|
BuildSecondCachedJoinDriver<IT1,IT2,OT> |
|
BuildSideIterator |
Iterate all the elements in memory which has not been(or has been) probed during probe phase.
|
BuildSideIterator.BucketIterator |
Partition bucket iterator.
|
BuiltInAggregateFunction<T,ACC> |
|
BuiltInFunctionDefinition |
Definition of a built-in function.
|
BuiltInFunctionDefinition.Builder |
Builder for fluent definition of built-in functions.
|
BuiltInFunctionDefinitions |
Dictionary of function definitions for all built-in functions.
|
BuiltInPythonAggregateFunction |
The list of the built-in aggregate functions which can be mixed with the Python UDAF.
|
BuiltInScalarFunction |
|
BuiltInSpecializedFunction |
|
BuiltInSqlFunction |
|
BuiltInSqlFunction.Builder |
Builder for fluent definition of built-in functions.
|
BuiltInSqlOperator |
|
BuiltInTableFunction<T> |
|
BulkBlockChannelReader |
|
BulkBucketWriter<IN,BucketID> |
A factory that creates BulkPartWriters .
|
BulkDecodingFormat<T> |
|
BulkFormat<T,SplitT extends FileSourceSplit> |
The BulkFormat reads and decodes batches of records at a time.
|
BulkFormat.Reader<T> |
The actual reader that reads the batches of records.
|
BulkFormat.RecordIterator<T> |
An iterator over records with their position in the file.
|
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
|
BulkReaderFormatFactory |
Base interface for configuring a BulkFormat for file system connector.
|
BulkWriter<T> |
An encoder that encodes data in a bulk fashion, encoding many records together at a time.
|
BulkWriter.Factory<T> |
|
BulkWriterFormatFactory |
|
BundledCacheLimitPolicy |
A bundled cache limit policy, any two cache policies can be combined.
|
BundleTrigger<T> |
A BundleTrigger determines when a bundle of input elements should be evaluated and
trigger the callback which registered previously.
|
BundleTriggerCallback |
Interface for bundle trigger callbacks that can be registered to a BundleTrigger .
|
ByteArrayConstructor |
Creates byte arrays (byte[]).
|
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.
|
ByteArrayWrapper |
A wrapper of the byte array.
|
ByteArrayWrapperSerializer |
|
ByteArrayWrapperSerializer.ByteArrayWrapperSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
ByteBufferReadable |
An interface mark that a filesystem supports to read bytes from a ByteBuffer and its
given position.
|
ByteBufferReadableClosingFSDataInputStream |
|
ByteBufferReadableFSDataInputStream |
|
ByteBufferWritableFSDataOutputStream |
|
ByteBufUtils |
Utility routines to process ByteBuf .
|
ByteColumnReader |
|
ByteColumnVector |
Byte column vector.
|
ByteComparator |
|
ByteHashSet |
Byte hash set.
|
ByteParser |
|
BytePrimitiveArrayComparator |
|
BytePrimitiveArraySerializer |
A serializer for byte arrays.
|
BytePrimitiveArraySerializer.BytePrimitiveArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
BytesColumnReader |
|
BytesColumnVector |
|
BytesColumnVector.Bytes |
Bytes data.
|
ByteSerializer |
Type serializer for Byte .
|
ByteSerializer.ByteSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
BytesHashMap |
A binary map in the structure like Map<BinaryRowData, BinaryRowData> .
|
BytesHashMapSpillMemorySegmentPool |
MemorySegmentPool for BytesHashMap to fall back to sort agg.
|
BytesMap<K,V> |
|
BytesMap.LookupInfo<K,V> |
Result fetched when looking up a key.
|
BytesMultiMap |
A binary map in the structure like Map<BinaryRowData, List<BinaryRowData>> .
|
ByteStreamStateHandle |
A state handle that contains stream state in a byte array.
|
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.
|
CachedDataInputStream |
|
CachedDataOutputStream |
|
CachedDataStream<T> |
|
CachedPlan |
SQL execution plan cache.
|
CachedShuffleDescriptors |
|
CacheLimitPolicy |
Space checker.
|
CacheLoader |
|
CacheMetricGroup |
Pre-defined metrics for cache.
|
CacheReloadTrigger |
Customized trigger for reloading lookup table entries.
|
CacheReloadTrigger.Context |
|
CacheSupportedPipelineExecutor |
The pipeline executor that support caching intermediate dataset.
|
CacheTransformation<T> |
When in batch mode, the CacheTransformation represents the intermediate result of the
upper stream should be cached when it is computed at the first time.
|
CacheTransformationTranslator<OUT,T extends CacheTransformation<OUT>> |
|
CacheTransformationTranslator.IdentityStreamOperator<T> |
|
CacheTransformationTranslator.NoOpStreamOperator<T> |
|
CachingAsyncLookupFunction |
A wrapper function around user-provided async lookup function with a cache layer.
|
CachingLookupFunction |
A wrapper function around user-provided lookup function with a cache layer.
|
CalciteContext |
To provide calcite context which is mainly used to create Calcite's RelNode.
|
CalciteParser |
Thin wrapper around SqlParser that does exception conversion and SqlNode casting.
|
CalciteSchemaBuilder |
This class is used to create a CalciteSchema with a given Schema as the root.
|
CalcPythonCorrelateTransposeRule |
Rule will transpose the conditions after the Python correlate node if the join type is inner
join.
|
CalculatedQueryOperation |
Describes a relational operation that was created from applying a TableFunction .
|
CallAsync |
Message for asynchronous callable invocations.
|
CallBindingCallContext |
|
CallContext |
|
CallExpression |
Resolved and validated call expression for calling a function.
|
CallExpressionConvertRule |
|
CallExpressionConvertRule.ConvertContext |
|
CallExpressionResolver |
|
CallProcedureOperation |
A Operation that describes the call procedure statement.
|
CanalJsonDecodingFormat |
|
CanalJsonDeserializationSchema |
Deserialization schema from Canal JSON to Flink Table/SQL internal data structure RowData .
|
CanalJsonDeserializationSchema.Builder |
|
CanalJsonFormatFactory |
|
CanalJsonFormatOptions |
Option utils for canal-json format.
|
CanalJsonSerializationSchema |
Serialization schema that serializes an object of Flink Table/SQL internal data structure RowData into a Canal JSON bytes.
|
CancelCheckpointMarker |
The CancelCheckpointMarker travels through the data streams, similar to the CheckpointBarrier , but signals that a certain checkpoint should be canceled.
|
CancelOperationHandler |
Handler to cancel operation.
|
CancelOperationHeaders |
Message headers for canceling operation.
|
CancelOptions |
Command line options for the CANCEL command.
|
CancelTaskException |
Thrown to trigger a canceling of the executing task.
|
CapitalizeQueryHintsShuttle |
A shuttle to capitalize all query hints on corresponding nodes.
|
CarGeneratorFunction |
A generator function for simulating car data.
|
CastCodeBlock |
Generated cast code block result.
|
CastExecutor<IN,OUT> |
Interface to model a function that performs the casting of a value from one type to another.
|
CastRule<IN,OUT> |
A CastRule provides the logic to create a CastExecutor starting from the input
and the target types.
|
CastRule.Context |
Casting context.
|
CastRulePredicate |
In order to apply a CastRule , the runtime checks if a particular rule matches the tuple
of input and target type using this class.
|
CastRulePredicate.Builder |
|
CastRuleProvider |
This class resolves CastRule using the input and the target type.
|
Catalog |
This interface is responsible for reading and writing metadata such as database/table/views/UDFs
from a registered catalog.
|
CatalogBaseTable |
A common parent that describes the unresolved metadata of a table or view in a catalog.
|
CatalogBaseTable.TableKind |
|
CatalogCalciteSchema |
A mapping between Flink's catalog and Calcite's schema.
|
CatalogChange |
|
CatalogChange.CatalogCommentChange |
A catalog change to modify the comment.
|
CatalogChange.CatalogConfigurationChange |
A catalog change to modify the catalog configuration.
|
CatalogColumnStatistics |
Column statistics of a table or partition.
|
CatalogColumnStatisticsDataBase |
Column statistics value base class.
|
CatalogColumnStatisticsDataBinary |
Column statistics value of binary type.
|
CatalogColumnStatisticsDataBoolean |
Column statistics value of boolean type.
|
CatalogColumnStatisticsDataDate |
Column statistics value of date type.
|
CatalogColumnStatisticsDataDouble |
Column statistics value of double type.
|
CatalogColumnStatisticsDataLong |
Column statistics value of long type.
|
CatalogColumnStatisticsDataString |
Column statistics value of string type.
|
CatalogContext |
Context for catalog which provides the name, factory identifier and configuration to identify the
same physical catalog for different logical catalog.
|
CatalogDatabase |
Interface of a database in a catalog.
|
CatalogDatabaseImpl |
|
CatalogDescriptor |
Describes a Catalog with the catalog name and configuration.
|
CatalogException |
A catalog-related, runtime exception.
|
CatalogFactory |
A factory to create configured catalog instances based on string-based properties.
|
CatalogFactory.Context |
Context provided when a catalog is created.
|
CatalogFunction |
Interface for a function in a catalog.
|
CatalogFunctionImpl |
A catalog function implementation.
|
CatalogLock |
Deprecated.
|
CatalogLock.Factory |
Deprecated.
|
CatalogManager |
A manager for dealing with catalog objects such as tables, views, functions, and types.
|
CatalogManager.Builder |
|
CatalogManagerCalciteSchema |
|
CatalogMaterializedTable |
Represents the unresolved metadata of a materialized table in a Catalog .
|
CatalogMaterializedTable.Builder |
|
CatalogMaterializedTable.LogicalRefreshMode |
The logical refresh mode of materialized table.
|
CatalogMaterializedTable.RefreshMode |
The physical refresh mode of materialized table.
|
CatalogMaterializedTable.RefreshStatus |
Background refresh pipeline status of materialized table.
|
CatalogModel |
Interface for a model in a catalog.
|
CatalogModificationEvent |
The basic interface for catalog modification event, all database and table related events are
implements this interface.
|
CatalogModificationListener |
A listener that is notified on specific catalog changed in catalog manager.
|
CatalogModificationListenerFactory |
A factory to create catalog modification listener instances based on context which contains job
configuration and user classloader.
|
CatalogModificationListenerFactory.Context |
Context provided when a listener is created.
|
CatalogNotExistException |
Exception for an operation on a nonexistent catalog.
|
CatalogPartition |
Represents a partition object in catalog.
|
CatalogPartitionImpl |
A catalog partition implementation.
|
CatalogPartitionSpec |
Represents a partition spec object in catalog.
|
CatalogPropertiesUtil |
Utilities for de/serializing Catalog objects into a map of string properties.
|
CatalogRegistry |
A catalog registry for dealing with catalogs.
|
CatalogSchemaTable |
|
CatalogSourceTable |
A FlinkPreparingTableBase implementation which defines the interfaces required to
translate the Calcite RelOptTable to the Flink specific TableSourceTable .
|
CatalogStore |
Represents the storage where persists all Catalog s.
|
CatalogStoreFactory |
A factory to create configured catalog store instances based on string-based properties.
|
CatalogStoreFactory.Context |
Context provided when a catalog store is created.
|
CatalogStoreHolder |
|
CatalogStoreHolder.Builder |
|
CatalogTable |
Represents the unresolved metadata of a table in a Catalog .
|
CatalogTable.Builder |
Builder for configuring and creating instances of CatalogTable .
|
CatalogTableImpl |
Deprecated.
|
CatalogTableStatistics |
Statistics for a non-partitioned table or a partition of a partitioned table.
|
CatalogTableStatisticsConverter |
|
CatalogTableStats |
Class to describe catalog table statistics.
|
CatalogView |
Represents the unresolved metadata of a view in a Catalog .
|
CatalogViewImpl |
Deprecated.
|
CEP |
Utility class for complex event processing.
|
CEPCacheOptions |
CEP Cache Options.
|
CepOperator<IN,KEY,OUT> |
CEP pattern operator for a keyed input stream.
|
ChainedAllReduceDriver<IT> |
|
ChainedDriver<IT,OT> |
The interface to be implemented by drivers that do not run in an own task context, but are
chained to other tasks.
|
ChainedFlatMapDriver<IT,OT> |
|
ChainedMapDriver<IT,OT> |
|
ChainedOperatorHashInfo |
Helper class to help maintain the hash info of an operator chain.
|
ChainedReduceCombineDriver<T> |
Chained version of ReduceCombineDriver.
|
ChainedSourceInfo |
Helper class to help maintain the chained source info of an operator chain.
|
ChainedStateHandle<T extends StateObject> |
Handle to state handles for the operators in an operator chain.
|
ChainingOptimizingExecutor |
Executor which will perform chaining optimization before generating the StreamGraph.
|
ChainingStrategy |
Defines the chaining scheme for the operator.
|
ChangelogApplierFactory |
|
ChangelogBackendRestoreOperation |
|
ChangelogBackendRestoreOperation.BaseBackendBuilder<K> |
|
ChangelogBackendRestoreOperation.ChangelogRestoreTargetBuilder<K> |
|
ChangelogCollectResult |
Collects results and returns them as a changelog.
|
ChangelogCsvDeserializer |
|
ChangelogCsvFormat |
|
ChangelogCsvFormatFactory |
|
ChangelogKeyedStateBackend<K> |
A KeyedStateBackend that keeps state on the underlying delegated keyed state backend as
well as on the state change log.
|
ChangelogKeyGroupedPriorityQueue<T> |
|
ChangelogMaterializationMetricGroup |
Metrics related to the materialization part of Changelog.
|
ChangelogMigrationRestoreTarget<K> |
|
ChangelogMode |
The set of changes contained in a changelog.
|
ChangelogMode.Builder |
|
ChangelogRestoreTarget<K> |
Maintains metadata operation related to Changelog recovery.
|
ChangelogResult |
A result that is represented as a changelog consisting of insert and delete records.
|
ChangelogSocketExample |
|
ChangelogState |
|
ChangelogStateBackend |
This state backend holds the working state in the underlying delegatedStateBackend, and forwards
state changes to State Changelog.
|
ChangelogStateBackendHandle |
A handle to ChangelogStateBackend state.
|
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl |
|
ChangelogStateBackendLocalHandle |
|
ChangelogStateFactory |
|
ChangelogStateHandle |
|
ChangelogStateHandleStreamImpl |
|
ChangelogStorageMetricGroup |
Metrics related to the Changelog Storage used by the Changelog State Backend.
|
ChangelogTaskLocalStateStore |
|
ChannelReaderInputView |
|
ChannelReaderInputViewIterator<E> |
A simple iterator over the input read though an I/O channel.
|
ChannelReaderKVInputViewIterator<K,V> |
Key-Value style channel reader input view iterator.
|
ChannelSelector<T extends IOReadableWritable> |
The ChannelSelector determines to which logical channels a record should be written to.
|
ChannelSelectorRecordWriter<T extends IOReadableWritable> |
A regular record-oriented runtime result writer.
|
ChannelStateHolder |
Implemented by entities that hold any kind of channel state and need a reference to the ChannelStateWriter .
|
ChannelStatePendingResult |
The pending result of channel state for a specific checkpoint-subtask.
|
ChannelStatePersister |
|
ChannelStateWriter |
Writes channel state during checkpoint/savepoint.
|
ChannelStateWriter.ChannelStateWriteResult |
Channel state write result.
|
ChannelStateWriter.NoOpChannelStateWriter |
|
ChannelStateWriteRequestExecutorFactory |
The factory of ChannelStateWriteRequestExecutor .
|
ChannelStateWriterImpl |
|
ChannelWithMeta |
Channel with block count and numBytesInLastBlock of file.
|
ChannelWriterOutputView |
|
CharacterFilter |
Interface for a character filter function.
|
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.
|
CharType |
Logical type of a fixed-length character string.
|
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.
|
CheckedSupplier<R> |
|
CheckedThread |
A thread that additionally catches exceptions and offers a joining method that re-throws the
exceptions.
|
Checkpoint |
A checkpoint, pending or completed.
|
Checkpoint.DiscardObject |
Extra interface for discarding the checkpoint.
|
CheckpointableInput |
Input, with just basic methods for blocking and resuming consumption.
|
CheckpointableInputFormat<S extends InputSplit,T extends Serializable> |
An interface that describes InputFormat s that allow checkpointing/restoring their state.
|
CheckpointableKeyedStateBackend<K> |
Interface that combines both, the KeyedStateBackend interface, which encapsulates methods
responsible for keyed state management and the Snapshotable which tells the system how to
snapshot the underlying state.
|
CheckpointableTask |
A task that participates in checkpointing.
|
CheckpointBarrier |
Checkpoint barriers are used to align checkpoints throughout the streaming topology.
|
CheckpointBarrierHandler |
|
CheckpointBarrierTracker |
|
CheckpointBoundKeyedStateHandle |
|
CheckpointCommittableManager<CommT> |
A CheckpointCommittableManager collects committables for one checkpoint across
potentially multiple upstream subtasks.
|
CheckpointCommitter |
This class is used to save information about which sink operator instance has committed
checkpoints to a backend.
|
CheckpointConfig |
Configuration that captures all checkpointing related settings.
|
CheckpointConfigHandler |
Handler which serves the checkpoint configuration.
|
CheckpointConfigHeaders |
|
CheckpointConfigInfo |
|
CheckpointConfigInfo.ExternalizedCheckpointInfo |
Contains information about the externalized checkpoint configuration.
|
CheckpointConfigInfo.ProcessingMode |
Processing mode.
|
CheckpointConfigInfo.ProcessingModeDeserializer |
Processing mode deserializer.
|
CheckpointConfigInfo.ProcessingModeSerializer |
|
CheckpointCoordinator |
The checkpoint coordinator coordinates the distributed snapshots of operators and state.
|
CheckpointCoordinatorConfiguration |
|
CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder |
|
CheckpointCoordinatorDeActivator |
This actor listens to changes in the JobStatus and activates or deactivates the periodic
checkpoint scheduler.
|
CheckpointCoordinatorGateway |
RPC Gateway interface for messages to the CheckpointCoordinator.
|
CheckpointedCollectResultBuffer<T> |
A buffer which encapsulates the logic of dealing with the response from the CollectSinkFunction .
|
CheckpointedFunction |
This is the core interface for stateful transformation functions, meaning functions that
maintain state across individual stream records.
|
CheckpointedInputGate |
|
CheckpointedPosition |
The position of a reader, to be stored in a checkpoint.
|
CheckpointedResultPartition |
Interface for partitions that are checkpointed, meaning they store data as part of unaligned
checkpoints.
|
CheckpointedStateScope |
The scope for a chunk of checkpointed state.
|
CheckpointException |
Base class for checkpoint related exceptions.
|
CheckpointFailureManager |
The checkpoint failure manager which centralized manage checkpoint failure processing logic.
|
CheckpointFailureManager.FailJobCallback |
A callback interface about how to fail a job.
|
CheckpointFailureReason |
Various reasons why a checkpoint was failure.
|
CheckpointHandlers |
HTTP handlers for asynchronous triggering of checkpoints.
|
CheckpointHandlers.CheckpointStatusHandler |
HTTP handler to query for the status of the checkpoint.
|
CheckpointHandlers.CheckpointTriggerHandler |
Handler for the checkpoint trigger operation.
|
CheckpointIDCounter |
A checkpoint ID counter.
|
CheckpointIdPathParameter |
Path parameter for the checkpoint id of type Long .
|
CheckpointInfo |
Represents information about a triggered checkpoint.
|
CheckpointingMode |
The checkpointing mode defines what consistency guarantees the system gives in the presence of
failures.
|
CheckpointingMode |
Deprecated.
|
CheckpointingOptions |
A collection of all configuration options that relate to checkpoints and savepoints.
|
CheckpointingStatistics |
|
CheckpointingStatistics.Counts |
Checkpoint counts.
|
CheckpointingStatistics.LatestCheckpoints |
Statistics about the latest checkpoints.
|
CheckpointingStatistics.RestoredCheckpointStatistics |
Statistics for a restored checkpoint.
|
CheckpointingStatistics.Summary |
Checkpoint summary.
|
CheckpointingStatisticsHandler |
Handler which serves the checkpoint statistics.
|
CheckpointingStatisticsHeaders |
|
CheckpointListener |
This interface is typically only needed for transactional interaction with the "outside world",
like committing external side effects on checkpoints.
|
CheckpointMessageParameters |
Message parameters for checkpoint related messages.
|
CheckpointMetadata |
The metadata of a snapshot (checkpoint or savepoint).
|
CheckpointMetaData |
Encapsulates all the meta data for a checkpoint.
|
CheckpointMetadataOutputStream |
An output stream for checkpoint metadata.
|
CheckpointMetrics |
A collection of simple metrics, around the triggering of a checkpoint.
|
CheckpointMetricsBuilder |
|
CheckpointOptions |
Command line options for the CHECKPOINT command.
|
CheckpointOptions |
Options for performing the checkpoint.
|
CheckpointOptions.AlignmentType |
How a checkpoint should be aligned.
|
CheckpointPlan |
The plan of one checkpoint, indicating which tasks to trigger, waiting for acknowledge or commit
for one specific checkpoint.
|
CheckpointPlanCalculator |
Calculates the plan of the next checkpoint, including the tasks to trigger, wait or commit for
each checkpoint.
|
CheckpointPlanCalculatorContext |
|
CheckpointProperties |
The configuration of a checkpoint.
|
CheckpointRecoveryFactory |
A factory for per Job checkpoint recovery components.
|
CheckpointResourcesCleanupRunner |
CheckpointResourcesCleanupRunner implements JobManagerRunner in a way, that only
the checkpoint-related resources are instantiated.
|
CheckpointResourcesCleanupRunnerFactory |
|
CheckpointResponder |
Responder for checkpoint acknowledge and decline messages in the Task .
|
CheckpointRetentionPolicy |
Policy for whether checkpoints are retained after a job terminates.
|
CheckpointRollingPolicy<IN,BucketID> |
|
CheckpointRollingPolicy.PolicyBuilder<IN,BucketID,T extends CheckpointRollingPolicy.PolicyBuilder<IN,BucketID,T>> |
|
Checkpoints |
A utility class with the methods to write/load/dispose the checkpoint and savepoint metadata.
|
CheckpointScheduling |
CheckpointScheduling provides methods for starting and stopping the periodic scheduling
of checkpoints.
|
CheckpointsCleaner |
Delegate class responsible for checkpoints cleaning and counting the number of checkpoints yet to
clean.
|
CheckpointStateOutputStream |
|
CheckpointStateToolset |
A toolset of operations that can be performed on a location embedded within the class.
|
CheckpointStatisticDetailsHandler |
REST handler which returns the details for a checkpoint.
|
CheckpointStatisticDetailsHeaders |
|
CheckpointStatistics |
Statistics for a checkpoint.
|
CheckpointStatistics.CompletedCheckpointStatistics |
Statistics for a completed checkpoint.
|
CheckpointStatistics.FailedCheckpointStatistics |
Statistics for a failed checkpoint.
|
CheckpointStatistics.PendingCheckpointStatistics |
Statistics for a pending checkpoint.
|
CheckpointStatsCache |
A size-based cache of accessed checkpoints for completed and failed checkpoints.
|
CheckpointStatsCounts |
Counts of checkpoints.
|
CheckpointStatsHistory |
An array based history of checkpoint stats.
|
CheckpointStatsListener |
An interface that allows listening on the checkpoint lifecycle.
|
CheckpointStatsSnapshot |
A snapshot of the checkpoint stats.
|
CheckpointStatsStatus |
Status of the tracked checkpoint.
|
CheckpointStatsTracker |
Tracker for checkpoint statistics.
|
CheckpointStatusHeaders |
These headers define the protocol for querying the status of a checkpoint operation.
|
CheckpointStatusMessageParameters |
The parameters for triggering a checkpoint.
|
CheckpointStorage |
CheckpointStorage defines how StateBackend 's store their state for fault tolerance in
streaming applications.
|
CheckpointStorageAccess |
Implementations of this interface should implement methods acting as an administration role for
checkpoint storage, which defined in CheckpointStorageCoordinatorView .
|
CheckpointStorageCoordinatorView |
|
CheckpointStorageFactory<T extends CheckpointStorage> |
|
CheckpointStorageLoader |
This class contains utility methods to load checkpoint storage from configurations.
|
CheckpointStorageLocation |
A storage location for one particular checkpoint, offering data persistent, metadata persistence,
and lifecycle/cleanup methods.
|
CheckpointStorageLocationReference |
A reference to a storage location.
|
CheckpointStorageWorkerView |
This interface implements the durable storage of checkpoint data and metadata streams.
|
CheckpointStoreUtil |
|
CheckpointStreamFactory |
A factory for checkpoint output streams, which are used to persist data for checkpoints.
|
CheckpointStreamWithResultProvider |
Interface that provides access to a CheckpointStateOutputStream and a method to provide the
SnapshotResult .
|
CheckpointStreamWithResultProvider.KeyedStateHandleFactory |
|
CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream |
|
CheckpointStreamWithResultProvider.PrimaryStreamOnly |
|
CheckpointTriggerHeaders |
These headers define the protocol for triggering a checkpoint.
|
CheckpointTriggerMessageParameters |
The parameters for triggering a checkpoint.
|
CheckpointTriggerRequestBody |
|
CheckpointType |
Describes the type in which a checkpoint should be taken.
|
CheckpointType |
The type of checkpoint to perform.
|
ChecksumUtils |
Utility class related to checksums.
|
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.
|
Chunk |
Chunk is a logically contiguous space backed by one or multiple ByteBuffer .
|
ChunkedByteBuf |
A ByteBuf instance to be consumed in chunks by ChunkedWriteHandler , respecting
the high and low watermarks.
|
ClassDataTypeConverter |
|
ClassDataTypeConverter |
Class-based data type extractor that supports extraction of clearly identifiable data types for
input and output conversion.
|
ClassLayout |
Mock class avoid a dependency on OpenJDK JOL, which is incompatible with the Apache License.
|
ClassLeakCleaner |
Utilities to clean up the leaking classes.
|
ClassLoaderTestProgram |
End-to-end test program for verifying that the classloader.resolve-order setting is being
honored by Flink.
|
ClassLoaderUtil |
Utilities for information with respect to class loaders, specifically class loaders for the
dynamic loading of user defined classes.
|
ClassLoadingUtils |
Classloading utilities.
|
ClassLogicalTypeConverter |
Get internal(sql engine execution data formats) and default external class for LogicalType .
|
CleanupOnCloseRpcSystem |
An RpcSystem wrapper that cleans up resources after the RPC system has been closed.
|
CleanupOptions |
ConfigOption collection for the configuration of repeatable cleanup of resource cleanup
after a job reached a globally-terminated state.
|
CleanupRetryStrategyFactory |
|
CleanupRunnerFactory |
|
CleanupState |
|
CleanupWhenUnsuccessful |
OutputFormat s may implement this interface to run a cleanup hook when the execution is
not successful.
|
ClearOperation |
Operation to represent CLEAR command.
|
ClearOperationParseStrategy |
|
ClearQueryBlockAliasResolver |
A shuttle to remove query block alias hint.
|
ClearQueryHintsOnUnmatchedNodesShuttle |
Clear the invalid query hints in the unmatched nodes.
|
ClearQueryHintsWithInvalidPropagationShuttle |
Due to Calcite will expand the whole SQL RelNode tree that contains query block, query hints
(including join hints and state ttl hints) will be propagated from root to leaves in the whole
RelNode tree.
|
CLI |
A simple CLI parser for the WordCount
example application.
|
CliArgsException |
Special exception that is thrown when the command line parsing fails.
|
CliChangelogResultView |
CLI view for retrieving and displaying a changelog stream.
|
CliChangelogResultView.ResultChangelogOperation |
Available operations for this view.
|
CliClient |
SQL CLI client.
|
CliClient.ExecutionMode |
Mode of the execution.
|
Client<REQ extends MessageBody,RESP extends MessageBody> |
The base class for every client in the queryable state module.
|
ClientAndIterator<E> |
A pair of an Iterator to receive results from a streaming application and a JobClient to interact with the program.
|
ClientClassloaderUtil |
|
ClientCoordinationHandler |
Handler that receives the coordination requests from the client and returns the response from the
coordinator.
|
ClientCoordinationHeaders |
|
ClientCoordinationMessageParameters |
|
ClientCoordinationRequestBody |
|
ClientCoordinationResponseBody |
|
ClientHandler<REQ extends MessageBody,RESP extends MessageBody> |
The handler used by a Client to handling incoming messages.
|
ClientHandlerCallback<RESP extends MessageBody> |
|
ClientHighAvailabilityServices |
ClientHighAvailabilityServices provides services those are required on client-side.
|
ClientHighAvailabilityServicesFactory |
|
ClientOptions |
Describes a client configuration parameter.
|
ClientResourceManager |
|
ClientUtils |
Utility functions for Flink client.
|
ClientUtils |
Contains utility methods for clients.
|
ClientWrapperClassLoader |
|
CliFrontend |
Implementation of a simple command line frontend for executing programs.
|
CliFrontendParser |
A simple command line parser (based on Apache Commons CLI) that extracts command line options.
|
CliInputView |
CLI view for entering a string.
|
CliInputView.InputOperation |
Available operations for this view.
|
CliOptions |
Command line options to configure the SQL client.
|
CliOptions.EmbeddedCliOptions |
Command option lines to configure SQL Client in the embedded mode.
|
CliOptions.GatewayCliOptions |
Command option lines to configure SQL Client in the gateway mode.
|
CliOptionsParser |
Parser for command line options.
|
CliResultView<O extends Enum<O>> |
Abstract CLI view for showing results (either as changelog or table).
|
CliRowView |
CLI view for visualizing a row.
|
CliRowView.RowOperation |
Available operations for this view.
|
CliStrings |
Utility class that contains all strings for CLI commands and messages.
|
CliTableauResultView |
Print result in tableau mode.
|
CliTableResultView |
CLI view for retrieving and displaying a table.
|
CliTableResultView.ResultTableOperation |
Available operations for this view.
|
CliUtils |
Utilities for CLI formatting.
|
CliView<OP extends Enum<OP>,OUT> |
Framework for a CLI view with header, footer, and main part that is scrollable.
|
Clock |
A simple clock that returns the number of seconds since the unix epoch.
|
Clock |
A clock that gives access to time.
|
ClockService |
A clock service which can get current processing time.
|
CloseableInputProvider<E> |
Utility interface for a provider of an input that can be closed.
|
CloseableIterable<T> |
This interface represents an iterable that is also closeable.
|
CloseableIterable.Empty<T> |
Empty iterator.
|
CloseableIterator<T> |
|
CloseableIterator.IteratorAdapter<E> |
|
CloseableRegistry |
|
CloseableResultIterator<T> |
Closeable result iterator for jdbc driver.
|
CloseOperationHandler |
Handler to close operation.
|
CloseOperationHeaders |
Message headers for closing operation.
|
CloseSessionHandler |
Handler to close session.
|
CloseSessionHeaders |
Message headers for closing a session.
|
CloseSessionResponseBody |
|
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).
|
ClusterClient<T> |
Encapsulates the functionality necessary to submit a program to a remote cluster.
|
ClusterClientFactory<ClusterID> |
A factory containing all the necessary information for creating clients to Flink clusters.
|
ClusterClientJobClientAdapter<ClusterID> |
|
ClusterClientProvider<T> |
|
ClusterClientServiceLoader |
|
ClusterConfigHandler |
Handler which serves the cluster's configuration.
|
ClusterConfiguration |
Configuration class which contains the parsed command line arguments for the ClusterEntrypoint .
|
ClusterConfigurationInfoHeaders |
|
ClusterConfigurationParserFactory |
Parser factory which generates a ClusterConfiguration from the given list of command line
arguments.
|
ClusterControllable |
Interface for triggering failover in a Flink cluster.
|
ClusterController |
Controller for interacting with a cluster.
|
ClusterDatasetCorruptedException |
Indicates some task fail to consume cluster dataset.
|
ClusterDataSetDeleteHandlers |
|
ClusterDataSetDeleteHandlers.SerializableVoid |
|
ClusterDataSetDeleteStatusHeaders |
Specification for retrieving the status for the delete operation of a cluster data set.
|
ClusterDataSetDeleteStatusMessageParameters |
|
ClusterDataSetDeleteTriggerHeaders |
Specification for triggering the deletion of a cluster data set.
|
ClusterDataSetDeleteTriggerMessageParameters |
|
ClusterDataSetEntry |
The entry for a single cluster data set.
|
ClusterDataSetIdPathParameter |
Path parameter identifying cluster data sets.
|
ClusterDataSetListHandler |
|
ClusterDataSetListHeaders |
Specification for retrieving an overview over all available cluster partitions.
|
ClusterDataSetListResponseBody |
|
ClusterDeploymentException |
Class which indicates a problem when deploying a Flink cluster.
|
ClusterDescriptor<T> |
A descriptor to deploy a cluster (e.g.
|
ClusterEntrypoint |
Base class for the Flink cluster entry points.
|
ClusterEntrypoint.ExecutionMode |
|
ClusterEntrypoint.ShutdownBehaviour |
|
ClusterEntrypointException |
|
ClusterEntryPointExceptionUtils |
Exception utils to handle and enrich exceptions occurring in the ClusterEntrypoint.
|
ClusterEntrypointUtils |
|
ClusterInformation |
Information about the cluster which is shared with the cluster components.
|
ClusterIPService |
The service type of ClusterIP.
|
ClusterOptions |
Options which control the cluster behaviour.
|
ClusterOptions.UncaughtExceptionHandleMode |
|
ClusterOptions.UserSystemExitMode |
The mode of how to handle user code attempting to exit JVM.
|
ClusterOverview |
|
ClusterOverviewHandler |
Handler which returns the cluster overview information with version.
|
ClusterOverviewHeaders |
|
ClusterOverviewWithVersion |
Cluster overview message including the current Flink version and commit id.
|
ClusterPartitionManager |
Interface for components that manage cluster partitions.
|
ClusterPartitionReport |
A report about the current status of all cluster partitions of the TaskExecutor, describing which
partitions are available.
|
ClusterPartitionReport.ClusterPartitionReportEntry |
An entry describing all partitions belonging to one dataset.
|
ClusterResourceStatisticsProvider |
Provides statistics of cluster resources.
|
ClusterRetrieveException |
Exception which indicates that a cluster could not be retrieved.
|
ClusterSpecification |
|
ClusterSpecification.ClusterSpecificationBuilder |
|
ClusterUncaughtExceptionHandler |
Utility for handling any uncaught exceptions
|
CmdJobManagerDecorator |
Attach the command and args to the main container for running the JobManager.
|
CmdTaskManagerDecorator |
Attach the command and args to the main container for running the TaskManager.
|
CoalesceFunction |
|
CoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT> |
|
CoBroadcastWithNonKeyedOperator<IN1,IN2,OUT> |
|
CoBundleTrigger<IN1,IN2> |
|
CodeGeneratorCastRule<IN,OUT> |
Cast rule that has code generation capabilities.
|
CodeGeneratorCastRule.Context |
Context for code generation.
|
CodeGenOperatorFactory<OUT> |
Stream operator factory for code gen operator.
|
CodeRewriter |
Interface for Java code rewriter.
|
CodeSplitUtil |
Utils for rewriters.
|
CoFlatMapFunction<IN1,IN2,OUT> |
A CoFlatMapFunction implements a flat-map transformation over two connected streams.
|
CoGroupDriver<IT1,IT2,OT> |
CoGroup task which is executed by a Task Manager.
|
CoGroupedStreams<T1,T2> |
CoGroupedStreams represents two DataStreams that have been co-grouped.
|
CoGroupedStreams.TaggedUnion<T1,T2> |
Internal class for implementing tagged union co-group.
|
CoGroupedStreams.UnionSerializer<T1,T2> |
|
CoGroupedStreams.UnionSerializerSnapshot<T1,T2> |
|
CoGroupedStreams.WithWindow<T1,T2,KEY,W extends Window> |
|
CoGroupFunction<IN1,IN2,O> |
The interface for CoGroup functions.
|
CoGroupOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> |
|
CoGroupRawDriver<IT1,IT2,OT> |
|
CoGroupRawDriver.SimpleIterable<IN> |
|
CoGroupRawOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> |
|
CoGroupRawOperatorBase.SimpleListIterable<IN> |
|
CoGroupTaskIterator<T1,T2> |
Interface describing the methods that have to be implemented by local strategies for the CoGroup
Pact.
|
CoGroupWithSolutionSetFirstDriver<IT1,IT2,OT> |
|
CoGroupWithSolutionSetSecondDriver<IT1,IT2,OT> |
|
CollectAggFunction<T> |
Built-in COLLECT aggregate function.
|
CollectAggFunction.CollectAccumulator<T> |
Accumulator for COLLECT.
|
CollectCoordinationRequest |
|
CollectCoordinationResponse |
A CoordinationResponse from the coordinator containing the required batch or new results
and other necessary information in serialized form.
|
CollectDynamicSink |
|
CollectionDataType |
A data type that contains an element type (e.g.
|
CollectionExecutor |
Execution utility for serial, local, collection-based executions of Flink programs.
|
CollectionInputFormat<T> |
An input format that returns objects from a collection.
|
CollectionPosition |
To represent collection's position in repeated type.
|
CollectionResultIterator |
Result iterator from given iterator.
|
CollectionUtil |
Simple utility to work with Java collections.
|
CollectIteratorAssert<T> |
This assertion used to compare records in the collect iterator to the target test data with
different semantic(AT_LEAST_ONCE, EXACTLY_ONCE).
|
CollectIteratorAssertions |
|
CollectModifyOperation |
|
Collector<OUT> |
This class take response for collecting data to output stream.
|
Collector<T> |
Collects a record and forwards it.
|
CollectResultBase |
|
CollectResultFetcher<T> |
A fetcher which fetches query results from sink and provides exactly-once semantics.
|
CollectResultIterator<T> |
An iterator which iterates through the results of a query job.
|
CollectSink<IN> |
A specialized data sink to be used by DataStreamUtils.collect().
|
CollectSinkAddressEvent |
An OperatorEvent that passes the socket server address in the sink to the coordinator.
|
CollectSinkFunction<IN> |
A sink function that collects query results and sends them back to the client.
|
CollectSinkOperator<IN> |
A StreamSink that collects query results and sends them back to the client.
|
CollectSinkOperatorCoordinator |
|
CollectSinkOperatorCoordinator.Provider |
|
CollectSinkOperatorFactory<IN> |
|
CollectStreamSink<T> |
|
CollectTypeStrategy |
|
CoLocationConstraint |
A CoLocationConstraint stores the ID of CoLocationGroup and an ID referring to
the actual subtask (i.e.
|
CoLocationGroup |
CoLocationGroup refers to a list of JobVertex instances, where the i-th
subtask of one vertex has to be executed on the same TaskManager as the i-th
subtask of all other JobVertex instances in the same group.
|
CoLocationGroupImpl |
|
Column |
|
Column |
Class to define column schema of TPS-DS table.
|
Column.ComputedColumn |
Representation of a computed column.
|
Column.MetadataColumn |
Representation of a metadata column.
|
Column.PhysicalColumn |
Representation of a physical column.
|
ColumnarArrayData |
Columnar array to support access to vector column data.
|
ColumnarMapData |
Columnar map to support access to vector column data.
|
ColumnarRowData |
Columnar row to support access to vector column data.
|
ColumnarRowIterator |
|
ColumnBatchFactory<SplitT extends FileSourceSplit> |
|
ColumnBatchFactory<BatchT,SplitT extends FileSourceSplit> |
|
ColumnInfo |
A column info represents a table column's structure with column name, column type.
|
ColumnInfo |
|
ColumnReader<VECTOR extends WritableColumnVector> |
|
ColumnReferenceFinder |
|
ColumnStats |
Column statistics.
|
ColumnStats.Builder |
ColumnStats builder.
|
ColumnVector |
Nullable column vector.
|
CoMapFunction<IN1,IN2,OUT> |
A CoFlatMapFunction implements a map() transformation over two connected streams.
|
CombineFunction<IN,OUT> |
Generic interface used for combine functions ("combiners").
|
Command |
Enumerates the possible types of input statements.
|
CommandLineOptions |
Base class for all options parsed from the command line.
|
CommandLineOptions |
Container class for command line options.
|
CommandLineParser<T> |
Command line parser which produces a result from the given command line arguments.
|
CommandLineWrapper |
Utility class for setting up command-line tool usages in a readable fashion.
|
CommandLineWrapper.SedBuilder |
Wrapper around sed used for processing text.
|
CommandLineWrapper.TarBuilder |
Wrapper around tar used for extracting .tar archives.
|
CommandLineWrapper.WGetBuilder |
Wrapper around wget used for downloading files.
|
CommitRequestImpl<CommT> |
Internal implementation to commit a specific committable and handle the response.
|
CommitRequestState |
Internal state of a committable.
|
CommittableCollector<CommT> |
This class is responsible to book-keep the committing progress across checkpoints and upstream
subtasks.
|
CommittableCollectorSerializer<CommT> |
|
CommittableMessage<CommT> |
The message send from SinkWriter to Committer .
|
CommittableMessageSerializer<CommT> |
|
CommittableMessageTypeInfo<CommT> |
|
CommittableSummary<CommT> |
This class tracks the information about committables belonging to one checkpoint coming from one
subtask.
|
CommittableWithLineage<CommT> |
Provides metadata.
|
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 .
|
CommitterOperatorFactory<CommT> |
|
CommittingSinkWriter<InputT,CommittableT> |
A SinkWriter that performs the first part of a two-phase commit protocol.
|
CommonArgumentTypeStrategy |
Argument type strategy that checks and casts for a common, least restrictive type of all
arguments.
|
CommonArrayInputTypeStrategy |
|
CommonCatalogOptions |
A collection of ConfigOption which are consistently used in multiple catalogs.
|
CommonCollectionInputTypeStrategy |
|
CommonExecAsyncCalc |
Base class for exec Async Calc.
|
CommonExecCalc |
Base class for exec Calc.
|
CommonExecCorrelate |
Base ExecNode which matches along with join a Java/Scala user defined table function.
|
CommonExecExchange |
Base class for exec Exchange.
|
CommonExecExpand |
Base ExecNode that can expand one row to multiple rows based on given projects.
|
CommonExecLegacySink<T> |
|
CommonExecLegacyTableSourceScan |
|
CommonExecLookupJoin |
Base ExecNode for temporal table join which shares most methods.
|
CommonExecMatch |
Common ExecNode which matches along with MATCH_RECOGNIZE.
|
CommonExecPythonCalc |
Base class for exec Python Calc.
|
CommonExecPythonCorrelate |
Base ExecNode which matches along with join a Python user defined table function.
|
CommonExecSink |
|
CommonExecTableSourceScan |
|
CommonExecUnion |
Base ExecNode that is not a physical node and just union the inputs' records into one
node.
|
CommonExecValues |
Base ExecNode that read records from given values.
|
CommonExecWindowTableFunction |
Base ExecNode for window table-valued function.
|
CommonInputTypeStrategy |
|
CommonMapInputTypeStrategy |
|
CommonModuleOptions |
A collection of ConfigOption which are consistently used in multiple modules.
|
CommonPhysicalMatch |
Base physical RelNode which matches along with MATCH_RECOGNIZE.
|
CommonPhysicalMatchRule |
The physical rule is responsible for converting FlinkLogicalMatch to physical Match rel.
|
CommonProcessMemorySpec<FM extends FlinkMemory> |
Common memory components of Flink processes (e.g.
|
CommonPythonUtil |
A utility class used in PyFlink.
|
CommonRangeBoundaries<T> |
|
CommonTestUtils |
This class contains reusable utility methods for unit tests.
|
CommonTypeStrategy |
Type strategy that returns a common, least restrictive type of selected arguments.
|
CompactBucketWriter<T> |
|
CompactBulkReader<T> |
|
CompactContext |
|
CompactContext.CompactContextImpl |
|
CompactCoordinator |
Coordinator that coordinates file compaction for the FileSink .
|
CompactCoordinator |
This is the single (non-parallel) monitoring task which coordinate input files to compaction
units. - Receives in-flight input files inside checkpoint. - Receives all upstream end input
messages after the checkpoint completes successfully, starts coordination.
|
CompactCoordinatorFactory |
|
CompactCoordinatorStateHandler |
|
CompactCoordinatorStateHandlerFactory |
|
CompactFileUtils |
Utils for compacting files.
|
CompactFileWriter<T> |
|
CompactingFileWriter |
|
CompactingFileWriter.Type |
|
CompactingHashTable<T> |
A hash table that uses Flink's managed memory and supports replacement of records or updates to
records.
|
CompactMessages |
Util class for all compaction messages.
|
CompactMessages.CompactionUnit |
The unit of a single compaction.
|
CompactMessages.CompactOutput |
|
CompactMessages.CoordinatorInput |
The input of compact coordinator.
|
CompactMessages.CoordinatorOutput |
The output of compact coordinator.
|
CompactMessages.EndCheckpoint |
A flag to end checkpoint, coordinator can start coordinating one checkpoint.
|
CompactMessages.EndCompaction |
A flag to end compaction.
|
CompactMessages.InputFile |
A partitioned input file.
|
CompactOperator<T> |
Receives compaction units to do compaction.
|
CompactorOperator |
An operator that perform compaction for the FileSink .
|
CompactorOperatorFactory |
|
CompactorOperatorStateHandler |
|
CompactorOperatorStateHandlerFactory |
|
CompactorRequest |
Request of file compacting for FileSink .
|
CompactorRequestSerializer |
|
CompactorRequestTypeInfo |
|
CompactReader<T> |
Reader for compaction.
|
CompactReader.Factory<T> |
|
CompactService |
The asynchronous file compaction service.
|
CompactWriter<T> |
Writer for compaction.
|
CompactWriter.Factory<T> |
|
ComparableAggregator<T> |
|
ComparableRecordComparator |
|
ComparableTypeStrategy |
An InputTypeStrategy that checks if all input arguments can be compared with each other
with the minimal provided comparison.
|
Comparator |
|
Compilable |
Represents an artifact that can be compiled to a CompiledPlan .
|
CompileAndExecutePlanOperation |
Operation to describe an COMPILE AND EXECUTE PLAN statement.
|
CompiledPlan |
Represents an immutable, fully optimized, and executable entity that has been compiled from a
Table & SQL API pipeline definition.
|
CompilePlanOperation |
Operation to describe an COMPILE PLAN statement.
|
CompilerHints |
A class encapsulating compiler hints describing the behavior of the user function.
|
CompileUtils |
Utilities to compile a generated code to a Class.
|
CompletedCheckpoint |
A CompletedCheckpoint describes a checkpoint after all required tasks acknowledged it (with their
state) and that is considered successful.
|
CompletedCheckpointStats |
Statistics for a successfully completed checkpoint.
|
CompletedCheckpointStatsSummary |
Summary over all completed checkpoints.
|
CompletedCheckpointStatsSummarySnapshot |
|
CompletedCheckpointStorageLocation |
The CompletedCheckpointStorageLocation describes the storage aspect of a completed checkpoint.
|
CompletedCheckpointStore |
|
CompletedOperationCache<K extends OperationKey,R extends Serializable> |
Cache to manage ongoing operations.
|
CompletedScheduledFuture<T> |
|
CompletedStateFuture<T> |
A StateFuture that has already been completed when it is created.
|
CompleteStateIterator<T> |
|
CompleteStatementHandler |
Handler to complete a statement.
|
CompleteStatementHeaders |
Message headers for completing a statement.
|
CompleteStatementRequestBody |
|
CompleteStatementResponseBody |
|
ComplexPayload |
|
ComplexPayload.InnerPayLoad |
Nested class in state type.
|
ComplexPayloadAvro |
|
ComplexPayloadAvro.Builder |
RecordBuilder for ComplexPayloadAvro instances.
|
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.
|
ComponentClosingUtils |
A util class to help with a clean component shutdown.
|
ComponentMainThreadExecutor |
Interface for an executor that runs tasks in the main thread of an RpcEndpoint .
|
ComponentMainThreadExecutor.DummyComponentMainThreadExecutor |
Dummy implementation of ComponentMainThreadExecutor.
|
ComponentMetricGroup<P extends AbstractMetricGroup<?>> |
Abstract MetricGroup for system components (e.g., TaskManager,
Job, Task, Operator).
|
CompositeArgumentTypeStrategy |
Strategy that checks that the argument has a composite type.
|
CompositeBuffer |
An implementation of Buffer which contains multiple partial buffers for network data
communication.
|
CompositeKeySerializationUtils |
Utils for RocksDB state serialization and deserialization.
|
CompositeSerializer<T> |
Base class for composite serializers.
|
CompositeSerializer.PrecomputedParameters |
This class holds composite serializer parameters which can be precomputed in advanced for
better performance.
|
CompositeSingleOperandTypeChecker |
Default implementation of CompositeOperandTypeChecker , the
class was copied over because of current Calcite issue CALCITE-5380.
|
CompositeStateHandle |
Base of all snapshots that are taken by StateBackend s and some other components in tasks.
|
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> |
|
CompressedBlockChannelReader |
Compressed block channel reader provides a scenario where MemorySegment must be maintained.
|
CompressedBlockChannelWriter |
Compressed block channel writer provides a scenario where MemorySegment must be maintained.
|
CompressedHeaderlessChannelReaderInputView |
|
CompressedHeaderlessChannelWriterOutputView |
|
CompressedSerializedValue<T> |
An extension of SerializedValue that compresses the value after the serialization.
|
CompressibleFSDataInputStream |
|
CompressibleFSDataOutputStream |
|
CompressionUtils |
Utils used to extract compressed files.
|
CompressorUtils |
|
CompressWriterFactory<IN> |
A factory that creates for bulk writers that, when provided with a CompressionCodec , they compress the data they write.
|
CompressWriters |
|
ComputationState |
Helper class which encapsulates the currentStateName of the NFA computation.
|
ConcatenatedExtract<FROM,OVER,TO> |
Combines two extractors which will be executed one after each other.
|
ConcatFileCompactor |
|
Conditions |
Common conditions for architecture tests.
|
ConfigConstants |
This class contains all constants for the configuration.
|
ConfigGroup |
A class that specifies a group of config options.
|
ConfigGroups |
Annotation used on classes containing config options that enables the separation of options into
different tables based on key prefixes.
|
ConfigOption<T> |
A ConfigOption describes a configuration parameter.
|
ConfigOptions |
|
ConfigOptions.ListConfigOptionBuilder<E> |
|
ConfigOptions.OptionBuilder |
|
ConfigOptions.TypedConfigOptionBuilder<T> |
|
ConfigOptionsDocGenerator |
Class used for generating code based documentation of configuration parameters.
|
ConfigurableCheckpointStorage |
An interface for checkpoint storage types that pick up additional parameters from a
configuration.
|
ConfigurableForStOptionsFactory |
An interface for options factory that pick up additional parameters from a configuration.
|
ConfigurableRocksDBOptionsFactory |
Deprecated.
|
ConfigurableRocksDBOptionsFactory |
An interface for options factory that pick up additional parameters from a configuration.
|
ConfigurableStateBackend |
An interface for state backends that pick up additional parameters from a configuration.
|
ConfigurableStreamPartitioner |
Interface for StreamPartitioner which have to be configured with the maximum parallelism
of the stream transformation.
|
Configuration |
Lightweight configuration object which stores key/value pairs.
|
ConfigurationCommandLineOptions |
Represents the set of command-line options related to update and get configuration.
|
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.
|
ConfigurationInfo |
|
ConfigurationInfoEntry |
|
ConfigurationJsonSerializerFilter |
|
ConfigurationNotAllowedMessage |
|
ConfigurationOptionLocator |
Utility for discovering config options.
|
ConfigurationParserUtils |
Utility class to extract related parameters from Configuration and to sanity check them.
|
ConfigurationUtils |
|
ConfigurationValidator |
Interface for classes that validate connector specific table options, including common utils for
validation.
|
ConfigurationValidatorUtil |
|
ConfigureSessionHandler |
Handler to configure a session with statement.
|
ConfigureSessionHeaders |
Message headers for configuring a session.
|
ConfigureSessionRequestBody |
|
ConfigUtils |
General utilities for parsing values to configuration options.
|
ConfigUtils |
Utilities class for configuration of Hadoop and Google Storage.
|
ConfigUtils.ConfigContext |
Interface that provides context-specific config helper functions, factored out to support
unit testing
|
ConfluentRegistryAvroDeserializationSchema<T> |
Deserialization schema that deserializes from Avro binary format using SchemaCoder that
uses Confluent Schema Registry.
|
ConfluentRegistryAvroSerializationSchema<T> |
Serialization schema that serializes to Avro binary format that uses Confluent Schema Registry.
|
ConfluentSchemaRegistryCoder |
Reads and Writes schema using Confluent Schema Registry protocol.
|
CongestionControlRateLimitingStrategy |
A RateLimitingStrategy implementation that does the following:
Scales up when any request is successful.
|
CongestionControlRateLimitingStrategy.CongestionControlRateLimitingStrategyBuilder |
|
ConnectedComponentsData |
Test data for ConnectedComponents programs.
|
ConnectedStreams<IN1,IN2> |
ConnectedStreams represent two connected streams of (possibly) different data types.
|
ConnectionClosedException |
Exception which is thrown if the RestClient detects that a connection was closed.
|
ConnectionErrorMessage |
Message for indicating connection error.
|
ConnectionException |
Base class for all connection related exception thrown by the RestClient .
|
ConnectionID |
A ConnectionID identifies a connection to a remote task manager by the socket address and
a connection index.
|
ConnectionIdleException |
Exception which is thrown by the RestClient if a connection becomes idle.
|
ConnectionLimitingFactory |
|
ConnectionManager |
The connection manager manages physical connections for the (logical) remote input channels at
runtime.
|
ConnectionUtils |
Utilities to determine the network interface and address that should be used to bind the
TaskManager communication to.
|
ConnectionUtils.LeaderConnectingAddressListener |
|
ConnectorCatalogTable<T1,T2> |
|
ConnectorDescriptorValidator |
Deprecated. |
ConnectorRules |
Rules for Flink connectors.
|
ConnectorTestConstants |
The default configuration values used in connector tests.
|
ConnectorTestingExtension |
A JUnit 5 Extension for supporting running of connector testing framework.
|
ConstantArgumentCount |
|
ConstantFoldingUtil |
Utility for deciding whether than expression supports constant folding or not.
|
ConstantRankNumberColumnRemoveRule |
Planner rule that removes the output column of rank number iff there is an equality condition for
the rank column.
|
ConstantRankNumberColumnRemoveRule.ConstantRankNumberColumnRemoveRuleConfig |
Rule configuration.
|
ConstantRankRange |
rankStart and rankEnd are inclusive, rankStart always start from one.
|
ConstantRankRangeWithoutEnd |
ConstantRankRangeWithoutEnd is a RankRange which not specify RankEnd.
|
Constants |
Constants for kubernetes.
|
Constants |
constants.
|
Constants |
constants.
|
Constants |
Constants used in the SqlGatewayService.
|
Constraint |
Integrity constraints, generally referred to simply as constraints, define the valid states of
SQL-data by constraining the values in the base tables.
|
Constraint |
Deprecated.
|
Constraint.ConstraintType |
Type of the constraint.
|
Constraint.ConstraintType |
Type of the constraint.
|
ConstraintArgumentTypeStrategy |
Strategy for an argument that must fulfill a given constraint.
|
ConstraintEnforcer |
Processes RowData to enforce the following constraints:
NOT NULL column constraint of a sink table
CHAR(length) /@{code VARCHAR(length)}: trim string values to comply with the
length defined in their corresponding types.
|
ConstraintEnforcer.Builder |
Helper builder, so that the ConstraintEnforcer can be instantiated with only the NOT
NULL constraint validation, only the CHAR/VARCHAR length validation, only the
BINARY/VARBINARY length validation or combinations of them, or all of them.
|
ConstraintEnforcer.FieldInfo |
Helper POJO to keep info about CHAR/VARCHAR/BINARY/VARBINARY fields, used to determine if
trimming or padding is needed.
|
ConsumedPartitionGroup |
|
ConsumerRegionGroupExecutionView |
|
ConsumerVertexGroup |
|
ContaineredTaskManagerParameters |
This class describes the basic parameters for launching a TaskManager process.
|
ContainingTaskDetails |
Details about the operator containing task (such as StreamTask ).
|
ContextClassLoaderExtension |
JUnit extension to customize the classloader that a test is run with.
|
ContextClassLoaderExtension.ContextClassLoaderExtensionBuilder |
|
ContextKey<K,N> |
The composite key which contains some context information, such as keyGroup, etc.
|
ContextResolvedFunction |
This class contains information about a function and its relationship with a Catalog , if
any.
|
ContextResolvedModel |
This class contains information about a model and its relationship with a Catalog , if
any.
|
ContextResolvedProcedure |
This class contains information about a procedure and its relationship with a Catalog .
|
ContextResolvedTable |
This class contains information about a table, its ResolvedSchema , its options and its
relationship with a Catalog , if any.
|
ContextStateFutureImpl<T> |
A state future that holds the RecordContext and maintains the reference count of it.
|
ContinuousEnumerationSettings |
Settings describing how to do continuous file discovery and enumeration for the file source's
continuous discovery and streaming mode.
|
ContinuousEventTimeTrigger<W extends Window> |
A Trigger that continuously fires based on a given time interval.
|
ContinuousFileMonitoringFunction<OUT> |
Deprecated.
|
ContinuousFileReaderOperator<OUT,T extends TimestampedInputSplit> |
|
ContinuousFileReaderOperatorFactory<OUT,T extends TimestampedInputSplit> |
|
ContinuousFileSplitEnumerator |
A continuously monitoring enumerator.
|
ContinuousPartitionFetcher<P,T extends Comparable<T>> |
Partition fetcher for helping continuously fetch partitioned table.
|
ContinuousPartitionFetcher.Context<P,T extends Comparable<T>> |
Context for fetch partitions, partition information is stored in hive meta store.
|
ContinuousProcessingTimeTrigger<W extends Window> |
A Trigger that continuously fires based on a given time interval as measured by the clock
of the machine on which the job is running.
|
ContinuousRefreshHandler |
Embedded continuous refresh handler of Flink streaming job for materialized table.
|
ContinuousRefreshHandlerSerializer |
|
ControlMessages |
Control messages for the PekkoRpcActor .
|
ConvergenceCriterion<T extends Value> |
Used to check for convergence.
|
ConversionException |
Exception which is thrown if an input cannot be converted into the requested type.
|
Converter<From,To,C> |
A generic interface for converting data types.
|
CoordinatedOperatorFactory<OUT> |
|
CoordinatedTask |
|
CoordinationRequest |
|
CoordinationRequestGateway |
|
CoordinationRequestHandler |
|
CoordinationResponse |
|
CoordinatorStore |
|
CoordinatorStoreImpl |
|
CoProcessFunction<IN1,IN2,OUT> |
A function that processes elements of two streams and produces a single output one.
|
CoProcessOperator<IN1,IN2,OUT> |
|
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>> |
|
CopyingBroadcastingOutput |
|
CopyingFirstInputOfTwoInputStreamOperatorOutput |
|
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.
|
CopyingOneInputStreamOperatorOutput |
|
CopyingSecondInputOfTwoInputStreamOperatorOutput |
|
CopyOnWriteSkipListStateMap<K,N,S> |
Implementation of state map which is based on skip list with copy-on-write support. states will
be serialized to bytes and stored in the space allocated with the given allocator.
|
CopyOnWriteSkipListStateMapSnapshot<K,N,S> |
|
CopyOnWriteStateMap<K,N,S> |
Implementation of Flink's in-memory state maps with copy-on-write support.
|
CopyOnWriteStateMap.StateMapEntry<K,N,S> |
|
CopyOnWriteStateMapSnapshot<K,N,S> |
|
CopyOnWriteStateTable<K,N,S> |
|
CopyOnWriteStateTableSnapshot<K,N,S> |
This class represents the snapshot of a CopyOnWriteStateTable and has a role in operator
state checkpointing.
|
CoreModule |
Module of default core metadata in Flink.
|
CoreModuleFactory |
|
CoreOptions |
The set of configuration options for core parameters.
|
CorrelateSortToRankRule |
Planner rule that rewrites sort correlation to a Rank.
|
CorrelateSortToRankRule.CorrelateSortToRankRuleConfig |
Rule configuration.
|
CorruptConfigurationException |
Exception indicating that the parsed configuration was corrupt.
|
CosineDistance<DATA> |
This delta function calculates the cosine distance between two given vectors.
|
CoStreamFlatMap<IN1,IN2,OUT> |
|
CoStreamMap<IN1,IN2,OUT> |
|
Count1AggFunction |
This count1 aggregate function returns the count1 of values which go into it like
[[CountAggFunction]].
|
CountAggFunction |
built-in count aggregate function.
|
CountAggFunction |
Count agg aggregate.
|
|