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.
|
CountAggFunction.CountAccumulator |
The initial accumulator for count aggregate function.
|
CountBundleTrigger<T> |
A BundleTrigger that fires once the count of elements in a bundle reaches the given
count.
|
CountCoBundleTrigger<IN1,IN2> |
A CoBundleTrigger that fires once the count of elements in a bundle reaches the given
count.
|
Counter |
A Counter is a Metric that measures a count.
|
CountEvictor<W extends Window> |
An Evictor that keeps up to a certain amount of elements.
|
CountingCollector<OUT> |
|
CountingIterable<IN> |
|
CountingIterator<IN> |
|
CountingMutableObjectIterator<IN> |
|
CountingOutput<OUT> |
Wrapping Output that updates metrics on the number of emitted elements.
|
CountSlidingWindowAssigner |
A GroupWindowAssigner that windows elements into sliding windows based on the count
number of the elements.
|
CountTrigger<W extends Window> |
A Trigger that fires once the count of elements in a pane reaches the given count.
|
CountTumblingWindowAssigner |
A GroupWindowAssigner that windows elements into fixed-size windows based on the count
number of the elements.
|
CountWindow |
A Window that represents a count window.
|
CountWindow.Serializer |
The serializer used to write the CountWindow type.
|
CountWindow.Serializer.CountWindowSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
CPUResource |
Represents CPU resource.
|
CreateCatalogFunctionOperation |
Operation to describe a CREATE FUNCTION statement for catalog functions.
|
CreateCatalogOperation |
Operation to describe a CREATE CATALOG statement.
|
CreateDatabaseEvent |
|
CreateDatabaseOperation |
Operation to describe a CREATE DATABASE statement.
|
CreateEmbeddedSchedulerWorkflowHandler |
Handler to create workflow in embedded scheduler.
|
CreateEmbeddedSchedulerWorkflowHeaders |
Message headers for create workflow in embedded scheduler.
|
CreateEmbeddedSchedulerWorkflowRequestBody |
|
CreateEmbeddedSchedulerWorkflowResponseBody |
|
CreateMaterializedTableOperation |
Operation to describe a CREATE MATERIALIZED TABLE statement.
|
CreateModelEvent |
|
CreateOperation |
A Operation that describes the DDL statements, e.g.
|
CreatePeriodicRefreshWorkflow |
|
CreateRefreshWorkflow |
|
CreateTableASOperation |
Operation to describe a CREATE TABLE AS statement.
|
CreateTableEvent |
|
CreateTableOperation |
Operation to describe a CREATE TABLE statement.
|
CreateTempSystemFunctionOperation |
Operation to describe a CREATE FUNCTION statement for temporary system function.
|
CreateViewOperation |
Operation to describe a CREATE VIEW statement.
|
CreatingExecutionGraph |
|
CreditBasedInputBuffersUsageGauge |
Gauge metric measuring the input buffers usage for SingleInputGate s under credit based
mode.
|
CrossDriver<T1,T2,OT> |
Cross task which is executed by a Task Manager.
|
CrossFunction<IN1,IN2,OUT> |
Interface for Cross functions.
|
CrossOperatorBase<IN1,IN2,OUT,FT extends CrossFunction<IN1,IN2,OUT>> |
|
CrossOperatorBase.CrossHint |
The cross hint tells the system which sizes to expect from the data sets
|
CrossOperatorBase.CrossWithLarge |
Marker interface to declare the second input as the larger one.
|
CrossOperatorBase.CrossWithSmall |
Marker interface to declare the second input as the smaller one.
|
CsvAppendTableSinkFactory |
Deprecated.
|
CsvAppendTableSourceFactory |
Deprecated.
|
CsvBatchTableSinkFactory |
Deprecated.
|
CsvBatchTableSourceFactory |
Deprecated.
|
CsvFileFormatFactory |
CSV format factory for file system.
|
CsvFileFormatFactory.CsvBulkDecodingFormat |
|
CsvFormatFactory |
|
CsvFormatOptions |
Options for CSV format.
|
CsvFormatStatisticsReportUtil |
Utils for Csv format statistics report.
|
CsvInputFormat<OUT> |
Deprecated. |
CsvReaderFormat<T> |
A StreamFormat for reading CSV files.
|
CsvRowDataDeserializationSchema |
Deserialization schema from CSV to Flink Table & SQL internal data structures.
|
CsvRowDataDeserializationSchema.Builder |
|
CsvRowDataSerializationSchema |
Serialization schema that serializes an object of Flink Table & SQL internal data structure into
a CSV bytes.
|
CsvRowDataSerializationSchema.Builder |
|
CsvRowDeserializationSchema |
Deserialization schema from CSV to Flink types.
|
CsvRowDeserializationSchema.Builder |
|
CsvRowSchemaConverter |
Converter functions that covert Flink's type information to Jackson's CsvSchema .
|
CsvRowSerializationSchema |
Serialization schema that serializes an object of Flink types into a CSV bytes.
|
CsvRowSerializationSchema.Builder |
|
CsvTableSink |
Deprecated.
|
CsvTableSink.CsvFormatter |
Formats a Row into a String with fields separated by the field delimiter.
|
CsvTableSinkFactoryBase |
Deprecated.
|
CsvTableSource |
Deprecated.
|
CsvTableSource.Builder |
A builder for creating CsvTableSource instances.
|
CsvTableSource.CsvLookupFunction |
LookupFunction to support lookup in CsvTableSource.
|
CsvTableSourceFactoryBase |
Deprecated.
|
CsvToRowDataConverters |
Tool class used to convert from CSV-format JsonNode to RowData .
|
CumeDistAggFunction |
built-in CUME_DIST agg function.
|
CumulativeWindowAssigner |
A GroupWindowAssigner that windows elements into cumulative windows based on the
timestamp of the elements.
|
CumulativeWindowSpec |
Logical representation of a cumulative window specification.
|
CuratorFrameworkWithUnhandledErrorListener |
A wrapper for curatorFramework and unHandledErrorListener which should be unregister from
curatorFramework before closing it.
|
CustomCommandLine |
Custom command-line interface to load hooks for the command-line interface.
|
CustomExtension |
|
CustomHeadersDecorator<R extends RequestBody,P extends ResponseBody,M extends MessageParameters> |
Decorator class for MessageHeaders that adds the ability to include custom HTTP headers.
|
CustomizedConverter |
|
CustomizedConverters |
|
CustomizedConvertRule |
Customized CallExpressionConvertRule , Functions conversion here all require special
logic, and there may be some special rules, such as needing get the literal values of inputs,
such as converting to combinations of functions, to convert to RexNode of calcite.
|
CustomPartitionerWrapper<K,T> |
Partitioner that selects the channel with a user defined partitioner function on a key.
|
CustomSinkOperatorUidHashes |
This class is responsible to hold operator Uid hashes from the common operators of the sink.
|
CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder |
|
CustomSSLEngineProvider |
Extension of the ConfigSSLEngineProvider to use a FingerprintTrustManagerFactory .
|
CustomTestFailureEnricher |
The custom enricher for test.
|
CustomTestFailureEnricherFactory |
|
CustomTimestampAssigner<T> |
TimestampAssigner which extracts timestamp from the second field of the input element.
|
DamBehavior |
Enumeration for the different dam behaviors of an algorithm or a driver strategy.
|
DashboardConfigHandler |
Handler which returns the dashboard configuration.
|
DashboardConfiguration |
Response of the DashboardConfigHandler containing general configuration values such as
the time zone and the refresh interval.
|
DashboardConfiguration.Features |
Collection of features that are enabled/disabled.
|
DashboardConfigurationHeaders |
|
DatabaseAlreadyExistException |
Exception for trying to create a database that already exists.
|
DatabaseMetaDataUtils |
|
DatabaseModificationEvent |
Basic event for database modification such as create, alter and drop, it has the database name
and CatalogDatabase .
|
DatabaseNotEmptyException |
Exception for trying to drop on a database that is not empty.
|
DatabaseNotExistException |
Exception for trying to operate on a database that doesn't exist.
|
DataBuffer |
Data of different subpartitions can be appended to a DataBuffer and after the DataBuffer is full or finished, the appended data can be copied from it in subpartition index
order.
|
DataDistribution |
|
DatadogHttpClient |
Http client talking to Datadog.
|
DatadogHttpClient.EmptyCallback |
A handler for OkHttpClient callback.
|
DatadogHttpReporter |
Metric Reporter for Datadog.
|
DatadogHttpReporterFactory |
|
DataFormatConverters |
Converters between internal data format and java format.
|
DataFormatConverters.AbstractRowDataConverter<E> |
Abstract converter for internal base row.
|
DataFormatConverters.ArrayDataConverter |
Converter for ArrayData.
|
DataFormatConverters.BigDecimalConverter |
Converter for BigDecimal.
|
DataFormatConverters.BooleanConverter |
Converter for boolean.
|
DataFormatConverters.ByteConverter |
Converter for byte.
|
DataFormatConverters.CaseClassConverter |
Converter for case class.
|
DataFormatConverters.DataFormatConverter<Internal,External> |
Converter between internal data format and java format.
|
DataFormatConverters.DateConverter |
Converter for date.
|
DataFormatConverters.DecimalDataConverter |
Converter for DecimalData.
|
DataFormatConverters.DoubleConverter |
Converter for double.
|
DataFormatConverters.FloatConverter |
Converter for float.
|
DataFormatConverters.GenericConverter<T> |
|
DataFormatConverters.IdentityConverter<T> |
Identity converter.
|
DataFormatConverters.InstantConverter |
Converter for Instant.
|
DataFormatConverters.IntConverter |
Converter for int.
|
DataFormatConverters.LocalDateConverter |
Converter for LocalDate.
|
DataFormatConverters.LocalDateTimeConverter |
Converter for LocalDateTime.
|
DataFormatConverters.LocalTimeConverter |
Converter for LocalTime.
|
DataFormatConverters.LongConverter |
Converter for long.
|
DataFormatConverters.LongTimestampDataConverter |
Converter for Long and TimestampData.
|
DataFormatConverters.MapConverter |
Converter for map.
|
DataFormatConverters.MapDataConverter |
Converter for MapData.
|
DataFormatConverters.ObjectArrayConverter<T> |
Converter for object array.
|
DataFormatConverters.PojoConverter<T> |
Converter for pojo.
|
DataFormatConverters.PrimitiveBooleanArrayConverter |
Converter for primitive boolean array.
|
DataFormatConverters.PrimitiveByteArrayConverter |
Converter for primitive byte array.
|
DataFormatConverters.PrimitiveDoubleArrayConverter |
Converter for primitive double array.
|
DataFormatConverters.PrimitiveFloatArrayConverter |
Converter for primitive float array.
|
DataFormatConverters.PrimitiveIntArrayConverter |
Converter for primitive int array.
|
DataFormatConverters.PrimitiveLongArrayConverter |
Converter for primitive long array.
|
DataFormatConverters.PrimitiveShortArrayConverter |
Converter for primitive short array.
|
DataFormatConverters.RawValueDataConverter |
Converter for RawValueData.
|
DataFormatConverters.RowConverter |
Converter for row.
|
DataFormatConverters.RowDataConverter |
Converter for base row.
|
DataFormatConverters.ShortConverter |
Converter for short.
|
DataFormatConverters.StringConverter |
Converter for String.
|
DataFormatConverters.StringDataConverter |
Converter for StringData.
|
DataFormatConverters.TimeConverter |
Converter for time.
|
DataFormatConverters.TimestampConverter |
Converter for timestamp.
|
DataFormatConverters.TimestampDataConverter |
|
DataFormatConverters.TimestampLtzConverter |
Converter for timestamp which doesn't consider the time zone.
|
DataFormatConverters.TupleConverter |
Converter for flink tuple.
|
DataGenConnectorOptions |
Options for the DataGen connector.
|
DataGenConnectorOptionsUtil |
|
DataGenerator<T> |
Stateful and re-scalable data generator.
|
DataGenerator |
|
DataGeneratorContainer |
|
DataGeneratorMapper<A,B> |
|
DataGeneratorPerCheckpoint |
|
DataGeneratorSource<OUT> |
A data source that produces N data points in parallel.
|
DataGeneratorSource<T> |
Deprecated.
|
DataGenTableSource |
|
DataGenTableSourceFactory |
|
DataGenVisitorBase |
|
DataInputDecoder |
|
DataInputDeserializer |
A simple and efficient deserializer for the DataInput interface.
|
DataInputStatus |
It is an internal equivalent of InputStatus that provides
additional non public statuses.
|
DataInputView |
This interface defines a view over some memory that can be used to sequentially read the contents
of the memory.
|
DataInputViewStream |
|
DataInputViewStreamWrapper |
|
DataOutputEncoder |
|
DataOutputSerializer |
A simple and efficient serializer for the DataOutput interface.
|
DataOutputView |
This interface defines a view over some memory that can be used to sequentially write contents to
the memory.
|
DataOutputViewStream |
|
DataOutputViewStreamWrapper |
|
DatasetConfigFacet |
Builtin config facet for dataset.
|
DataSetMetaInfo |
Container for meta-data of a data set.
|
DatasetSchemaFacet |
Builtin schema facet for dataset.
|
DatasetSchemaField<T> |
Field for schema in dataset.
|
DataSinkTask<IT> |
DataSinkTask which is executed by a task manager.
|
DataSourceTask<OT> |
DataSourceTask which is executed by a task manager.
|
DataStream |
This is the topmost base interface of all streams of DataStream V2 API.
|
DataStream<T> |
A DataStream represents a stream of elements of the same type.
|
DataStream.Collector<T> |
|
DataStreamAllroundTestJobFactory |
A factory for components of general purpose test jobs for Flink's DataStream API operators and
primitives.
|
DataStreamAllroundTestProgram |
A general purpose test job for Flink's DataStream API operators and primitives.
|
DataStreamPythonFunction |
DataStreamPythonFunction maintains the serialized python function which will be used in
BeamDataStreamPythonFunctionRunner.
|
DataStreamPythonFunctionInfo |
|
DataStreamPythonFunctionOperator<OUT> |
Interface for Python DataStream operators.
|
DataStreamQueryOperation<E> |
Deprecated. |
DataStreamScanProvider |
|
DataStreamSink<T> |
A Stream Sink.
|
DataStreamSinkExternalContext<T> |
External context for DataStream sinks.
|
DataStreamSinkProvider |
|
DataStreamSinkV2ExternalContext<T> |
External context for DataStream sinks whose version is V2.
|
DataStreamSource<T> |
The DataStreamSource represents the starting point of a DataStream.
|
DataStreamSourceExternalContext<T> |
External context for DataStream sources.
|
DataStreamStateTTLTestProgram |
A test job for State TTL feature.
|
DataStreamUtils |
|
DataStreamV2SinkTransformation<InputT,OutputT> |
|
DataStreamV2SinkTransformationTranslator<Input,Output> |
|
DataStreamV2SinkUtils |
Utils to create the DataStream V2 supported Sink .
|
DataStreamV2SourceUtils |
Utils to create the DataStream V2 supported Source .
|
DataStructureConverter<I,E> |
Converter between internal and external data structure.
|
DataStructureConverters |
Registry of available data structure converters.
|
DataType |
Describes the data type of a value in the table ecosystem.
|
DataTypeConversionClassTransformation |
This type transformation transforms the specified data types to a new one with the expected
conversion class.
|
DataTypeDefaultVisitor<R> |
|
DataTypeExtractor |
Reflection-based utility that analyzes a given Type , method, or class
to extract a (possibly nested) DataType from it.
|
DataTypeFactory |
Factory for creating fully resolved data types that can be used for planning.
|
DataTypeHint |
A hint that influences the reflection-based extraction of a DataType .
|
DataTypePrecisionFixer |
The data type visitor used to fix the precision for data type with the given logical type which
carries the correct precisions.
|
DataTypeQueryable |
Indicates that a DataType can be retrieved from a class that implements this interfaces.
|
DataTypes |
A DataType can be used to declare input and/or output types of operations.
|
DataTypes.AbstractField |
Common helper class for resolved and unresolved fields of a row or structured type.
|
DataTypes.Field |
Helper class for defining the field of a row or structured type.
|
DataTypes.Resolution |
Helper class for defining the resolution of an interval.
|
DataTypes.UnresolvedField |
Helper class for defining the unresolved field of a row or structured type.
|
DataTypeUtils |
|
DataTypeVisitor<R> |
|
DataView |
|
DataViewSpec |
Information about a DataView stored in state.
|
DataViewUtils |
|
DataViewUtils.DistinctViewSpec |
Specification for a special MapView for deduplication.
|
Date |
Class representing a date value in statistics.
|
DateComparator |
|
DateDateConverter |
|
DateLocalDateConverter |
|
DateSerializer |
|
DateSerializer |
Takes int instead of long as the serialized value.
|
DateSerializer.DateSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
DateSerializer.DateSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
DateTimeBucketAssigner<IN> |
A BucketAssigner that assigns to buckets based on current system time.
|
DateTimeUtils |
Utility functions for datetime types: date, time, timestamp.
|
DateTimeUtils.TimeUnit |
Enumeration of time units used to construct an interval.
|
DateTimeUtils.TimeUnitRange |
A range of time units.
|
DateType |
Logical type of a date consisting of year-month-day with values ranging from
0000-01-01 to 9999-12-31 .
|
DateWriter<T> |
|
DateWriter.DateWriterForArray |
|
DateWriter.DateWriterForRow |
|
DayTimeIntervalDurationConverter |
|
DayTimeIntervalType |
Logical type for a group of day-time interval types.
|
DayTimeIntervalType.DayTimeResolution |
Supported resolutions of this type.
|
DCounter |
Mapping of counter between Flink and Datadog.
|
DeactivatedChangelogStateBackend |
This state backend use delegatedStateBackend and State changes to restore to the
delegatedStateBackend in which switching Changelog from enabled to disabled.
|
DeactivatedCheckpointCompletedCheckpointStore |
|
DeactivatedCheckpointIDCounter |
|
DeadLettersActor |
Actor which listens to DeadLetter and responds with a failure if
the message was a RPC.
|
Deadline |
|
DeadlockBreakupProcessor |
|
DebeziumAvroDeserializationSchema |
Deserialization schema from Debezium Avro to Flink Table/SQL internal data structure RowData .
|
DebeziumAvroFormatFactory |
|
DebeziumAvroSerializationSchema |
Serialization schema from Flink Table/SQL internal data structure RowData to Debezium
Avro.
|
DebeziumJsonDecodingFormat |
|
DebeziumJsonDeserializationSchema |
Deserialization schema from Debezium JSON to Flink Table/SQL internal data structure RowData .
|
DebeziumJsonFormatFactory |
|
DebeziumJsonFormatOptions |
Option utils for debezium-json format.
|
DebeziumJsonSerializationSchema |
Serialization schema from Flink Table/SQL internal data structure RowData to Debezium
JSON.
|
DecimalBigDecimalConverter |
|
DecimalColumnVector |
Decimal column vector.
|
DecimalData |
An internal data structure representing data of DecimalType .
|
DecimalDataRandomGenerator |
|
DecimalDataSerializer |
|
DecimalDataSerializer |
We create the DecimalSerializer instead of using the DecimalSerializer of flink-table-runtime for
performance reasons in Python deserialization.
|
DecimalDataSerializer.DecimalSerializerSnapshot |
|
DecimalDataSerializer.DecimalSerializerSnapshot |
|
DecimalDataTypeInfo |
|
DecimalDataUtils |
|
DecimalType |
Logical type of a decimal number with fixed precision and scale.
|
DecimalWriter<T> |
|
DecimalWriter.DecimalWriterForArray |
|
DecimalWriter.DecimalWriterForRow |
|
DeclarationRewriter |
Extract and rename local variables into member variables.
|
DeclarativeAggregateFunction |
API for aggregation functions that are expressed in terms of expressions.
|
DeclarativeExpressionResolver |
|
DeclarativeSlotPool |
Slot pool interface which uses Flink's declarative resource management protocol to acquire
resources.
|
DeclarativeSlotPool.NewSlotsListener |
Listener interface for newly available slots.
|
DeclarativeSlotPool.NoOpNewSlotsListener |
|
DeclarativeSlotPoolBridge |
|
DeclarativeSlotPoolBridgeServiceFactory |
|
DeclarativeSlotPoolFactory |
|
DeclarativeSlotPoolService |
|
DeclarativeSlotPoolServiceFactory |
|
DeclareResourceRequirementServiceConnectionManager |
|
DeclareResourceRequirementServiceConnectionManager.DeclareResourceRequirementsService |
Service that accepts resource requirements.
|
DeclineCheckpoint |
This message is sent from the TaskExecutor to the
JobMaster to tell the checkpoint coordinator that a
checkpoint request could not be heeded.
|
DecoderBasedReader<T> |
|
DecoderBasedReader.Decoder<T> |
|
DecoderBasedReader.Decoder.Factory<T> |
|
DecoderBasedReader.Factory<T> |
|
DecodingFormat<I> |
|
DecodingFormatFactory<I> |
|
DeduplicatedQueue<T> |
|
DeduplicateFunctionHelper |
Utility for deduplicate function.
|
DefaultAllocatedSlotPool |
|
DefaultBatchJobRecoveryHandler |
|
DefaultBlocklistHandler |
|
DefaultBlocklistHandler.Factory |
|
DefaultBlocklistTracker |
|
DefaultBroadcastVariableInitializer<T> |
|
DefaultBucketFactoryImpl<IN,BucketID> |
|
DefaultCalciteContext |
A context for default dialect with calcite related interfaces.
|
DefaultCatalogMaterializedTable |
|
DefaultCatalogModel |
A catalog model implementation.
|
DefaultCatalogTable |
|
DefaultCheckpointPlan |
|
DefaultCheckpointPlanCalculator |
|
DefaultCheckpointStatsTracker |
|
DefaultCLI |
The default CLI which is used for interaction with standalone clusters.
|
DefaultClientHighAvailabilityServicesFactory |
Default factory for creating client high availability services.
|
DefaultClusterClientServiceLoader |
|
DefaultCompletedCheckpointStore<R extends ResourceVersion<R>> |
|
DefaultCompletedCheckpointStoreUtils |
|
DefaultContainerizedExternalSystem<C extends org.testcontainers.containers.GenericContainer<C>> |
Default implementation of external system based on container.
|
DefaultContainerizedExternalSystem.Builder<C extends org.testcontainers.containers.GenericContainer<C>> |
|
DefaultContext |
The context memorized initial configuration.
|
DefaultContextUtils |
|
DefaultDeclarativeSlotPool |
|
DefaultDeclarativeSlotPoolFactory |
|
DefaultDelegationTokenManager |
Manager for delegation tokens in a Flink cluster.
|
DefaultDelegationTokenManagerFactory |
|
DefaultDispatcherGatewayService |
A facade over the Dispatcher that exposes specific functionality.
|
DefaultDispatcherResourceManagerComponentFactory |
|
DefaultDispatcherRunner |
Runner for the Dispatcher which is responsible for
the leader election.
|
DefaultDispatcherRunnerFactory |
|
DefaultExecutionDeployer |
|
DefaultExecutionDeployer.Factory |
|
DefaultExecutionDeploymentReconciler |
|
DefaultExecutionDeploymentTracker |
|
DefaultExecutionGraph |
|
DefaultExecutionGraphBuilder |
|
DefaultExecutionGraphCache |
|
DefaultExecutionGraphFactory |
|
DefaultExecutionOperations |
|
DefaultExecutionPlanStore<R extends ResourceVersion<R>> |
|
DefaultExecutionTopology |
|
DefaultExecutor |
|
DefaultExecutorFactory |
|
DefaultExecutorServiceLoader |
|
DefaultExpressionEvaluator |
|
DefaultExtractor<T> |
A Extractor implementation that extracts element to string with line separator.
|
DefaultFailureEnricherContext |
|
DefaultFileFilter |
A file filter that filters out hidden files based on common naming patterns, i.e., files where
the filename starts with '.' or with '_'.
|
DefaultFileWriterBucketFactory<IN> |
|
DefaultFreeSlotTracker |
|
DefaultGroupCache<G,K,V> |
|
DefaultGroupCache.Factory<G,K,V> |
|
DefaultHadoopFileCommitterFactory |
|
DefaultHeartbeatMonitor<O> |
|
DefaultInMemorySorterFactory<T> |
|
DefaultInputConsumableDecider |
|
DefaultInputConsumableDecider.Factory |
|
DefaultInputSplitAssigner |
|
DefaultJobBundleFactory |
A JobBundleFactory for which the implementation can specify a custom EnvironmentFactory for environment management.
|
DefaultJobBundleFactory.ServerInfo |
A container for EnvironmentFactory and its corresponding Grpc servers.
|
DefaultJobBundleFactory.WrappedSdkHarnessClient |
Holder for an SdkHarnessClient along with its associated state and data servers.
|
DefaultJobCreatedEvent |
|
DefaultJobExecutionStatusEvent |
|
DefaultJobInfo |
|
DefaultJobLeaderIdService |
Service which retrieves for a registered job the current job leader id (the leader id of the job
manager responsible for the job).
|
DefaultJobLeaderService |
|
DefaultJobManagerJobMetricGroupFactory |
|
DefaultJobManagerRunnerRegistry |
|
DefaultJobMasterServiceFactory |
|
DefaultJobMasterServiceProcess |
|
DefaultJobMasterServiceProcessFactory |
|
DefaultJobTable |
|
DefaultKeyedStateStore |
Default implementation of KeyedStateStore that currently forwards state registration to a RuntimeContext .
|
DefaultKeyedStateStoreV2 |
Default implementation of KeyedStateStoreV2.
|
DefaultKubernetesArtifactUploader |
|
DefaultLastStateConnectionStateListener |
A simple ConnectionState listener that remembers the last state.
|
DefaultLeaderElectionService |
Default implementation for leader election service.
|
DefaultLeaderRetrievalService |
|
DefaultLineageDataset |
|
DefaultLineageEdge |
Implementation of LineageEdge.
|
DefaultLineageGraph |
|
DefaultLineageGraph.LineageGraphBuilder |
|
DefaultLineageVertex |
|
DefaultLogicalEdge |
|
DefaultLogicalPipelinedRegion |
|
DefaultLogicalResult |
|
DefaultLogicalTopology |
|
DefaultLogicalVertex |
|
DefaultLookupCache |
|
DefaultLookupCache.Builder |
|
DefaultMetricFilter |
|
DefaultNonPartitionedContext<OUT> |
|
DefaultOpenContext |
|
DefaultOperatorCoordinatorHandler |
|
DefaultOperatorStateBackend |
Default implementation of OperatorStateStore that provides the ability to make snapshots.
|
DefaultOperatorStateBackendBuilder |
|
DefaultPackagedProgramRetriever |
PackageProgramRetrieverImpl is the default implementation of PackagedProgramRetriever that can either retrieve a PackagedProgram from a specific jar,
some provided user classpath or the system classpath.
|
DefaultParserFactory |
|
DefaultPartitionedContext |
|
DefaultPartitionWithMetrics |
|
DefaultPartTimeExtractor |
|
DefaultPlannerFactory |
|
DefaultPluginManager |
|
DefaultPreferredLocationsRetriever |
|
DefaultProcedureContext |
|
DefaultProcessingTimeManager |
|
DefaultRequirementMatcher |
|
DefaultResolvedCatalogModel |
A validated CatalogModel that is backed by the original metadata coming from the Catalog but resolved by the framework.
|
DefaultResourceAllocationStrategy |
|
DefaultResourceCleaner<T> |
|
DefaultResourceCleaner.Builder<T> |
Builder for creating DefaultResourceCleaner instances.
|
DefaultResourceTracker |
|
DefaultRollingPolicy<IN,BucketID> |
|
DefaultRollingPolicy.PolicyBuilder |
|
DefaultRuntimeContext |
|
DefaultScheduler |
The future default scheduler.
|
DefaultSchedulerComponents |
|
DefaultSchedulerFactory |
|
DefaultSchedulingPipelinedRegion |
|
DefaultShuffleMasterSnapshotContext |
|
DefaultShuffleMetrics |
|
DefaultSlotAssigner |
Simple SlotAssigner that treats all slots and slot sharing groups equally.
|
DefaultSlotPoolServiceSchedulerFactory |
|
DefaultSlotStatusSyncer |
|
DefaultSourceLineageVertex |
|
DefaultSpeculativeExecutionHandler |
|
DefaultStateManager |
|
DefaultStateTransitionManager |
DefaultStateTransitionManager is a state machine which manages the AdaptiveScheduler 's state transitions based on the previous transition time and the available
resources.
|
DefaultSubtaskAttemptNumberStore |
Simple container for subtask attempt counts backed by a list.
|
DefaultTaskInfo |
|
DefaultTimerService<K> |
Service to register timeouts for a given key.
|
DefaultTwoOutputNonPartitionedContext<OUT1,OUT2> |
|
DefaultVertexAttemptNumberStore |
Maintains the attempt number per subtask.
|
DefaultVertexParallelismAndInputInfosDecider |
|
DefaultVertexParallelismInfo |
|
DefaultVertexParallelismStore |
Maintains the configured parallelisms for vertices, which should be defined by a scheduler.
|
DefaultYarnNodeManagerClientFactory |
|
DefaultYarnResourceManagerClientFactory |
|
DefinedFieldMapping |
Deprecated.
|
DefinedProctimeAttribute |
Deprecated.
|
DefinedRowtimeAttributes |
Deprecated.
|
DeflateInflaterInputStreamFactory |
Factory for input streams that decompress the "deflate" compression format.
|
DelegateExecutorFactory |
|
DelegateOperatorTransformation<OUT> |
|
DelegateOperatorTransformation.DelegateOperator<OUT> |
|
DelegatePlannerFactory |
|
DelegatingAsyncResultFuture |
|
DelegatingConfiguration |
A configuration that manages a subset of keys with a common prefix from a given configuration.
|
DelegatingResultFuture<OUT> |
|
DelegatingStateBackend |
An interface to delegate state backend.
|
DelegationTokenContainer |
Container for delegation tokens.
|
DelegationTokenManager |
Manager for delegation tokens in a Flink cluster.
|
DelegationTokenManager.Listener |
|
DelegationTokenProvider |
Delegation token provider API.
|
DelegationTokenProvider.ObtainedDelegationTokens |
Container for obtained delegation tokens.
|
DelegationTokenReceiver |
Delegation token receiver API.
|
DelegationTokenReceiverRepository |
Repository for delegation token receivers.
|
DeleteEmbeddedSchedulerWorkflowHandler |
Handler to delete workflow in embedded scheduler.
|
DeleteEmbeddedSchedulerWorkflowHeaders |
Message headers for delete workflow in embedded scheduler.
|
DeleteFromFilterOperation |
The operation for deleting data in a table according to filters directly.
|
DeletePushDownUtils |
A utility class for delete push down.
|
DeleteRefreshWorkflow<T extends RefreshHandler> |
|
DelimitedInputFormat<OT> |
Base implementation for input formats that split the input at a delimiter into records.
|
DeliveryGuarantee |
DeliverGuarantees that can be chosen.
|
DeltaEvictor<T,W extends Window> |
|
DeltaFunction<DATA> |
This interface allows the implementation of a function which calculates the delta between two
data points.
|
DeltaIterationBase<ST,WT> |
A DeltaIteration is similar to a BulkIterationBase , but maintains state across the
individual iteration steps.
|
DeltaIterationBase.SolutionSetPlaceHolder<ST> |
Specialized operator to use as a recognizable place-holder for the solution set input to the
step function.
|
DeltaIterationBase.WorksetPlaceHolder<WT> |
Specialized operator to use as a recognizable place-holder for the working set input to the
step function.
|
DeltaTrigger<T,W extends Window> |
|
DenseRankAggFunction |
built-in dense_rank aggregate function.
|
Dependency |
Represents a dependency.
|
DependencyParser |
Parsing utils for the Maven dependency plugin.
|
DependencyTree |
Represents a dependency tree.
|
DeploymentOptions |
|
DeploymentOptionsInternal |
Internal options used during deployment.
|
DeploymentStateTimeMetrics |
Metrics that capture how long a job was deploying tasks.
|
DeployParser |
Parsing utils for the Maven deploy plugin.
|
DescribeCatalogOperation |
Operation to describe a DESCRIBE CATALOG catalog_name statement.
|
DescribedEnum |
|
DescribeFunctionOperation |
Operation to describe a FUNCTION.
|
DescribeJobOperation |
Operation to describe a DESCRIBE JOB statement.
|
DescribeTableOperation |
Operation to describe a DESCRIBE [EXTENDED] [[catalogName.] dataBasesName].sqlIdentifier
statement.
|
Description |
|
Description.DescriptionBuilder |
|
DescriptiveStatisticsHistogram |
|
DescriptiveStatisticsHistogramStatistics |
|
Descriptor |
Deprecated.
|
DescriptorProperties |
Deprecated.
|
DescriptorValidator |
Deprecated.
|
DeserializationDelegate<T> |
The deserialization delegate is used during deserialization to read an arbitrary element as if it
implements IOReadableWritable , with the help of a type serializer.
|
DeserializationException |
An exception specifying that the deserialization caused an error.
|
DeserializationFormatFactory |
|
DeserializationSchema<T> |
The deserialization schema describes how to turn the byte messages delivered by certain data
sources (for example Apache Kafka) into data types (Java/Scala objects) that are processed by
Flink.
|
DeserializationSchema.InitializationContext |
|
DeserializationSchemaAdapter |
|
DetachedApplicationRunner |
|
DetachedJobExecutionResult |
The JobExecutionResult returned by a context environment when executing a job in detached
mode.
|
DeterminismEnvelope<T> |
Envelope that carries whether the wrapped value is deterministic or not.
|
DeweyNumber |
Versioning scheme which allows to retrieve dependencies between different versions.
|
DeweyNumber.DeweyNumberSerializer |
|
DeweyNumber.DeweyNumberSerializer.DeweyNumberSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
DGauge |
Mapping of gauge between Flink and Datadog.
|
DHistogram |
Maps histograms to datadog gauges.
|
Dictionary |
The interface for dictionary in AbstractColumnVector to decode dictionary encoded values.
|
DirectConvertRule |
|
DirectoryBasedPluginFinder |
This class is used to create a collection of PluginDescriptor based on directory
structure for a given plugin root folder.
|
DirectoryStateHandle |
This state handle represents a directory.
|
DirectoryStreamStateHandle |
This state handle represents a directory, usually used to be registered to SharedStateRegistry to track the life cycle of the directory.
|
DisabledKvStateRequestStats |
|
DiscardingSink<T> |
Deprecated.
|
DiscardingSink<IN> |
A special sink that ignores all elements.
|
DiskIOScheduler |
The DiskIOScheduler is a scheduler that controls the reading of data from shuffle files.
|
DiskTierConsumerAgent |
The data client is used to fetch data from disk tier.
|
DiskTierFactory |
|
DiskTierProducerAgent |
|
Dispatcher |
Base class for the Dispatcher component.
|
Dispatcher.ExecutionType |
Enum to distinguish between initial job submission and re-submission for recovery.
|
DispatcherBootstrap |
An interface containing the logic of bootstrapping the Dispatcher of a cluster.
|
DispatcherBootstrapFactory |
|
DispatcherCachedOperationsHandler |
A handler for async operations triggered by the Dispatcher whose keys and results are
cached.
|
DispatcherException |
|
DispatcherFactory |
|
DispatcherGateway |
Gateway for the Dispatcher component.
|
DispatcherId |
|
DispatcherLeaderProcessFactory |
Factory for the DispatcherLeaderProcess .
|
DispatcherLeaderProcessFactoryFactory |
|
DispatcherOperationCaches |
Encapsulates caches for results of asynchronous operations triggered by the Dispatcher .
|
DispatcherResourceCleanerFactory |
|
DispatcherResourceManagerComponent |
|
DispatcherResourceManagerComponentFactory |
|
DispatcherRestEndpoint |
|
DispatcherRunner |
|
DispatcherRunnerFactory |
|
DispatcherServices |
|
DispatcherThreadFactory |
Thread factory that creates threads with a given name, associates them with a given thread group,
and set them to daemon mode.
|
Disposable |
Interface for classes that can be disposed, i.e. that have a dedicated lifecycle step to
"destroy" the object.
|
DistinctQueryOperation |
Removes duplicated rows of underlying relational operation.
|
DistinctType |
Logical type of a user-defined distinct type.
|
DistinctType.Builder |
|
DistributedCache |
DistributedCache provides static methods to write the registered cache files into job
configuration or decode them from job configuration.
|
DistributedCache.DistributedCacheEntry |
|
DistributedCacheViaBlobTestProgram |
End-to-end test program for verifying that files are distributed via BlobServer and later
accessible through DistribitutedCache.
|
DistributedRuntimeUDFContext |
A standalone implementation of the RuntimeContext , created by runtime UDF operators.
|
DistributionPattern |
A distribution pattern determines, which sub tasks of a producing task are connected to which
consuming sub tasks.
|
DMeter |
Mapping of meter between Flink and Datadog.
|
DMetric |
Abstract metric of Datadog for serialization.
|
DockerImageVersions |
Utility class for defining the image names and versions of Docker containers used during the Java
tests.
|
Documentation |
Collection of annotations to modify the behavior of the documentation generators.
|
Documentation.ExcludeFromDocumentation |
Annotation used on config option fields or REST API message headers to exclude it from
documentation.
|
Documentation.ExecMode |
The execution mode the config works for.
|
Documentation.OverrideDefault |
Annotation used on config option fields to override the documented default.
|
Documentation.Section |
Annotation used on config option fields to include them in specific sections.
|
Documentation.Sections |
Constants for section names.
|
Documentation.SuffixOption |
Annotation used on config option fields or options class to mark them as a suffix-option;
i.e., a config option where the key is only a suffix, with the prefix being dynamically
provided at runtime.
|
Documentation.TableOption |
Annotation used on table config options for adding meta data labels.
|
DoneFuture<T> |
A Future that is always done and will just yield the object that was given at creation
time.
|
DoubleColumnReader |
|
DoubleColumnVector |
Double column vector.
|
DoubleComparator |
|
DoubleCounter |
An accumulator that sums up double values.
|
DoubleEmittingSourceReaderWithCheckpointsInBetween<E,O,IterT extends Iterator<E>,SplitT extends IteratorSourceSplit<E,IterT>> |
A SourceReader that synchronizes emission of N elements on the arrival of the checkpoint
barriers It 1) emits a list of elements without checkpoints in-between, 2) then waits for two
checkpoints to complete, 3) then re-emits the same elements before 4) waiting for another two
checkpoints and 5) exiting.
|
DoubleHashSet |
Double hash set.
|
DoubleMaximum |
An accumulator that finds the maximum double value.
|
DoubleMinimum |
An accumulator that finds the minimum double value.
|
DoubleParser |
Parses a text field into a Double.
|
DoublePrimitiveArrayComparator |
|
DoublePrimitiveArraySerializer |
A serializer for double arrays.
|
DoublePrimitiveArraySerializer.DoublePrimitiveArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
DoubleSerializer |
Type serializer for Double .
|
DoubleSerializer.DoubleSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
DoubleSumAggregator |
|
DoubleType |
Logical type of an 8-byte double precision floating point number.
|
DoubleValue |
Boxed serializable and comparable double precision floating point type, representing the
primitive type double .
|
DoubleValueComparator |
Specialized comparator for DoubleValue based on CopyableValueComparator.
|
DoubleValueParser |
Parses a text field into a DoubleValue.
|
DoubleValueSerializer |
|
DoubleValueSerializer.DoubleValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
DoubleWriter<T> |
|
DoubleWriter.DoubleWriterForArray |
|
DoubleWriter.DoubleWriterForRow |
|
DoubleZeroConvergence |
|
DownloadCache |
A DownloadCache allows tests to download a files and/or directories and optionally caches
them.
|
DownloadCacheFactory |
|
DownTimeGauge |
A gauge that returns (in milliseconds) how long a job has not been not running any more, in case
it is in a failing/recovering situation.
|
DQLCachedPlan |
PlanCache for DQL.
|
Driver<S extends Function,OT> |
The interface to be implemented by all drivers that run alone (or as the primary driver) in a
task.
|
DriverStrategy |
Enumeration of all available operator strategies.
|
DriverUri |
Parse catalog, table and connection properties from uri for FlinkDriver .
|
DriverUtils |
Utils methods are copied from flink-core for flink jdbc driver to avoid excessive dependency.
|
DropCatalogFunctionOperation |
Operation to describe a DROP FUNCTION statement for catalog functions.
|
DropCatalogOperation |
Operation to describe a DROP CATALOG statement.
|
DropDatabaseEvent |
|
DropDatabaseOperation |
Operation to describe a DROP DATABASE statement.
|
DropMaterializedTableOperation |
Operation to describe a DROP MATERIALIZED TABLE statement.
|
DropModelEvent |
When a model is dropped, a DropModelEvent event will be created and fired.
|
DropOperation |
A Operation that describes the DROP DDL statements, e.g.
|
DropPartitionsOperation |
Operation to describe ALTER TABLE DROP PARTITION statement.
|
DropTableEvent |
When a table is dropped, a DropTableEvent event will be created and fired.
|
DropTableOperation |
Operation to describe a DROP TABLE statement.
|
DropTempSystemFunctionOperation |
Operation to describe a DROP FUNCTION statement for temporary system function.
|
DropUpdateBeforeFunction |
|
DropViewOperation |
Operation to describe a DROP VIEW statement.
|
DropwizardHistogramWrapper |
Wrapper to use a Dropwizard Histogram as a Flink Histogram .
|
DropwizardMeterWrapper |
Wrapper to use a Dropwizard Meter as a Flink Meter .
|
DSeries |
Json serialization between Flink and Datadog.
|
DualInputOperator<IN1,IN2,OUT,FT extends Function> |
Abstract operator superclass for all operators that have two inputs, like "Join", "CoGroup", or
"Cross".
|
DualInputSemanticProperties |
Container for the semantic properties associated to a dual input operator.
|
DualKeyLinkedMap<A,B,V> |
Map which stores values under two different indices.
|
Dummy |
Dummy marker interface used for excluding all other groups.
|
DummyBatchJobRecoveryHandler |
|
DummyFSFactory |
Factory of dummy FileSystem.
|
DummyInitializationContext |
A dummy context for serialization schemas.
|
DummySpeculativeExecutionHandler |
|
DummyStreamExecutionEnvironment |
|
DuplicateJobSubmissionException |
Exception which is returned upon job submission if the submitted job is currently being executed.
|
DuplicatingCheckpointOutputStream |
A CheckpointStateOutputStream that wraps a primary and a secondary CheckpointStateOutputStream
and duplicates all writes into both streams.
|
DuplicatingStateChangeFsUploader |
A StateChangeFsUploader implementation that writes the changes to remote and local.
|
DynamicCodeLoadingException |
An exception that is thrown if the dynamic instantiation of code fails.
|
DynamicConfiguration |
A dynamic JAAS configuration.
|
DynamicEventTimeSessionWindows<T> |
A WindowAssigner that windows elements into sessions based on the timestamp of the
elements.
|
DynamicFileEnumerator |
FileEnumerator that supports dynamic filtering.
|
DynamicFileEnumerator.Provider |
|
DynamicFileSplitEnumerator<SplitT extends FileSourceSplit> |
A SplitEnumerator implementation that supports dynamic filtering.
|
DynamicFilteringData |
Data for dynamic filtering.
|
DynamicFilteringDataCollectorOperator |
|
DynamicFilteringDataCollectorOperatorCoordinator |
|
DynamicFilteringDataCollectorOperatorCoordinator.Provider |
|
DynamicFilteringDataCollectorOperatorFactory |
|
DynamicFilteringDependencyProcessor |
This processor future checks each dynamic filter source to see if it is chained with a multiple
input operator.
|
DynamicFilteringEvent |
|
DynamicFilteringInfo |
A decorative interface that indicates it holds the dynamic partition filtering data.
|
DynamicParallelismInference |
Sources that implement this interface will dynamically infer the source’s parallelism when it is
unspecified.
|
DynamicParallelismInference.Context |
A context that provides dynamic parallelism decision infos.
|
DynamicParametersConfigurationParserFactory |
DynamicParametersConfigurationParserFactory can be used to extract the dynamic parameters
from command line.
|
DynamicPartitionPruningUtils |
Planner utils for Dynamic partition Pruning.
|
DynamicPartitionWriter<T> |
Dynamic partition writer to writing multiple partitions at the same time, it maybe consumes more
memory.
|
DynamicProcessingTimeSessionWindows<T> |
A WindowAssigner that windows elements into sessions based on the current processing
time.
|
DynamicPropertiesUtil |
|
DynamicResult |
A result of a dynamic table program.
|
DynamicSinkUtils |
|
DynamicSourceUtils |
|
DynamicTableFactory |
Base interface for configuring a dynamic table connector for an external storage system from
catalog and session information.
|
DynamicTableFactory.Context |
Provides catalog and session information describing the dynamic table to be accessed.
|
DynamicTableSink |
Sink of a dynamic table to an external storage system.
|
DynamicTableSink.Context |
|
DynamicTableSink.DataStructureConverter |
Converter for mapping between Flink's internal data structures and objects specified by the
given DataType that can be passed into a runtime implementation.
|
DynamicTableSink.SinkRuntimeProvider |
Provides actual runtime implementation for writing the data.
|
DynamicTableSinkFactory |
|
DynamicTableSinkSpec |
|
DynamicTableSource |
Source of a dynamic table from an external storage system.
|
DynamicTableSource.Context |
|
DynamicTableSource.DataStructureConverter |
Converter for mapping between objects and Flink's internal data structures during runtime.
|
DynamicTableSourceFactory |
|
DynamicTableSourceSpec |
|
DynamicTemporaryAWSCredentialsProvider |
Support dynamic session credentials for authenticating with AWS.
|
EachCallbackWrapper<C extends CustomExtension> |
An extension wrap logic for BeforeEachCallback and AfterEachCallback .
|
EdgeManager |
Class that manages all the connections between tasks.
|
EdgeManagerBuildUtil |
|
Either<L,R> |
This type represents a value of one two possible types, Left or Right (a disjoint union),
inspired by Scala's Either type.
|
Either.Left<L,R> |
|
Either.Right<L,R> |
|
EitherSerializer<L,R> |
|
EitherTypeInfo<L,R> |
|
EitherTypeInfoFactory<L,R> |
|
ElementConverter<InputT,RequestEntryT> |
This interface specifies the mapping between elements of a stream to request entries that can be
sent to the destination.
|
ElementOrder |
This enum defines the element order of being processed.
|
ElementTriggers |
A Trigger that fires at some point after a specified number of input elements have
arrived.
|
ElementTriggers.CountElement<W extends Window> |
A Trigger that fires at some point after a specified number of input elements have
arrived.
|
ElementTriggers.EveryElement<W extends Window> |
A Trigger that triggers on every element.
|
EltFunction |
|
Email |
Toy email resentation.
|
EmailId |
POJO representing an EmailId.
|
EmailInformation |
POJO representing some information about an email.
|
EmbeddedCompletedCheckpointStore |
An embedded in-memory checkpoint store, which supports shutdown and suspend.
|
EmbeddedExecutor |
A base class for executors that invoke directly methods of the Dispatcher and do not go through the REST
API.
|
EmbeddedExecutorFactory |
|
EmbeddedExecutorServiceLoader |
|
EmbeddedHaServices |
An implementation of the HighAvailabilityServices for the non-high-availability case
where all participants (ResourceManager, JobManagers, TaskManagers) run in the same process.
|
EmbeddedHaServicesWithLeadershipControl |
|
EmbeddedJobClient |
|
EmbeddedJobClientCreator |
An interface to be implemented by JobClient suppliers.
|
EmbeddedJobResultStore |
|
EmbeddedLeaderService |
A simple leader election service, which selects a leader among contenders and notifies listeners.
|
EmbeddedPythonBatchCoBroadcastProcessOperator<IN1,IN2,OUT> |
|
EmbeddedPythonBatchKeyedCoBroadcastProcessOperator<K,IN1,IN2,OUT> |
|
EmbeddedPythonCoProcessOperator<IN1,IN2,OUT> |
|
EmbeddedPythonEnvironment |
|
EmbeddedPythonEnvironmentManager |
The base class of python environment manager which is used to create the PythonEnvironment
object.
|
EmbeddedPythonKeyedCoProcessOperator<K,IN1,IN2,OUT> |
|
EmbeddedPythonKeyedProcessOperator<K,IN,OUT> |
|
EmbeddedPythonProcessOperator<IN,OUT> |
|
EmbeddedPythonScalarFunctionOperator |
|
EmbeddedPythonTableFunctionOperator |
The Python TableFunction operator in embedded Python environment.
|
EmbeddedPythonWindowOperator<K,IN,OUT,W extends Window> |
|
EmbeddedQuartzScheduler |
An embedded workflow scheduler based on quartz Scheduler that store all workflow in
memory, it does not have high availability.
|
EmbeddedQuartzScheduler.EmbeddedSchedulerJob |
The Job implementation for embedded quartz scheduler.
|
EmbeddedRefreshHandler |
|
EmbeddedRefreshHandlerSerializer |
|
EmbeddedRocksDBStateBackend |
Deprecated.
|
EmbeddedRocksDBStateBackend |
A StateBackend that stores its state in an embedded
RocksDB instance.
|
EmbeddedRocksDBStateBackend.PriorityQueueStateType |
The options to chose for the type of priority queue state.
|
EmbeddedRocksDBStateBackendFactory |
Deprecated.
|
EmbeddedRocksDBStateBackendFactory |
|
EmbeddedSchedulerWorkflowRequestBody |
RequestBody for suspend, resume, delete workflow in embedded scheduler.
|
EmbeddedWorkflowScheduler |
|
EmbeddedWorkflowSchedulerFactory |
|
EmptyFileMergingOperatorStreamStateHandle |
|
EmptyIterator<E> |
An empty iterator that never returns anything.
|
EmptyMessageParameters |
MessageParameters implementation which has no parameters.
|
EmptyMetaStoreFactory |
|
EmptyMutableObjectIterator<E> |
An empty mutable object iterator that never returns anything.
|
EmptyRequestBody |
Request which do not have a request payload.
|
EmptyResponseBody |
|
EmptyRowDataKeySelector |
A utility class which key is always empty no matter what the input row is.
|
EmptySegmentFileStateHandle |
|
EmptyShuffleMasterSnapshot |
|
Encoder<IN> |
A Encoder is used by the streaming file sink to perform the actual writing of the
incoming elements to the files in a bucket.
|
EncodingFormat<I> |
|
EncodingFormatFactory<I> |
|
EncodingUtils |
General utilities for string-encoding.
|
EndOfChannelStateEvent |
|
EndOfData |
This event indicates there will be no more data records in a subpartition.
|
EndOfPartitionEvent |
This event marks a subpartition as fully consumed.
|
EndOfSegmentEvent |
EndOfSegmentEvent is used to notify the downstream switch tiers in tiered storage shuffle
mode.
|
EndOfSuperstepEvent |
Marks the end of a superstep of one particular iteration superstep.
|
Endpoint |
Represent an endpoint.
|
EndpointNotStartedException |
Exception which is thrown if an endpoint has not been started (yet).
|
EndpointVersion |
Version of the endpoint.
|
EndStatementSetOperation |
Operation to describe a End statement.
|
EndsWithFunction |
|
EnrichedRowData |
An implementation of RowData which is backed by two RowData with a well-defined
index mapping, One of the rows is fixed, while the other can be swapped for performant changes in
hot code paths.
|
EntropyInjectingFileSystem |
An interface to be implemented by a FileSystem that is aware of entropy injection.
|
EntropyInjector |
|
EntryClassInformationProvider |
EntryClassInformationProvider provides information about the entry class.
|
EntryClassQueryParameter |
Query parameter specifying the name of the entry point class.
|
EntrypointClusterConfiguration |
|
EntrypointClusterConfigurationParserFactory |
|
EnumComparator<T extends Enum<T>> |
|
EnumerableToLogicalTableScan |
Rule that converts an EnumerableTableScan into a LogicalTableScan.
|
EnumerableToLogicalTableScan.EnumerableToLogicalTableScanConfig |
Rule configuration.
|
EnumSerializer<T extends Enum<T>> |
|
EnumSerializer.EnumSerializerSnapshot<T extends Enum<T>> |
|
EnumTriangleData |
Test data for EnumTriangle programs.
|
EnumTypeInfo<T extends Enum<T>> |
|
Environment |
The Environment gives the code executed in a task access to the task's properties (such as name,
parallelism), the configurations, the data stream readers and writers, as well as the various
components that are provided by the TaskManager, such as memory manager, I/O manager, ...
|
EnvironmentInfo |
The response of environment info.
|
EnvironmentInformation |
Utility class that gives access to the execution environment of the JVM, like the executing user,
startup options, or the JVM version.
|
EnvironmentInformation.RevisionInformation |
Revision information encapsulates information about the source code revision of the Flink
code.
|
EnvironmentSettings |
Defines all parameters that initialize a table environment.
|
EnvironmentSettings.Builder |
|
EnvironmentVariableKeyProvider |
An implementation of KeyProvider , which reads the Azure
storage key from an environment variable named "AZURE_STORAGE_KEY".
|
EnvSecretsDecorator |
Support setting environment variables via Secrets.
|
EpochManager |
Epoch manager segments inputs into distinct epochs, marked by the arrival of non-records(e.g.
|
EpochManager.Epoch |
All inputs are segment into distinct epochs, marked by the arrival of non-record inputs.
|
EpochManager.ParallelMode |
This enum defines whether parallel execution between epochs is allowed.
|
EqualityAndHashcodeProvider |
This class is used for scalar function, in that it is used for sharing the initialization context
between scalar functions that need code generated hashcode and equals method.
|
ErrorInfo |
Simple container to hold an exception and the corresponding timestamp.
|
ErrorResponseBody |
Generic response body for communicating errors on the server.
|
EscalatingSupervisorStrategy |
Escalating supervisor strategy.
|
EuclideanDistance<DATA> |
This delta function calculates the euclidean distance between two given points.
|
Event |
Data type for events, consisting of the originating IP address and an event type.
|
Event |
|
EventAnnouncement |
|
EventComparator<T> |
Custom comparator used to compares two events.
|
EventDeSerializationSchema |
A serializer and deserializer for the Event type.
|
EventId |
|
EventId.EventIdSerializer |
|
EventId.EventIdSerializer.EventIdSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
EventListener<T> |
|
EventSerializer |
Utility class to serialize and deserialize task events.
|
EventsGenerator |
A generator for events.
|
EventsGeneratorFunction |
A generator function that produces the events on the fly.
|
EventTimeSessionWindows |
A WindowAssigner that windows elements into sessions based on the timestamp of the
elements.
|
EventTimeTemporalJoinRewriteRule |
Traverses an event time temporal table join RelNode tree and update the right child to
set FlinkLogicalTableSourceScan 's eventTimeSnapshot property to true which will prevent
it generating a new StreamPhysicalChangelogNormalize later.
|
EventTimeTemporalJoinRewriteRule.Config |
|
EventTimeTrigger |
A Trigger that fires once the watermark passes the end of the window to which a pane
belongs.
|
EventTimeTriggers |
A Trigger that reacts to event-time timers.
|
EventTimeTriggers.AfterEndOfWindow<W extends Window> |
A Trigger that fires once the watermark passes the end of the window to which a pane
belongs.
|
EventTimeTriggers.AfterEndOfWindowEarlyAndLate<W extends Window> |
A composite Trigger that consist of AfterEndOfWindow and a early trigger and late
trigger.
|
EventTimeTriggers.AfterEndOfWindowNoLate<W extends Window> |
A composite Trigger that consist of AfterEndOfWindow and a late trigger.
|
EventType |
|
EventType |
The type of the event processed by the state machine.
|
EventTypeAndState |
Simple combination of EventType and State.
|
EvictingWindowOperator<K,IN,OUT,W extends Window> |
|
EvictingWindowOperatorFactory<K,IN,OUT,W extends Window> |
|
EvictingWindowReaderFunction<IN,R,OUT,KEY,W extends Window> |
Wrapper for reading state from an evicting window operator.
|
EvictingWindowSavepointReader<W extends Window> |
This class provides entry points for reading keyed state written out using the
WindowOperator .
|
Evictor<T,W extends Window> |
An Evictor can remove elements from a pane before/after the evaluation of WindowFunction
and after the window evaluation gets triggered by a Trigger
|
Evictor.EvictorContext |
A context object that is given to Evictor methods.
|
ExceptionHandler<E extends Throwable> |
Interface to be implemented by classes that handle exceptions.
|
ExceptionHistoryEntry |
ExceptionHistoryEntry collects information about a single failure that triggered the
scheduler's failure handling.
|
ExceptionHistoryEntry.ArchivedTaskManagerLocation |
|
ExceptionInChainedOperatorException |
A special exception that signifies that the cause exception came from a chained operator.
|
ExceptionInChainedStubException |
A special exception to indicate that an exception occurred in the nested call of a chained stub.
|
ExceptionInMultipleInputOperatorException |
|
ExceptionUtils |
A collection of utility functions for dealing with exceptions and exception workflows.
|
ExclusiveBuffersUsageGauge |
Gauge metric measuring the exclusive buffers usage gauge for SingleInputGate s.
|
ExecEdge |
The representation of an edge connecting two ExecNode s.
|
ExecEdge.Builder |
|
ExecEdge.HashShuffle |
Records are shuffled by hash when passing through this edge.
|
ExecEdge.Shuffle |
|
ExecEdge.Shuffle.Type |
Enumeration which describes the shuffle type for records when passing this edge.
|
ExecNode<T> |
The representation of execution information for a FlinkPhysicalRel .
|
ExecNodeBase<T> |
|
ExecNodeConfig |
|
ExecNodeContext |
Helper class that holds the necessary identifier fields that are used for JSON plan serialization
and deserialization.
|
ExecNodeGraph |
|
ExecNodeGraphGenerator |
A generator that generates a ExecNode graph from a graph of FlinkPhysicalRel s.
|
ExecNodeGraphInternalPlan |
|
ExecNodeGraphProcessor |
|
ExecNodeGraphValidator |
|
ExecNodeMetadata |
Annotation to be used for ExecNode s to keep necessary metadata when
serializing/deserializing them in a plan.
|
ExecNodeMetadataUtil |
|
ExecNodeMetadataUtil.ExecNodeNameVersion |
|
ExecNodePlanDumper |
An utility class for converting an exec node plan to a string as a tree style.
|
ExecNodeTranslator<T> |
|
ExecNodeUtil |
|
ExecNodeVisitor |
Visitor pattern for traversing a dag of ExecNode objects.
|
ExecNodeVisitorImpl |
|
Executable |
Represents an artifact that can be executed.
|
ExecutableOperation |
|
ExecutableOperation.Context |
The context to execute the operation.
|
ExecutableOperationContextImpl |
|
ExecutableOperationUtils |
Utils for the executable operation.
|
ExecutePlanOperation |
Operation to describe an EXECUTE PLAN statement.
|
ExecuteStatementHandler |
Handler to execute a statement.
|
ExecuteStatementHeaders |
Message headers for executing a statement.
|
ExecuteStatementRequestBody |
|
ExecuteStatementResponseBody |
|
Execution |
A single execution of a vertex.
|
ExecutionAttemptID |
Unique identifier for the attempt to execute a tasks.
|
ExecutionConfig |
A config to define the behavior of the program execution.
|
ExecutionConfig.ClosureCleanerLevel |
Configuration settings for the closure cleaner.
|
ExecutionConfig.GlobalJobParameters |
Abstract class for a custom user configuration object registered at the execution config.
|
ExecutionConfigAccessor |
Accessor that exposes config settings that are relevant for execution from an underlying Configuration .
|
ExecutionConfigOptions |
This class holds configuration constants used by Flink's table module.
|
ExecutionConfigOptions.AsyncOutputMode |
Output mode for asynchronous operations, equivalent to {@see AsyncDataStream.OutputMode}.
|
ExecutionConfigOptions.LegacyCastBehaviour |
Deprecated. |
ExecutionConfigOptions.NotNullEnforcer |
The enforcer to guarantee NOT NULL column constraint when writing data into sink.
|
ExecutionConfigOptions.RetryStrategy |
Retry strategy in the case of failure.
|
ExecutionConfigOptions.RowtimeInserter |
Rowtime attribute insertion strategy for the sink.
|
ExecutionConfigOptions.SinkKeyedShuffle |
Shuffle by primary key before sink.
|
ExecutionConfigOptions.TypeLengthEnforcer |
The enforcer to guarantee that length of CHAR/VARCHAR/BINARY/VARBINARY columns is respected
when writing data into a sink.
|
ExecutionConfigOptions.UidGeneration |
Strategy for generating transformation UIDs for remapping state to operators during restore.
|
ExecutionConfigOptions.UpsertMaterialize |
Upsert materialize strategy before sink.
|
ExecutionContext |
A ExecutionContext contains information about the context in which functions are executed and the
APIs to create state.
|
ExecutionContextEnvironment |
|
ExecutionContextImpl |
Implementation of ExecutionContext.
|
ExecutionDeployer |
This deployer is responsible for deploying executions.
|
ExecutionDeployer.Factory |
|
ExecutionDeploymentListener |
A listener that is called when the deployment of an execution has been started/completed.
|
ExecutionDeploymentReconciler |
Component for reconciling the deployment state of executions.
|
ExecutionDeploymentReconciler.Factory |
|
ExecutionDeploymentReconciliationHandler |
Interface for triggering actions in case of state mismatches.
|
ExecutionDeploymentReport |
A report about the currently deployed executions of a TaskExecutor.
|
ExecutionDeploymentState |
Possible states for the deployment of an execution.
|
ExecutionDeploymentTracker |
A tracker for deployed executions.
|
ExecutionDeploymentTrackerDeploymentListenerAdapter |
|
ExecutionEnvironment |
This is the context in which a program is executed.
|
ExecutionEnvironmentFactory |
Factory class for execution environments.
|
ExecutionEnvironmentImpl |
|
ExecutionFailureHandler |
This handler deals with task failures to return a FailureHandlingResult which contains
tasks to restart to recover from failures.
|
ExecutionGraph |
The execution graph is the central data structure that coordinates the distributed execution of a
data flow.
|
ExecutionGraphCache |
|
ExecutionGraphCheckpointPlanCalculatorContext |
|
ExecutionGraphException |
|
ExecutionGraphException |
|
ExecutionGraphFactory |
|
ExecutionGraphHandler |
|
ExecutionGraphID |
A class for statistically unique execution graph IDs.
|
ExecutionGraphInfo |
ExecutionGraphInfo serves as a composite class that provides different ExecutionGraph -related information.
|
ExecutionGraphInfoStore |
|
ExecutionGraphResultPartitionAvailabilityChecker |
A ResultPartitionAvailabilityChecker which decides the intermediate result partition
availability based on whether the corresponding result partition in the execution graph is
tracked.
|
ExecutionGraphToInputsLocationsRetrieverAdapter |
|
ExecutionGraphUtils |
|
ExecutionHistory |
|
ExecutionJobVertex |
|
ExecutionJobVertex.Factory |
|
ExecutionJobVertexInitializedEvent |
|
ExecutionOperations |
|
ExecutionOptions |
ConfigOption s specific for a single execution of a user program.
|
ExecutionPlan |
An interface representing a general execution plan, which can be implemented by different types
of graphs such as JobGraph and StreamGraph.
|
ExecutionPlanStore |
|
ExecutionPlanStore.ExecutionPlanListener |
|
ExecutionPlanStoreUtil |
ExecutionPlanStore utility interfaces.
|
ExecutionPlanStoreWatcher |
|
ExecutionPlanUtils |
|
ExecutionPlanWriter |
Allows to store and remove execution plans.
|
ExecutionSlotAllocator |
Component responsible for assigning slots to a collection of Execution .
|
ExecutionSlotAllocatorFactory |
|
ExecutionSlotSharingGroup |
Represents execution vertices that will run the same shared slot.
|
ExecutionState |
An enumeration of all states that a task can be in during its execution.
|
ExecutionStateUpdateListener |
A listener that is called when an execution switched to a new state.
|
ExecutionTimeBasedSlowTaskDetector |
The slow task detector which detects slow tasks based on their execution time.
|
ExecutionVertex |
The ExecutionVertex is a parallel subtask of the execution.
|
ExecutionVertexFinishedEvent |
|
ExecutionVertexID |
|
ExecutionVertexInputInfo |
This class describe the inputs(partitions and subpartitions that belong to the same intermediate
result) information of an execution vertex.
|
ExecutionVertexResetEvent |
|
ExecutionVertexVersion |
This class helps to record version of an execution vertex.
|
ExecutionVertexVersioner |
Records modifications of ExecutionVertices , and allows for checking whether a vertex was modified.
|
Executor |
A gateway for communicating with Flink and other external systems.
|
Executor |
|
ExecutorFactory |
Factory that creates an Executor for submitting table programs.
|
ExecutorImpl |
Executor to connect to SqlGateway and execute statements.
|
ExecutorNotifier |
This class is used to coordinate between two components, where one component has an executor
following the mailbox model and the other component notifies it when needed.
|
Executors |
|
ExecutorThreadFactory |
A thread factory intended for use by critical thread pools.
|
ExecutorThreadFactory.Builder |
|
ExecutorUtils |
|
ExistingField |
Deprecated.
|
Expander |
Utility that expand SQL identifiers in a SQL query.
|
Expander.Expanded |
Result of expanding.
|
ExpandingPreparingTable |
A common subclass for all tables that are expanded to sub-query (views).
|
Experimental |
Annotation to mark classes for experimental use.
|
Explainable<SELF extends Explainable<SELF>> |
Represents an artifact that can be explained using a summary string.
|
ExplainDetail |
ExplainDetail defines the types of details for explain result.
|
ExplainFormat |
Explain format categorizes the output format of explain result.
|
ExplainOperation |
Operation to describe an EXPLAIN statement.
|
ExplicitArgumentTypeStrategy |
Strategy for an argument that corresponds to an explicitly defined type.
|
ExplicitTypeStrategy |
Type strategy that returns a fixed DataType .
|
ExponentialBackoffRetryStrategy |
An implementation of RetryStrategy that retries that has an exponential backoff with a
cap.
|
ExponentialDelayRestartBackoffTimeStrategy |
Restart strategy which tries to restart indefinitely number of times with an exponential backoff
time in between.
|
ExponentialDelayRestartBackoffTimeStrategy.ExponentialDelayRestartBackoffTimeStrategyFactory |
|
ExponentialWaitStrategy |
|
Expression |
General interface for all kinds of expressions.
|
ExpressionBuilder |
|
ExpressionCodeGeneratorCastRule<IN,OUT> |
Cast rule that is able to generate a single expression containing all the casting logic.
|
ExpressionConverter |
Visit expression to generator RexNode .
|
ExpressionDefaultVisitor<T> |
|
ExpressionParserException |
Deprecated.
|
ExpressionParserException |
Exception for all errors occurring during expression parsing.
|
ExpressionResolver |
|
ExpressionResolver.ExpressionResolverBuilder |
|
Expressions |
Entry point of the Table API Expression DSL such as: $("myField").plus(10).abs()
|
ExpressionUtils |
|
ExpressionVisitor<R> |
|
ExtendedParser |
|
ExtendedParseStrategy |
Strategy to parse statement to Operation . parsing some special command which can't
supported by CalciteParser , e.g.
|
ExtendedRelTypeFactory |
A factory for creating RelDataType instances including Flink-specific extensions.
|
ExtendedSqlCollectionTypeNameSpec |
A extended sql type name specification of collection type, different with SqlCollectionTypeNameSpec , we support NULL or NOT NULL suffix for the element type name(this
syntax does not belong to standard SQL).
|
ExtendedSqlNode |
An remark interface which should be inherited by extended sql nodes which are not supported by
Calcite core parser.
|
ExtendedSqlRowTypeNameSpec |
A sql type name specification of ROW type.
|
ExternalCatalogTable |
Helper CatalogTable for representing a table that is backed by some inline connector
(i.e.
|
ExternalContext |
External context for interacting with external system in testing framework.
|
ExternalContextFactory<C extends ExternalContext> |
|
ExternalizedCheckpointRetention |
Cleanup behaviour for externalized checkpoints when the job is cancelled.
|
ExternallyInducedSource<T,CD> |
Deprecated.
|
ExternallyInducedSource.CheckpointTrigger |
Through the CheckpointTrigger , the source function notifies the Flink source operator
when to trigger the checkpoint.
|
ExternallyInducedSourceReader<T,SplitT extends SourceSplit> |
Sources that implement this interface delay checkpoints when receiving a trigger message from the
checkpoint coordinator to the point when their input data/events indicate that a checkpoint
should be triggered.
|
ExternalModifyOperation |
Internal operation used to convert a Table into a DataStream.
|
ExternalPythonBatchCoBroadcastProcessOperator<IN1,IN2,OUT> |
|
ExternalPythonBatchKeyedCoBroadcastProcessOperator<OUT> |
|
ExternalPythonCoProcessOperator<IN1,IN2,OUT> |
|
ExternalPythonKeyedCoProcessOperator<OUT> |
|
ExternalPythonKeyedProcessOperator<OUT> |
|
ExternalPythonProcessOperator<IN,OUT> |
ExternalPythonProcessOperator is responsible for launching beam runner which will start a
python harness to execute user defined python ProcessFunction.
|
ExternalQueryOperation<E> |
Describes a relational operation that reads from a DataStream .
|
ExternalResource |
An external resource.
|
ExternalResource |
Modified version of the jUnit ExternalResource .
|
ExternalResourceDriver |
Driver which takes the responsibility to manage and provide the information of external resource.
|
ExternalResourceDriverFactory |
|
ExternalResourceInfo |
Contains the information of an external resource.
|
ExternalResourceInfoProvider |
Provide the information of external resources.
|
ExternalResourceOptions |
Configuration options for external resources and external resource drivers.
|
ExternalResourceUtils |
Utility class for external resource framework.
|
ExternalSerializer<I,E> |
A serializer that can serialize and deserialize all data structures defined by a DataType .
|
ExternalSerializer.ExternalSerializerSnapshot<I,E> |
|
ExternalServiceDecorator |
Creates an external Service to expose the rest port of the Flink JobManager(s).
|
ExternalSorter<E> |
|
ExternalSorterBuilder<T> |
|
ExternalSystemDataReader<T> |
A data reader for consuming records from an external system.
|
ExternalSystemSplitDataWriter<T> |
A data writer for writing records into a SourceSplit in the external system.
|
ExternalTypeInfo<T> |
Type information that wraps a serializer that originated from a DataType .
|
ExtraCalciteResource |
Compiler-checked resources similar to CalciteResource in Calcite project.
|
ExtractionAwareDeltaFunction<DATA,TO> |
Extend this abstract class to implement a delta function which is aware of extracting the data on
which the delta is calculated from a more complex data structure.
|
ExtractionUtils |
Utilities for performing reflection tasks.
|
ExtractionUtils.AssigningConstructor |
|
ExtractionVersion |
Logical version that describes the expected behavior of the reflection-based data type
extraction.
|
Extractor<T> |
An Extractor turns a record into a byte array for writing data.
|
Extractor<FROM,TO> |
Extractors allow to extract/convert one type to another.
|
Fabric8FlinkKubeClient |
|
Factory |
Base interface for all kind of factories that create object instances from a list of key-value
pairs in Flink's Table & SQL API.
|
FactoryUtil |
|
FactoryUtil.CatalogFactoryHelper |
|
FactoryUtil.CatalogStoreFactoryHelper |
|
FactoryUtil.DefaultCatalogContext |
|
FactoryUtil.DefaultCatalogStoreContext |
|
FactoryUtil.DefaultDynamicTableContext |
|
FactoryUtil.DefaultModuleContext |
|
FactoryUtil.FactoryHelper<F extends Factory> |
Base helper utility for validating all options for a Factory .
|
FactoryUtil.ModuleFactoryHelper |
|
FactoryUtil.TableFactoryHelper |
|
FactoryUtils |
Utilities for factories.
|
FactoryUtils.FactoryInvoker<F,R> |
Interface for invoking the factory.
|
FailedCheckpointStats |
Statistics for a failed checkpoint.
|
FailoverStrategy |
New interface for failover strategies.
|
FailoverStrategy.Factory |
|
FailoverStrategyFactoryLoader |
A utility class to load NG failover strategy factories from the configuration.
|
FailsInGHAContainerWithRootUser |
Collects tests that fail in GitHub Actions workflows that execute the tests in containers as a
root user.
|
FailsOnJava11 |
Marker interface for tests that fail on Java 11.
|
FailsOnJava17 |
Marker interface for tests that fail on Java 17.
|
FailsWithAdaptiveScheduler |
Marker for explicitly ignoring a test which fails with adaptive scheduler.
|
FailureEnricher |
Failure Enricher enabling custom logic and attaching metadata in the form of labels to each type
of failure as tracked in the JobMaster.
|
FailureEnricher.Context |
|
FailureEnricher.Context.FailureType |
Type of failure.
|
FailureEnricherFactory |
|
FailureEnricherTestProgram |
|
FailureEnricherUtils |
Utils class for loading and running pluggable failure enrichers.
|
FailureHandlingResult |
Result containing the tasks to restart upon a task failure.
|
FailureHandlingResultSnapshot |
|
FailureLabelFilterParameter |
Specifies a collections of failure labels, filtering the exceptions returned for
JobExceptionsHandler.
|
FailureLabelFilterParameter.FailureLabel |
Represents a failure label consisting of a KV pair of strings.
|
FailureMapper<T> |
This mapper simulates failure by throwing exceptions.
|
FailureRateRestartBackoffTimeStrategy |
Restart strategy which can restart when failure rate is not exceeded.
|
FailureRateRestartBackoffTimeStrategy.FailureRateRestartBackoffTimeStrategyFactory |
|
FailureResultUtil |
|
FallbackKey |
A key with FallbackKeys will fall back to the FallbackKeys if it itself is not configured.
|
FallbackYarnSessionCli |
A stub Yarn Command Line to throw an exception with the correct message when the
HADOOP_CLASSPATH is not set.
|
FamilyArgumentTypeStrategy |
Strategy for an argument that corresponds to a given LogicalTypeFamily and nullability.
|
FastTop1Function |
|
FatalErrorHandler |
Handler for fatal errors.
|
FatalExceptionClassifier |
Classifier class for retryable exceptions on request submission failure.
|
FatalExitExceptionHandler |
Handler for uncaught exceptions that will log the exception and kill the process afterwards.
|
FencedMessage<F extends Serializable,P> |
Interface for fenced messages.
|
FencedPekkoInvocationHandler<F extends Serializable> |
Fenced extension of the PekkoInvocationHandler .
|
FencedPekkoRpcActor<F extends Serializable,T extends FencedRpcEndpoint<F> & RpcGateway> |
Fenced extension of the PekkoRpcActor .
|
FencedRpcEndpoint<F extends Serializable> |
|
FencedRpcGateway<F extends Serializable> |
|
FencingTokenException |
|
FetchOrientation |
Orientation to fetch results.
|
FetchResultResponseBodyDeserializer |
|
FetchResultResponseBodyImpl |
|
FetchResultsHandler |
Handler to fetch results.
|
FetchResultsHeaders |
Message headers for fetching results.
|
FetchResultsMessageParameters |
|
FetchResultsResponseBody |
|
FetchResultsResponseBodySerializer |
|
FetchResultsRowFormatQueryParameter |
|
FetchResultsTokenPathParameter |
|
FieldAccessor<T,F> |
These classes encapsulate the logic of accessing a field specified by the user as either an index
or a field expression string.
|
FieldAccessorFactory |
|
FieldComputer<T> |
Deprecated.
|
FieldFromArray<OUT> |
Extracts a single field out of an array.
|
FieldFromTuple<OUT> |
Extracts a single field out of a tuple.
|
FieldInfoUtils |
Utility methods for extracting names and indices of fields from different TypeInformation s.
|
FieldInfoUtils.TypeInfoSchema |
|
FieldList |
Immutable ordered list of fields IDs.
|
FieldParser<T> |
A FieldParser is used parse a field from a sequence of bytes.
|
FieldParser.ParseErrorState |
An enumeration of different types of errors that may occur.
|
FieldReferenceExpression |
A reference to a field in an input.
|
FieldReferenceLookup |
Provides a way to look up field reference by the name of the field.
|
FieldsDataType |
A data type that contains field data types (i.e. row and structured type).
|
FieldSerializer |
This class is for the serialization of java.lang.reflect.Field, which doesn't implement
Serializable, therefore readObject/writeObject need to be implemented in classes where there is a
field of type java.lang.reflect.Field.
|
FieldSet |
Immutable unordered collection of fields IDs.
|
FieldsFromArray<OUT> |
Extracts multiple fields from an array and puts them into a new array of the specified type.
|
FieldsFromTuple |
Extracts one or more fields of the type Double from a tuple and puts them into a new double[].
|
FileBasedBufferIterator |
|
FileBasedCache |
A file-granularity LRU cache.
|
FileBasedStateOutputStream |
|
FileBasedStatisticsReportableInputFormat |
Extension of input format which is able to report estimated statistics for file based connector.
|
FileCache |
The FileCache is used to access registered cache files when a task is deployed.
|
FileCacheEntry |
A file cache entry that encapsulates file and the size of the file, and provides methods to read
or write file.
|
FileCatalogStore |
A CatalogStore that stores all catalog configuration to a directory.
|
FileCatalogStoreFactory |
|
FileCatalogStoreFactoryOptions |
|
FileChannelInputView |
|
FileChannelManager |
The manager used for creating/getting file IO channels based on config temp dirs.
|
FileChannelManagerImpl |
The manager used for creating/deleting file channels based on config temp dirs.
|
FileChannelOutputView |
|
FileChannelUtil |
File channel util for runtime.
|
FileCommitter |
|
FileCompactor |
The FileCompactor is responsible for compacting files into one file.
|
FileCompactStrategy |
Strategy for compacting the files written in FileSink before committing.
|
FileCompactStrategy.Builder |
|
FileCopyFunction |
This output format copies files from an existing savepoint into a new directory.
|
FileDataIndexCache<T extends FileDataIndexRegionHelper.Region> |
A cache layer of hybrid data index.
|
FileDataIndexRegionHelper<T extends FileDataIndexRegionHelper.Region> |
|
FileDataIndexRegionHelper.Region |
A FileDataIndexRegionHelper.Region Represents a series of buffers that are:
From the same subpartition
Logically (i.e. buffer index) consecutive
Physically (i.e. offset in the file) consecutive
|
FileDataIndexSpilledRegionManager<T extends FileDataIndexRegionHelper.Region> |
This class is responsible for spilling region to disk and managing these spilled regions.
|
FileDataIndexSpilledRegionManager.Factory<T extends FileDataIndexRegionHelper.Region> |
|
FileDataIndexSpilledRegionManagerImpl<T extends FileDataIndexRegionHelper.Region> |
|
FileDataIndexSpilledRegionManagerImpl.Factory<T extends FileDataIndexRegionHelper.Region> |
|
FileEnumerator |
The FileEnumerator 's task is to discover all files to be read and to split them into a
set of FileSourceSplit .
|
FileEnumerator.Provider |
Factory for the FileEnumerator , to allow the FileEnumerator to be eagerly
initialized and to not be serializable.
|
FileExecutionGraphInfoStore |
|
FileInputFormat<OT> |
|
FileInputFormat.FileBaseStatistics |
Encapsulation of the basic statistics the optimizer obtains about a file.
|
FileInputFormat.InputSplitOpenThread |
Obtains a DataInputStream in an thread that is not interrupted.
|
FileInputFormatCompactReader<T> |
|
FileInputSplit |
A file input split provides information on a particular part of a file, possibly hosted on a
distributed file system and replicated among several hosts.
|
FileIOChannel |
A Channel represents a collection of files that belong logically to the same resource.
|
FileIOChannel.Enumerator |
An enumerator for channels that logically belong together.
|
FileIOChannel.ID |
An ID identifying an underlying file channel.
|
FileJobGraphRetriever |
|
FileLifeCycleListener<BucketID> |
Listener about the status of file.
|
FileLock |
A file lock used for avoiding race condition among multiple threads/processes.
|
FileMergingCheckpointStateOutputStream |
|
FileMergingCheckpointStateOutputStream.FileMergingSnapshotManagerProxy |
|
FileMergingMetricGroup |
Metrics related to the file merging snapshot manager.
|
FileMergingOperatorStreamStateHandle |
|
FileMergingSnapshotManager |
FileMergingSnapshotManager provides an interface to manage files and meta information for
checkpoint files with merging checkpoint files enabled.
|
FileMergingSnapshotManager.SpaceStat |
Space usage statistics of a managed directory.
|
FileMergingSnapshotManager.SubtaskKey |
A key identifies a subtask.
|
FileMergingSnapshotManagerBase |
|
FileMergingSnapshotManagerBase.DirectoryHandleWithReferenceTrack |
This class wrap DirectoryStreamStateHandle with reference count by ongoing checkpoint.
|
FileMergingSnapshotManagerBuilder |
|
FileMergingSnapshotManagerClosableWrapper |
|
FileMergingType |
How the checkpoint files can be segmented.
|
FileMessageParameters |
|
FileMonitoringFunction |
Deprecated.
|
FileMonitoringFunction.WatchType |
The watch type of the FileMonitoringFunction .
|
FileOutputFormat<IT> |
The abstract base class for all Rich output formats that are file based.
|
FileOutputFormat.OutputDirectoryMode |
Behavior for creating output directories.
|
FilePathFilter |
|
FilePathFilter.DefaultFilter |
The default file path filtering method and is used if no other such function is provided.
|
FileProcessingMode |
|
FileReadFunction |
Deprecated.
|
FileRecords<T> |
A collection of records for one file split.
|
FileRegionBuffer |
This class represents a chunk of data in a file channel.
|
FileRegionWriteReadUtils |
|
FileSegment |
|
FileSink<IN> |
A unified sink that emits its input elements to FileSystem files within buckets.
|
FileSink.BulkFormatBuilder<IN,T extends FileSink.BulkFormatBuilder<IN,T>> |
A builder for configuring the sink for bulk-encoding formats, e.g.
|
FileSink.DefaultBulkFormatBuilder<IN> |
Builder for the vanilla FileSink using a bulk format.
|
FileSink.DefaultRowFormatBuilder<IN> |
Builder for the vanilla FileSink using a row format.
|
FileSink.RowFormatBuilder<IN,T extends FileSink.RowFormatBuilder<IN,T>> |
A builder for configuring the sink for row-wise encoding formats.
|
FileSinkCommittable |
Wrapper class for both type of committables in FileSink .
|
FileSinkCommittableSerializer |
|
FileSinkProgram |
|
FileSinkProgram.KeyBucketAssigner |
Use first field for buckets.
|
FileSlotAllocationSnapshotPersistenceService |
|
FileSource<T> |
A unified data source that reads files - both in batch and in streaming mode.
|
FileSource.FileSourceBuilder<T> |
The builder for the FileSource , to configure the various behaviors.
|
FileSourceReader<T,SplitT extends FileSourceSplit> |
|
FileSourceSplit |
A SourceSplit that represents a file, or a region of a file.
|
FileSourceSplitSerializer |
|
FileSourceSplitState<SplitT extends FileSourceSplit> |
|
FileSplitAssigner |
The FileSplitAssigner is responsible for deciding what split should be processed next by
which node.
|
FileSplitAssigner.Provider |
Factory for the FileSplitAssigner , to allow the FileSplitAssigner to be
eagerly initialized and to not be serializable.
|
FileStateHandle |
|
FileStatus |
Interface that represents the client side information for a file independent of the file system.
|
FileSystem |
Abstract base class of all file systems used by Flink.
|
FileSystem.FSKey |
An identifier of a file system, via its scheme and its authority.
|
FileSystem.WriteMode |
The possible write modes.
|
FileSystemBlobStore |
|
FileSystemCheckpointStorage |
|
FileSystemCommitter |
File system file committer implementation.
|
FileSystemConnectorOptions |
Options for the filesystem connector.
|
FileSystemConnectorOptions.FileStatisticsType |
|
FileSystemConnectorOptions.PartitionCommitTriggerType |
|
FileSystemFactory |
A factory to create file systems.
|
FileSystemFactory |
A factory to create file systems.
|
FileSystemJobEventStore |
|
FileSystemJobResultStore |
An implementation of the JobResultStore which persists job result data to an underlying
distributed filesystem.
|
FileSystemKind |
An enumeration defining the kind and characteristics of a FileSystem .
|
FileSystemOutputFormat<T> |
|
FileSystemOutputFormat.Builder<T> |
|
FileSystemSafetyNet |
The FileSystemSafetyNet can be used to guard a thread against FileSystem stream resource
leaks.
|
FileSystemStateStorageHelper<T extends Serializable> |
|
FileSystemTableFactory |
|
FileSystemTableSink |
|
FileSystemTableSink.ProjectionBulkFactory |
Project row to non-partition fields.
|
FileSystemTableSink.TableBucketAssigner |
|
FileSystemTableSink.TableRollingPolicy |
|
FileSystemTableSource |
File system table source.
|
FileSystemValidator |
Deprecated.
|
FileType |
|
FileUpload |
Client uploading a file.
|
FileUploadHandler |
Writes multipart/form-data to disk.
|
FileUploads |
A container for uploaded files.
|
FileUtils |
Collection of file-related utilities.
|
FileUtils |
This is a utility class to deal files and directories.
|
FileWriter<IN> |
|
FileWriterBucketFactory<IN> |
A factory able to create FileWriterBucket for the FileSink .
|
FileWriterBucketState |
States for FileWriterBucket .
|
FileWriterBucketStateSerializer |
A SimpleVersionedSerializer used to serialize the BucketState .
|
FilterableTableSource<T> |
Deprecated.
|
FilterAllFlatMapFunction |
Function filtering out all the input records.
|
FilterCondition |
Interface for code generated filter condition function on single RowData.
|
FilteredClassLoader |
A ClassLoader that filters out certain classes (by name) and throws a ClassNotFoundException when
they should be loaded.
|
FilterFunction<T> |
A filter function is a predicate applied individually to each record.
|
FilterOperatorBase<T,FT extends FlatMapFunction<T,T>> |
|
FilterPushDownSpec |
|
FilterQueryOperation |
Filters out rows of underlying relational operation that do not match given condition.
|
FinalizeOnMaster |
This interface may be implemented by OutputFormat s to have the master finalize them
globally.
|
FinalizeOnMaster.FinalizationContext |
A context that provides parallelism and finished attempts infos.
|
FineGrainedSlotManager |
Implementation of SlotManager supporting fine-grained resource management.
|
FineGrainedTaskManagerRegistration |
A FineGrainedTaskManagerRegistration represents a TaskManager.
|
FineGrainedTaskManagerSlot |
A FineGrainedTaskManagerSlot represents a slot located in a TaskManager.
|
FineGrainedTaskManagerTracker |
Implementation of TaskManagerTracker supporting fine-grained resource management.
|
FinishedDataOutput<IN> |
|
FinishedOnRestoreInput<IN> |
A fake Input for finished on restore tasks.
|
FinishedOnRestoreMainOperatorOutput<OUT> |
A fake main operator output that skips all the following operators for finished on restored
tasks.
|
FinishedOperatorChain<OUT,OP extends StreamOperator<OUT>> |
|
FinishedOperatorSubtaskState |
|
FinishedTaskStateProvider |
Collects and fulfills the finished state for the subtasks or operators.
|
FinishedTaskStateProvider.PartialFinishingNotSupportedByStateException |
Thrown when some subtasks of the operator have been finished but state doesn't support that
(e.g.
|
FiniteTestSource<T> |
A stream source that: 1) emits a list of elements without allowing checkpoints, 2) then waits for
two more checkpoints to complete, 3) then re-emits the same elements before 4) waiting for
another two checkpoints and 5) exiting.
|
FirstAttemptInitializationContext |
|
FirstInputOfTwoInput |
|
FirstInputOfTwoInputStreamOperatorOutput |
|
FirstTypeStrategy |
Type strategy that returns the first type that could be inferred.
|
FirstValueAggFunction<T> |
Built-in FIRST_VALUE aggregate function.
|
FirstValueWithRetractAggFunction<T> |
Built-in FIRST_VALUE with retraction aggregate function.
|
FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator<T> |
Accumulator for FIRST_VALUE.
|
FixedDelayRestartBackoffTimeStrategy |
Restart strategy which tries to restart a fixed number of times with a fixed backoff time in
between.
|
FixedDelayRestartBackoffTimeStrategy.FixedDelayRestartBackoffTimeStrategyFactory |
|
FixedLenBytesColumnReader<VECTOR extends WritableColumnVector> |
|
FixedLengthByteKeyAndValueComparator<INPUT> |
|
FixedLengthRecordSorter<T> |
|
FixedRetryStrategy |
An implementation of RetryStrategy that retries at a fixed delay.
|
FlameGraphTypeQueryParameter |
Flame Graph type query parameter.
|
FlameGraphTypeQueryParameter.Type |
Flame Graph type.
|
FlatAggregateTable |
|
FlatJoinFunction<IN1,IN2,OUT> |
Interface for Join functions.
|
FlatMapDriver<IT,OT> |
Map task which is executed by a Task Manager.
|
FlatMapFunction<T,O> |
Base interface for flatMap functions.
|
FlatMapOperatorBase<IN,OUT,FT extends FlatMapFunction<IN,OUT>> |
|
FlinkAggregateExpandDistinctAggregatesRule |
Planner rule that expands distinct aggregates (such as COUNT(DISTINCT x) ) from a Aggregate .
|
FlinkAggregateJoinTransposeRule |
Planner rule that pushes an Aggregate past a Join .
|
FlinkAggregateProjectMergeRule |
Extends calcite's AggregateProjectMergeRule, modification: consider the timeAttribute field when
analyzing interesting fields for the LogicalWindowAggregate node while normal Aggregate node
needn't.
|
FlinkAggregateRemoveRule |
Planner rule that removes a Aggregate if its aggregate
functions are SUM, MIN, MAX, AUXILIARY_GROUP with no filterArgs, and the underlying relational
expression is already distinct.
|
FlinkAssertions |
Some reusable assertions and utilities for AssertJ.
|
FlinkBushyJoinReorderRule |
Flink bushy join reorder rule, which will convert MultiJoin to a bushy join tree.
|
FlinkBushyJoinReorderRule.Config |
Rule configuration.
|
FlinkCalciteCatalogReader |
|
FlinkCalciteCatalogSnapshotReader |
|
FlinkCalciteSqlValidator |
Extends Calcite's SqlValidator by Flink-specific behavior.
|
FlinkCalcMergeRule |
Planner rule that merges a Calc onto a Calc .
|
FlinkCalcMergeRule.FlinkCalcMergeRuleConfig |
Rule configuration.
|
FlinkChillPackageRegistrar |
Registers all chill serializers used for Java types.
|
FlinkCompletableFutureAssert<T> |
Enhanced version of CompletableFutureAssert , that allows asserting
futures without relying on timeouts.
|
FlinkCompletableFutureAssert.WithThrowable |
A strongly typed alternative to WithThrowable .
|
FlinkConfigLoader |
Util class for loading configuration from commandline arguments.
|
FlinkConfMountDecorator |
Mounts the log4j.properties, logback.xml, and config.yaml configuration on the JobManager or
TaskManager pod.
|
FlinkConnection |
Connection to flink sql gateway for jdbc driver.
|
FlinkConnectorRateLimiter |
An interface to create a ratelimiter
|
FlinkContainers |
A Flink cluster running JM and TMs on containers.
|
FlinkContainers.Builder |
|
FlinkContainersSettings |
The central configuration holder for Flink container-based test environments.
|
FlinkContainersSettings.Builder |
FlinkContainersConfig builder static inner class.
|
FlinkContainerTestEnvironment |
|
FlinkConvertletTable |
Custom Flink SqlRexConvertletTable to add custom SqlNode to RexNode
conversions.
|
FlinkCounterWrapper |
A wrapper that allows a Flink counter to be used as a DropWizard counter.
|
FlinkCurrentDateDynamicFunction |
The Flink CURRENT_DATE function differs from the parent SqlCurrentDateFunction which is
aware of whether it is used in batch mode, if true it will act totally same as the parent SqlCurrentDateFunction , but will be a non-deterministic function if not in batch mode.
|
FlinkCurrentRowTimestampFunction |
The function CURRENT_ROW_TIMESTAMP() in Flink which supports configuring the return type and the
precision of return type.
|
FlinkDatabaseMetaData |
|
FlinkDataSource |
|
FlinkDistribution |
A wrapper around a Flink distribution.
|
FlinkDistribution.TestSqlGatewayRestClient |
This rest client is used to submit SQL strings to Rest Endpoint of Sql Gateway.
|
FlinkDriver |
Jdbc Driver for flink sql gateway.
|
FlinkDriverExample |
E2E tests for flink jdbc driver.
|
FlinkDynamicPartitionPruningProgram |
Planner program that tries to do partition prune in the execution phase, which can translate a
BatchPhysicalTableSourceScan to a BatchPhysicalDynamicFilteringTableSourceScan
whose source is a partition source.
|
FlinkException |
Base class of all Flink-specific checked exceptions.
|
FlinkExpectedException |
This class is just used to pass diagnostic message of some excepted procedure.
|
FlinkFilterCalcMergeRule |
Extends calcite's FilterCalcMergeRule, modification: only merge the two neighbouring Filter and Calc if each non-deterministic RexNode of bottom Calc should
appear at most once in the implicit project list and condition of top Filter .
|
FlinkFilterJoinRule<C extends FlinkFilterJoinRule.Config> |
Planner rule that pushes filters above and within a join node into the join node and/or its
children nodes.
|
FlinkFilterJoinRule.Config |
Rule configuration.
|
FlinkFilterJoinRule.FlinkFilterIntoJoinRule |
Rule that tries to push filter expressions into a join condition and into the inputs of the
join.
|
FlinkFilterJoinRule.FlinkFilterIntoJoinRule.FlinkFilterIntoJoinRuleConfig |
Rule configuration.
|
FlinkFilterJoinRule.FlinkJoinConditionPushRule |
Rule that pushes parts of the join condition to its inputs.
|
FlinkFilterJoinRule.FlinkJoinConditionPushRule.FlinkFilterJoinRuleConfig |
Rule configuration.
|
FlinkFilterJoinRule.Predicate |
Predicate that returns whether a filter is valid in the ON clause of a join for this
particular kind of join.
|
FlinkFilterProjectTransposeRule |
Extends calcite's FilterProjectTransposeRule for streaming scenario, modification: does not
transpose the top filter references field which generated by non-deterministic function.
|
FlinkFnApi |
|
FlinkFnApi.CoderInfoDescriptor |
A representation of the coder
|
FlinkFnApi.CoderInfoDescriptor.ArrowType |
Protobuf type org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType
|
FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder |
Protobuf type org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType
|
FlinkFnApi.CoderInfoDescriptor.ArrowTypeOrBuilder |
|
FlinkFnApi.CoderInfoDescriptor.Builder |
A representation of the coder
|
FlinkFnApi.CoderInfoDescriptor.DataTypeCase |
|
FlinkFnApi.CoderInfoDescriptor.FlattenRowType |
for Table & SQL
|
FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder |
for Table & SQL
|
FlinkFnApi.CoderInfoDescriptor.FlattenRowTypeOrBuilder |
|
FlinkFnApi.CoderInfoDescriptor.Mode |
Protobuf enum org.apache.flink.fn_execution.v1.CoderInfoDescriptor.Mode
|
FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType |
only used in batch over window
the data consists of [window data][arrow data]
|
FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder |
only used in batch over window
the data consists of [window data][arrow data]
|
FlinkFnApi.CoderInfoDescriptor.OverWindowArrowTypeOrBuilder |
|
FlinkFnApi.CoderInfoDescriptor.RawType |
for DataStream
|
FlinkFnApi.CoderInfoDescriptor.RawType.Builder |
for DataStream
|
FlinkFnApi.CoderInfoDescriptor.RawTypeOrBuilder |
|
FlinkFnApi.CoderInfoDescriptor.RowType |
Protobuf type org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType
|
FlinkFnApi.CoderInfoDescriptor.RowType.Builder |
Protobuf type org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType
|
FlinkFnApi.CoderInfoDescriptor.RowTypeOrBuilder |
|
FlinkFnApi.CoderInfoDescriptorOrBuilder |
|
FlinkFnApi.GroupWindow |
Protobuf type org.apache.flink.fn_execution.v1.GroupWindow
|
FlinkFnApi.GroupWindow.Builder |
Protobuf type org.apache.flink.fn_execution.v1.GroupWindow
|
FlinkFnApi.GroupWindow.WindowProperty |
Protobuf enum org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty
|
FlinkFnApi.GroupWindow.WindowType |
Protobuf enum org.apache.flink.fn_execution.v1.GroupWindow.WindowType
|
FlinkFnApi.GroupWindowOrBuilder |
|
FlinkFnApi.Input |
Protobuf type org.apache.flink.fn_execution.v1.Input
|
FlinkFnApi.Input.Builder |
Protobuf type org.apache.flink.fn_execution.v1.Input
|
FlinkFnApi.Input.InputCase |
|
FlinkFnApi.InputOrBuilder |
|
FlinkFnApi.JobParameter |
Protobuf type org.apache.flink.fn_execution.v1.JobParameter
|
FlinkFnApi.JobParameter.Builder |
Protobuf type org.apache.flink.fn_execution.v1.JobParameter
|
FlinkFnApi.JobParameterOrBuilder |
|
FlinkFnApi.OverWindow |
Used to describe the info of over window in pandas batch over window aggregation
|
FlinkFnApi.OverWindow.Builder |
Used to describe the info of over window in pandas batch over window aggregation
|
FlinkFnApi.OverWindow.WindowType |
Protobuf enum org.apache.flink.fn_execution.v1.OverWindow.WindowType
|
FlinkFnApi.OverWindowOrBuilder |
|
FlinkFnApi.Schema |
A representation of the data schema.
|
FlinkFnApi.Schema.BinaryInfo |
Protobuf type org.apache.flink.fn_execution.v1.Schema.BinaryInfo
|
FlinkFnApi.Schema.BinaryInfo.Builder |
Protobuf type org.apache.flink.fn_execution.v1.Schema.BinaryInfo
|
FlinkFnApi.Schema.BinaryInfoOrBuilder |
|
FlinkFnApi.Schema.Builder |
A representation of the data schema.
|
FlinkFnApi.Schema.CharInfo |
Protobuf type org.apache.flink.fn_execution.v1.Schema.CharInfo
|
FlinkFnApi.Schema.CharInfo.Builder |
Protobuf type org.apache.flink.fn_execution.v1.Schema.CharInfo
|
FlinkFnApi.Schema.CharInfoOrBuilder |
|
FlinkFnApi.Schema.DecimalInfo |
Protobuf type org.apache.flink.fn_execution.v1.Schema.DecimalInfo
|
FlinkFnApi.Schema.DecimalInfo.Builder |
Protobuf type org.apache.flink.fn_execution.v1.Schema.DecimalInfo
|
FlinkFnApi.Schema.DecimalInfoOrBuilder |
|
FlinkFnApi.Schema.Field |
Protobuf type org.apache.flink.fn_execution.v1.Schema.Field
|
FlinkFnApi.Schema.Field.Builder |
Protobuf type org.apache.flink.fn_execution.v1.Schema.Field
|
FlinkFnApi.Schema.FieldOrBuilder |
|
FlinkFnApi.Schema.FieldType |
Protobuf type org.apache.flink.fn_execution.v1.Schema.FieldType
|
FlinkFnApi.Schema.FieldType.Builder |
Protobuf type org.apache.flink.fn_execution.v1.Schema.FieldType
|
FlinkFnApi.Schema.FieldType.TypeInfoCase |
|
FlinkFnApi.Schema.FieldTypeOrBuilder |
|
FlinkFnApi.Schema.LocalZonedTimestampInfo |
Protobuf type org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo
|
FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder |
Protobuf type org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo
|
FlinkFnApi.Schema.LocalZonedTimestampInfoOrBuilder |
|
FlinkFnApi.Schema.MapInfo |
Protobuf type org.apache.flink.fn_execution.v1.Schema.MapInfo
|
FlinkFnApi.Schema.MapInfo.Builder |
Protobuf type org.apache.flink.fn_execution.v1.Schema.MapInfo
|
FlinkFnApi.Schema.MapInfoOrBuilder |
|
FlinkFnApi.Schema.TimeInfo |
Protobuf type org.apache.flink.fn_execution.v1.Schema.TimeInfo
|
FlinkFnApi.Schema.TimeInfo.Builder |
Protobuf type org.apache.flink.fn_execution.v1.Schema.TimeInfo
|
FlinkFnApi.Schema.TimeInfoOrBuilder |
|
FlinkFnApi.Schema.TimestampInfo |
Protobuf type org.apache.flink.fn_execution.v1.Schema.TimestampInfo
|
FlinkFnApi.Schema.TimestampInfo.Builder |
Protobuf type org.apache.flink.fn_execution.v1.Schema.TimestampInfo
|
FlinkFnApi.Schema.TimestampInfoOrBuilder |
|
FlinkFnApi.Schema.TypeName |
Protobuf enum org.apache.flink.fn_execution.v1.Schema.TypeName
|
FlinkFnApi.Schema.VarBinaryInfo |
Protobuf type org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo
|
FlinkFnApi.Schema.VarBinaryInfo.Builder |
Protobuf type org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo
|
FlinkFnApi.Schema.VarBinaryInfoOrBuilder |
|
FlinkFnApi.Schema.VarCharInfo |
Protobuf type org.apache.flink.fn_execution.v1.Schema.VarCharInfo
|
FlinkFnApi.Schema.VarCharInfo.Builder |
Protobuf type org.apache.flink.fn_execution.v1.Schema.VarCharInfo
|
FlinkFnApi.Schema.VarCharInfoOrBuilder |
|
FlinkFnApi.Schema.ZonedTimestampInfo |
Protobuf type org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo
|
FlinkFnApi.Schema.ZonedTimestampInfo.Builder |
Protobuf type org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo
|
FlinkFnApi.Schema.ZonedTimestampInfoOrBuilder |
|
FlinkFnApi.SchemaOrBuilder |
|
FlinkFnApi.StateDescriptor |
A representation of State
|
FlinkFnApi.StateDescriptor.Builder |
A representation of State
|
FlinkFnApi.StateDescriptor.StateTTLConfig |
Protobuf type org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig
|
FlinkFnApi.StateDescriptor.StateTTLConfig.Builder |
Protobuf type org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies |
TTL cleanup strategies.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder |
TTL cleanup strategies.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy |
Protobuf enum org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy |
Configuration of cleanup strategy while taking the full snapshot.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder |
Configuration of cleanup strategy while taking the full snapshot.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategyOrBuilder |
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry |
Protobuf type org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder |
Protobuf type org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.CleanupStrategyCase |
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder |
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy |
Configuration of cleanup strategy using custom compaction filter in RocksDB.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder |
Configuration of cleanup strategy using custom compaction filter in RocksDB.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategyOrBuilder |
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies |
Fixed strategies ordinals in strategies config field.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategiesOrBuilder |
|
FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility |
This option configures whether expired user value can be returned or not.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic |
This option configures time scale to use for ttl.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType |
This option value configures when to update last access timestamp which prolongs state TTL.
|
FlinkFnApi.StateDescriptor.StateTTLConfigOrBuilder |
|
FlinkFnApi.StateDescriptorOrBuilder |
|
FlinkFnApi.TypeInfo |
A representation of the data type information in DataStream.
|
FlinkFnApi.TypeInfo.AvroTypeInfo |
Protobuf type org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo
|
FlinkFnApi.TypeInfo.AvroTypeInfo.Builder |
Protobuf type org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo
|
FlinkFnApi.TypeInfo.AvroTypeInfoOrBuilder |
|
FlinkFnApi.TypeInfo.Builder |
A representation of the data type information in DataStream.
|
FlinkFnApi.TypeInfo.MapTypeInfo |
Protobuf type org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo
|
FlinkFnApi.TypeInfo.MapTypeInfo.Builder |
Protobuf type org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo
|
FlinkFnApi.TypeInfo.MapTypeInfoOrBuilder |
|
FlinkFnApi.TypeInfo.RowTypeInfo |
Protobuf type org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo
|
FlinkFnApi.TypeInfo.RowTypeInfo.Builder |
Protobuf type org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo
|
FlinkFnApi.TypeInfo.RowTypeInfo.Field |
Protobuf type org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field
|
FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder |
Protobuf type org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field
|
FlinkFnApi.TypeInfo.RowTypeInfo.FieldOrBuilder |
|
FlinkFnApi.TypeInfo.RowTypeInfoOrBuilder |
|
FlinkFnApi.TypeInfo.TupleTypeInfo |
Protobuf type org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo
|
FlinkFnApi.TypeInfo.TupleTypeInfo.Builder |
Protobuf type org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo
|
FlinkFnApi.TypeInfo.TupleTypeInfoOrBuilder |
|
FlinkFnApi.TypeInfo.TypeInfoCase |
|
FlinkFnApi.TypeInfo.TypeName |
Protobuf enum org.apache.flink.fn_execution.v1.TypeInfo.TypeName
|
FlinkFnApi.TypeInfoOrBuilder |
|
FlinkFnApi.UserDefinedAggregateFunction |
Protobuf type org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction
|
FlinkFnApi.UserDefinedAggregateFunction.Builder |
Protobuf type org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction
|
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec |
Protobuf type org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec
|
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder |
Protobuf type org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec
|
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.DataViewCase |
|
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView |
Protobuf type org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView
|
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder |
Protobuf type org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView
|
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListViewOrBuilder |
|
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView |
Protobuf type org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView
|
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder |
Protobuf type org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView
|
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapViewOrBuilder |
|
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpecOrBuilder |
|
FlinkFnApi.UserDefinedAggregateFunctionOrBuilder |
|
FlinkFnApi.UserDefinedAggregateFunctions |
A list of the user-defined aggregate functions to be executed in a group aggregate operation.
|
FlinkFnApi.UserDefinedAggregateFunctions.Builder |
A list of the user-defined aggregate functions to be executed in a group aggregate operation.
|
FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder |
|
FlinkFnApi.UserDefinedDataStreamFunction |
User defined DataStream function definition.
|
FlinkFnApi.UserDefinedDataStreamFunction.Builder |
User defined DataStream function definition.
|
FlinkFnApi.UserDefinedDataStreamFunction.FunctionType |
Protobuf enum org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.FunctionType
|
FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext |
Protobuf type org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext
|
FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder |
Protobuf type org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext
|
FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder |
|
FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder |
|
FlinkFnApi.UserDefinedFunction |
User-defined function definition.
|
FlinkFnApi.UserDefinedFunction.Builder |
User-defined function definition.
|
FlinkFnApi.UserDefinedFunctionOrBuilder |
|
FlinkFnApi.UserDefinedFunctions |
A list of user-defined functions to be executed in a batch.
|
FlinkFnApi.UserDefinedFunctions.Builder |
A list of user-defined functions to be executed in a batch.
|
FlinkFnApi.UserDefinedFunctionsOrBuilder |
|
FlinkGaugeWrapper<T> |
A wrapper that allows a Flink gauge to be used as a DropWizard gauge.
|
FlinkHints |
Utility class for Flink hints.
|
FlinkHintStrategies |
A collection of Flink style HintStrategy s.
|
FlinkHistogramWrapper |
Wrapper to use a Flink Histogram as a Dropwizard Histogram .
|
FlinkHttpObjectAggregator |
Same as HttpObjectDecoder but
returns HTTP 413 to the client if the payload exceeds MessageAggregator.maxContentLength .
|
FlinkImageBuilder |
A builder class for constructing Docker image based on flink-dist.
|
FlinkJobNotFoundException |
Exception indicating that we could not find a Flink job with the given job ID.
|
FlinkJobTerminatedWithoutCancellationException |
Exception indicating that the Flink job with the given job ID has terminated without
cancellation.
|
FlinkJoinPushExpressionsRule |
Planner rule that pushes down expressions in "equal" join condition.
|
FlinkJoinReorderRule |
Flink join reorder rule, which can change the join order of input relNode tree.
|
FlinkJoinReorderRule.Config |
Rule configuration.
|
FlinkJoinToMultiJoinRule |
Flink Planner rule to flatten a tree of LogicalJoin s into a single MultiJoin with
N inputs.
|
FlinkJoinToMultiJoinRule.Config |
Rule configuration.
|
FlinkJoinType |
Join type for join.
|
FlinkJsonSchema |
Annotations for auto-generating a documentation of json payloads.
|
FlinkJsonSchema.AdditionalFields |
This allows documenting a class that supports setting dynamic properties of a certain type.
|
FlinkKubeClient |
The client to talk with kubernetes.
|
FlinkKubeClient.WatchCallbackHandler<T> |
Callback handler for kubernetes resources.
|
FlinkKubeClientFactory |
|
FlinkLimit0RemoveRule |
Planner rule that rewrites `limit 0` to empty Values .
|
FlinkLimit0RemoveRule.FlinkLimit0RemoveRuleConfig |
Rule configuration.
|
FlinkLogicalCalcRemoveRule |
Rule to remove trivial FlinkLogicalCalc .
|
FlinkMatchers |
Deprecated.
|
FlinkMemory |
Memory components which constitute the Total Flink Memory.
|
FlinkMemoryUtils<FM extends FlinkMemory> |
|
FlinkMetadata |
Contains the interfaces for several specified metadata of flink.
|
FlinkMetadata.ColumnInterval |
Metadata about the interval of given column from a specified relational expression.
|
FlinkMetadata.ColumnInterval.Handler |
Handler API.
|
FlinkMetadata.ColumnNullCount |
Metadata about the null count of given column from a specified relational expression.
|
FlinkMetadata.ColumnNullCount.Handler |
Handler API.
|
FlinkMetadata.ColumnOriginNullCount |
Origin null count, looking until source.
|
FlinkMetadata.ColumnOriginNullCount.Handler |
Handler API.
|
FlinkMetadata.FilteredColumnInterval |
Metadata about the interval of given column under the given filter argument from a specified
relational expression.
|
FlinkMetadata.FilteredColumnInterval.Handler |
Handler API.
|
FlinkMetadata.FlinkDistribution |
Metadata about how a relational expression is distributed.
|
FlinkMetadata.FlinkDistribution.Handler |
Handler API.
|
FlinkMetadata.ModifiedMonotonicity |
Metadata about the modified property of a RelNode.
|
FlinkMetadata.ModifiedMonotonicity.Handler |
Handler API.
|
FlinkMetadata.UniqueGroups |
Metadata about the (minimum) unique groups of the given columns from a specified relational
expression.
|
FlinkMetadata.UniqueGroups.Handler |
Handler API.
|
FlinkMetadata.UpsertKeys |
Metadata about which combinations of columns are upsert identifiers.
|
FlinkMetadata.UpsertKeys.Handler |
Handler API.
|
FlinkMetadata.WindowProperties |
Metadata about the window properties of a RelNode.
|
FlinkMetadata.WindowProperties.Handler |
Handler API.
|
FlinkMeterWrapper |
Wrapper to use a Flink Meter as a Dropwizard Meter .
|
FlinkMetricContainer |
Helper class for forwarding Python metrics to Java accumulators and metrics.
|
FlinkMetricContainer.FlinkDistributionGauge |
Flink Gauge for DistributionResult .
|
FlinkMetricContainer.FlinkGauge |
Flink Gauge for GaugeResult .
|
FlinkOSSFileSystem |
Implementation of the Flink FileSystem interface for Aliyun OSS.
|
FlinkParseException |
Exception which indicates that the parsing of command line arguments failed.
|
FlinkPipelineTranslationUtil |
|
FlinkPipelineTranslator |
|
FlinkPod |
A collection of variables that composes a JobManager/TaskManager Pod.
|
FlinkPod.Builder |
|
FlinkPreparingTableBase |
A Flink Prepare.AbstractPreparingTable implementation for the
purposes of the sql-to-rel conversion and planner.
|
FlinkProjectCalcMergeRule |
Extends calcite's ProjectMergeRule, modification: only merge the two neighbouring Project
and Calc if each non-deterministic RexNode of bottom Calc should appear
at most once in the project list of top Project .
|
FlinkProjectJoinTransposeRule |
Planner rule that pushes a Project past a Join by splitting the projection into a projection on top of each
child of the join.
|
FlinkProjectMergeRule |
Extends calcite's ProjectMergeRule, modification: only merge the two neighbouring Project s if each non-deterministic RexNode of bottom Project should appear at
most once in the project list of top Project .
|
FlinkRecomputeStatisticsProgram |
A FlinkOptimizeProgram that recompute statistics after partition pruning and filter push down.
|
FlinkRelBuilder |
|
FlinkRelMdCollation |
FlinkRelMdCollation supplies a default implementation of RelMetadataQuery.collations(org.apache.calcite.rel.RelNode) for the standard logical algebra.
|
FlinkRelMetadataQuery |
A RelMetadataQuery that defines extended metadata handler in Flink, e.g ColumnInterval,
ColumnNullCount.
|
FlinkRelUtil |
Utilities for RelNode .
|
FlinkResource |
Generic interface for interacting with Flink.
|
FlinkResourceFactory |
|
FlinkResourceSetup |
|
FlinkResourceSetup.FlinkResourceSetupBuilder |
|
FlinkResultSet |
ResultSet for flink jdbc driver.
|
FlinkResultSetMetaData |
|
FlinkReturnTypes |
Type inference in Flink.
|
FlinkRexBuilder |
A slim extension over a RexBuilder .
|
FlinkRuntimeException |
Base class of all Flink-specific unchecked exceptions.
|
FlinkRuntimeFilterProgram |
Planner program that tries to inject runtime filter for suitable join to improve join
performance.
|
FlinkS3FileSystem |
Implementation of the Flink FileSystem interface for S3.
|
FlinkS3FileSystem.S5CmdConfiguration |
POJO representing parameters to configure s5cmd.
|
FlinkS3PrestoFileSystem |
FlinkS3PrestoFileSystem provides custom recursive deletion functionality to work around a
bug in the internally used Presto file system.
|
FlinkSchema |
Base class for flink Schema , which provides some default implementations.
|
FlinkSecurityManager |
FlinkSecurityManager to control certain behaviors that can be captured by Java system
security manager.
|
FlinkSemiAntiJoinFilterTransposeRule |
Planner rule that pushes semi-join down in a tree past a Filter .
|
FlinkSemiAntiJoinJoinTransposeRule |
Planner rule that pushes a org.apache.calcite.rel.core.SemiJoin down in a tree past a
Join in order to trigger other rules that will convert
SemiJoin s.
|
FlinkSemiAntiJoinProjectTransposeRule |
Planner rule that pushes a org.apache.calcite.rel.core.SemiJoin down in a tree past a
Project .
|
FlinkSqlCallBinding |
Binding supports to rewrite the DEFAULT operator.
|
FlinkSqlConformance |
Sql conformance used for flink to set specific sql dialect parser
|
FlinkSqlNameMatcher |
A workaround for adjusting types of ROW nested fields.
|
FlinkSqlOperatorTable |
Operator table that contains only Flink-specific functions and operators.
|
FlinkSqlParserFactories |
A util method to create SqlParserImplFactory according to SqlConformance.
|
FlinkSqlParserImpl |
SQL parser, generated from Parser.jj by JavaCC.
|
FlinkSqlParserImplConstants |
|
FlinkSqlParserImplTokenManager |
|
FlinkStatement |
Statement for flink jdbc driver.
|
FlinkStreamPlanAnalyzers |
|
FlinkTimestampDynamicFunction |
Function that used to define SQL time functions like LOCALTIME, CURRENT_TIME(these are all
dynamic functions in Calcite's SqlStdOperatorTable ) in Flink, the difference from the
parent SqlAbstractTimeFunction is this function class be aware of whether it is used in
batch mode, if true it will act totally same as the parent SqlAbstractTimeFunction , but
will be a non-deterministic function if not in batch mode.
|
FlinkTimestampWithPrecisionDynamicFunction |
Function that used to define SQL time function like LOCALTIMESTAMP, CURRENT_TIMESTAMP, NOW() in
Flink, the function support configuring the return type and the * precision of return type.
|
FlinkTypeSystem |
Custom type system for Flink.
|
FlinkUserCodeClassLoader |
|
FlinkUserCodeClassLoaders |
Gives the URLClassLoader a nicer name for debugging purposes.
|
FlinkUserCodeClassLoaders.ParentFirstClassLoader |
Regular URLClassLoader that first loads from the parent and only after that from the URLs.
|
FlinkUserCodeClassLoaders.ResolveOrder |
|
FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader |
Ensures that holding a reference on the context class loader outliving the scope of user code
does not prevent the user classloader to be garbage collected (FLINK-16245).
|
FlinkVersion |
Enumeration for Flink versions.
|
FlinkYarnSessionCli |
Class handling the command line interface to the YARN session.
|
FlinkZooKeeperQuorumPeer |
Simple wrapper for ZooKeeper's QuorumPeer , which reads a ZooKeeper config file and writes
the required 'myid' file before starting the peer.
|
FloatColumnReader |
|
FloatColumnVector |
Float column vector.
|
FloatComparator |
|
FloatHashSet |
Float hash set.
|
FloatingBuffersUsageGauge |
Gauge metric measuring the floating buffers usage gauge for SingleInputGate s.
|
FloatParser |
Parses a text field into a Float .
|
FloatPrimitiveArrayComparator |
|
FloatPrimitiveArraySerializer |
A serializer for float arrays.
|
FloatPrimitiveArraySerializer.FloatPrimitiveArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
FloatSerializer |
Type serializer for Float .
|
FloatSerializer.FloatSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
FloatType |
Logical type of a 4-byte single precision floating point number.
|
FloatValue |
Boxed serializable and comparable single precision floating point type, representing the
primitive type float .
|
FloatValueComparator |
Specialized comparator for FloatValue based on CopyableValueComparator.
|
FloatValueParser |
|
FloatValueSerializer |
|
FloatValueSerializer.FloatValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
FloatWriter<T> |
|
FloatWriter.FloatWriterForArray |
|
FloatWriter.FloatWriterForRow |
|
ForceNullableTypeStrategy |
Forces a given type strategy to be nullable.
|
Format |
Base interface for connector formats.
|
FormatDescriptor |
|
FormatDescriptor.Builder |
|
FormatFactory |
|
Formatter |
Allows providing multiple formatters for the description.
|
ForStAggregatingState<K,N,IN,ACC,OUT> |
|
ForStConfigurableOptions |
This class contains the configuration options for the ForStStateBackend.
|
ForStDBBunchPutRequest<K,N,UK,UV> |
The Bunch Put access request for ForStDB.
|
ForStDBCachingPriorityQueueSet<E extends HeapPriorityQueueElement> |
A priority queue with set semantics, implemented on top of RocksDB.
|
ForStDBCachingPriorityQueueSet.OrderedByteArraySetCache |
Cache that is organized as an ordered set for byte-arrays.
|
ForStDBGetRequest<K,N,V,R> |
The Get access request for ForStDB.
|
ForStDBIterRequest<K,N,UK,UV,R> |
The abstract iterator access request for ForStDB.
|
ForStDBListGetRequest<K,N,V> |
The Get access request for ForStDB.
|
ForStDBMapCheckRequest<K,N,V> |
The Map#isEmpty() and Map#contains() request for ForStDB.
|
ForStDBMapEntryIterRequest<K,N,UK,UV> |
|
ForStDBMapKeyIterRequest<K,N,UK,UV> |
|
ForStDBMapValueIterRequest<K,N,UK,UV> |
|
ForStDBOperation |
Data access operation to ForStDB.
|
ForStDBPriorityQueueSetFactory |
Encapsulates the logic and resources in connection with creating priority queue state structures,
for RocksDB backend.
|
ForStDBPutRequest<K,N,V> |
The Put access request for ForStDB.
|
ForStDBSingleGetRequest<K,N,V> |
The Get access request for ForStDB.
|
ForStDBTtlCompactFiltersManager |
RocksDB compaction filter utils for state with TTL.
|
ForStDBWriteBatchWrapper |
It's a wrapper class around ForStDB's WriteBatch for writing in bulk.
|
ForStFlinkFileSystem |
A FileSystem delegates some requests to file system loaded by Flink FileSystem mechanism.
|
ForStGeneralMultiGetOperation |
The general-purpose multiGet operation implementation for ForStDB, which simulates multiGet by
calling the Get API multiple times with multiple threads.
|
ForStHeapTimersFullRestoreOperation<K> |
Encapsulates the process of restoring a ForStDB instance from a full snapshot.
|
ForStIncrementalRestoreOperation<K> |
Encapsulates the process of restoring a ForSt instance from an incremental snapshot.
|
ForStIncrementalSnapshotStrategy<K> |
Snapshot strategy for ForStKeyedStateBackend that is based
on disableFileDeletions()+getLiveFiles() of ForSt and creates incremental snapshots.
|
ForStInnerTable<K,N,V> |
The concept of an abstracted table oriented towards ForStDB, and each ForStInnerTable can be
mapped to a ForSt internal State.
|
ForStIterateOperation |
The iterate operation implementation for ForStDB, which leverages rocksdb's iterator directly.
|
ForStIteratorWrapper |
This class was originally a wrapper around RocksIterator to check the iterator status for
all the methods mentioned to require this check in the wiki documentation: seek, next,
seekToFirst, seekToLast, seekForPrev, and prev.
|
ForStKeyedStateBackend<K> |
A KeyedStateBackend that stores its state in ForSt .
|
ForStKeyedStateBackendBuilder<K> |
|
ForStListIterator<V> |
The forst implementation for list iterator.
|
ForStListState<K,N,V> |
|
ForStMapIterator<T> |
The map iterator implementation for ForStDB.
|
ForStMapState<K,N,UK,UV> |
|
ForStMemoryConfiguration |
The settings regarding ForSt memory usage.
|
ForStMemoryControllerUtils |
Utils to create Cache and WriteBufferManager which are used to control total
memory usage of ForSt.
|
ForStMemoryControllerUtils.ForStMemoryFactory |
Factory for Write Buffer Manager and Bock Cache.
|
ForStNativeFullSnapshotStrategy<K> |
Snapshot strategy for ForStKeyedStateBackend that is based
on disableFileDeletions()+getLiveFiles() of ForSt and creates full snapshots.
|
ForStNativeMetricMonitor |
A monitor which pulls {RocksDB } native metrics and forwards them to Flink's metric group.
|
ForStNativeMetricOptions |
Enable which ForSt metrics to forward to Flink's metrics reporter.
|
ForStNoneRestoreOperation |
Encapsulates the process of initiating a ForSt instance without restore.
|
ForStOperationUtils |
Utils for ForSt Operations.
|
ForStOperationUtils.ForStKvStateInfo |
ForSt specific information about the k/v states.
|
ForStOptions |
Configuration options for the ForStStateBackend.
|
ForStOptionsFactory |
A factory for DBOptions and ColumnFamilyOptions to be passed to the
ForStStateBackend.
|
ForStPriorityQueueConfig |
The configuration of rocksDB priority queue state implementation.
|
ForStProperty |
RocksDB properties that can be queried by Flink's metrics reporter.
|
ForStReducingState<K,N,V> |
|
ForStResourceContainer |
The container for ForSt resources, including option factory and shared resource among instances.
|
ForStRestoreOperation |
Interface for ForSt restore.
|
ForStRestoreResult |
Entity holding result of ForSt instance restore.
|
ForStSerializerUtils |
A utility of serialization keys in ForSt.
|
ForStSnapshotStrategyBase<K,R extends SnapshotResources> |
Abstract base class for SnapshotStrategy implementations for ForSt state backend.
|
ForStSnapshotStrategyBase.ForStNativeSnapshotResources |
|
ForStSnapshotStrategyBase.ForStSyncSnapshotResources |
|
ForStSnapshotStrategyBase.PreviousSnapshot |
Previous snapshot with uploaded sst files.
|
ForStSnapshotUtil |
Utility methods and constants around ForSt creating and restoring snapshots for ForStStateBackend .
|
ForStStateBackend |
|
ForStStateBackend.PriorityQueueStateType |
The options to chose for the type of priority queue state.
|
ForStStateBackendFactory |
|
ForStStateDataTransfer |
|
ForStStateExecutor |
|
ForStStateKeysAndNamespaceIterator<K,N> |
|
ForStStateKeysIterator<K> |
|
ForStStateRequestClassifier |
The ForSt StateRequestContainer which can classify the state requests by ForStDB
requestType (Get、Put or Iterator).
|
ForStSyncKeyedStateBackend<K> |
|
ForStSyncKeyedStateBackendBuilder<K> |
|
ForStValueState<K,N,V> |
|
ForStWriteBatchOperation |
The writeBatch operation implementation for ForStDB.
|
ForwardForConsecutiveHashPartitioner<T> |
If there are multiple consecutive and the same hash shuffles, SQL planner will change them except
the first one to use forward partitioner, so that these operators can be chained to reduce
unnecessary shuffles.
|
ForwardForUnspecifiedPartitioner<T> |
|
ForwardGroup |
A forward group is a set of job vertices connected via forward edges.
|
ForwardGroupComputeUtil |
Common utils for computing forward groups.
|
ForwardHashExchangeProcessor |
|
ForwardingInputStream |
Input stream, that wraps another input stream and forwards all method calls to the wrapped
stream.
|
ForwardingOutputStream |
OutputStream , that wraps another OutputStream and forwards all method calls to
the wrapped stream.
|
ForwardPartitioner<T> |
Partitioner that forwards elements only to the locally running downstream operation.
|
FractionalTypeInfo<T> |
Type information for numeric fractional primitive types (double, float).
|
FreeingBufferRecycler |
A simple buffer recycler that frees the memory segments.
|
FreeSlotFunction |
A function for freeing slots.
|
FreeSlotTracker |
Track all free slots.
|
FromClasspathEntryClassInformationProvider |
FromClasspathEntryClassInformationProvider assumes the passed job class being available
on some classpath.
|
FromDataSource<T> |
DataStream v2 source that emit data from pre-provided data.
|
FromElementsFunction<T> |
Deprecated.
|
FromElementsGeneratorFunction<OUT> |
A stream generator function that returns a sequence of elements.
|
FromElementsSource<OUT> |
|
FromElementsSource.ElementsSupplier<OUT> |
A supplier of elements that allows to get those from any offset at any time.
|
FromElementsSourceReader<T> |
|
FromElementsSplit |
|
FromElementsSplitSerializer |
|
FromIteratorFunction<T> |
Deprecated.
|
FromJarEntryClassInformationProvider |
FromJarEntryClassInformationProvider is used for cases where the Jar archive is
explicitly specified.
|
FromSplittableIteratorFunction<T> |
Deprecated.
|
FrontMetricGroup<P extends AbstractMetricGroup<?>> |
|
FsCheckpointMetadataOutputStream |
|
FsCheckpointStateToolset |
|
FsCheckpointStorageAccess |
An implementation of durable checkpoint storage to file systems.
|
FsCheckpointStorageLocation |
A storage location for checkpoints on a file system.
|
FsCheckpointStreamFactory |
|
FsCheckpointStreamFactory.FsCheckpointStateOutputStream |
|
FsCompletedCheckpointStorageLocation |
|
FSDataInputStream |
Interface for a data input stream to a file on a FileSystem .
|
FSDataInputStreamWrapper |
|
FSDataInputStreamWrapper |
Code copy pasted from org.apache.avro.mapred.FSInput (which is Apache licensed as well).
|
FSDataOutputStream |
An output stream to a file that is created via a FileSystem .
|
FSDataOutputStreamWrapper |
|
FSDataOutputStreamWrapper |
|
FsJobArchivist |
Utility class for writing an archive file to a FileSystem and reading it back.
|
FsMergingCheckpointStorageAccess |
An implementation of file merging checkpoint storage to file systems.
|
FsMergingCheckpointStorageLocation |
An implementation of checkpoint storage location for file merging checkpoints.
|
FsSegmentDataInputStream |
|
FsStateChangelogOptions |
|
FsStateChangelogStorage |
|
FsStateChangelogStorageFactory |
|
FsStateChangelogStorageForRecovery |
|
FullCachingLookupProvider |
A LookupFunctionProvider that never lookup in external system on cache miss and provides
a cache for holding all entries in the external system.
|
FullOuterJoinDriver<IT1,IT2,OT> |
The full outer join driver implements the logic of an outer join operator at runtime.
|
FullSnapshotAsyncWriter<K> |
|
FullSnapshotResources<K> |
|
FullSnapshotRestoreOperation<K> |
The procedure of restoring state from a savepoint written with the unified binary format.
|
FullSnapshotUtil |
|
FullyFinishedOperatorState |
A special operator state implementation representing the operators whose instances are all
finished.
|
Function |
The base interface for all user-defined functions.
|
FunctionAlreadyExistException |
Exception for trying to create a function that already exists.
|
FunctionCatalog |
|
FunctionCatalog.InlineCatalogFunction |
The CatalogFunction which holds an instantiated UDF.
|
FunctionCatalogOperatorTable |
|
FunctionContext |
A FunctionContext allows to obtain global runtime information about the context in which
the user-defined function is executed.
|
FunctionDefinition |
Definition of a function.
|
FunctionDefinitionConvertRule |
A call expression converter rule that converts calls to user defined functions.
|
FunctionDefinitionFactory |
|
FunctionDefinitionFactory.Context |
Context provided when a function definition is created.
|
FunctionDelegationHelper |
Delegating functions are used to create metadata on recovery when the
actual function code is not known yet.
|
FunctionHint |
|
FunctionHints |
|
FunctionIdentifier |
Identifies a system function with function name or a catalog function with a fully qualified
identifier.
|
FunctionInfo |
Info to describe the function.
|
FunctionInitializationContext |
This interface provides a context in which user functions can initialize by registering to
managed state (i.e. state that is managed by state backends).
|
FunctionKind |
|
FunctionLanguage |
|
FunctionLookup |
|
FunctionNotExistException |
Exception for trying to operate on a function that doesn't exist.
|
FunctionRequirement |
|
FunctionSnapshotContext |
This interface provides a context in which user functions that use managed state (i.e. state that
is managed by state backends) can participate in a snapshot.
|
FunctionSplitter |
Split long functions into several smaller functions.
|
FunctionUtils |
Utility class that contains helper methods to work with Flink Function class.
|
FunctionUtils |
Utility class for Flink's functions.
|
FunctionWithException<T,R,E extends Throwable> |
A functional interface for a Function that may throw exceptions.
|
FusionCodegenExecNode |
A ExecNode which support operator fusion codegen.
|
FusionStreamOperatorBase |
|
FutureCompletingBlockingQueue<T> |
A custom implementation of blocking queue in combination with a CompletableFuture that is
used in the hand-over of data from a producing thread to a consuming thread.
|
FutureConsumerWithException<T,E extends Throwable> |
|
FutureTaskWithException<V> |
|
FutureUtils |
|
FutureUtils.ConjunctFuture<T> |
A future that is complete once multiple other futures completed.
|
FutureUtils.RetryException |
|
GateBuffersSpec |
The buffer specs of the InputGate include exclusive buffers per channel, required/total
floating buffers and the target of total buffers.
|
GatedRateLimiter |
An implementation of RateLimiter that completes defined number of futures in-between the
external notification events.
|
GatewayController |
Controller for interacting with a SqlGateway.
|
GatewayInfo |
|
GatewayRetriever<T extends RpcGateway> |
|
Gauge<T> |
A Gauge is a Metric that calculates a specific value at a point in time.
|
GaugePeriodTimer |
|
GeneralWindowProcessFunction<K,W extends Window> |
|
GeneratedAggsHandleFunction |
|
GeneratedClass<T> |
|
GeneratedCollector<C extends Collector<?>> |
|
GeneratedFilterCondition |
|
GeneratedFunction<F extends Function> |
|
GeneratedHashFunction |
|
GeneratedInput<F extends InputFormat<?,?>> |
|
GeneratedJoinCondition |
|
GeneratedLogUrlHandler |
Handler for retrieving the log url of a specified TaskManager or JobManager.
|
GeneratedNamespaceAggsHandleFunction<N> |
|
GeneratedNamespaceTableAggsHandleFunction<N> |
|
GeneratedNormalizedKeyComputer |
|
GeneratedOperator<C extends StreamOperator<?>> |
|
GeneratedProjection |
|
GeneratedRecordComparator |
|
GeneratedRecordEqualiser |
|
GeneratedResultFuture<T extends ResultFuture<?>> |
|
GeneratedTableAggsHandleFunction |
|
GeneratedWatermarkGenerator |
|
GeneratedWatermarkGeneratorSupplier |
|
GeneratedWatermarkGeneratorSupplier.DefaultWatermarkGenerator |
|
GeneratingIteratorSourceReader<E,O,IterT extends Iterator<E>,SplitT extends IteratorSourceSplit<E,IterT>> |
|
GeneratorFunction<T,O> |
Base interface for data generator functions.
|
GenericArrayData |
An internal data structure representing data of ArrayType .
|
GenericArraySerializer<C> |
A serializer for arrays of objects.
|
GenericArraySerializerSnapshot<C> |
|
GenericCLI |
A generic implementation of the CustomCommandLine that only expects the execution.target
parameter to be explicitly specified and simply forwards the rest of the options specified with
-D to the corresponding PipelineExecutor for further parsing.
|
GenericCsvInputFormat<OT> |
|
GenericDataSinkBase<IN> |
Operator for nodes that act as data sinks, storing the data they receive.
|
GenericDataSourceBase<OUT,T extends InputFormat<OUT,?>> |
Abstract superclass for data sources in a Pact plan.
|
GenericDataSourceBase.SplitDataProperties<T> |
|
GenericInMemoryCatalog |
A generic catalog implementation that holds all meta objects in memory.
|
GenericInMemoryCatalogFactory |
|
GenericInMemoryCatalogFactoryOptions |
|
GenericInMemoryCatalogStore |
A generic catalog store implementation that store all catalog configuration in memory.
|
GenericInMemoryCatalogStoreFactory |
|
GenericInMemoryCatalogStoreFactoryOptions |
|
GenericInputFormat<OT> |
Generic base class for all Rich inputs that are not based on files.
|
GenericInputSplit |
A generic input split that has only a partition number.
|
GenericJobEventSerializer |
|
GenericKeyMetricGroup |
|
GenericMapData |
|
GenericMetricGroup |
A simple named MetricGroup that is used to hold subgroups of
metrics.
|
GenericPairComparator<T1,T2> |
|
GenericRecordAvroTypeInfo |
TypeInformation for GenericRecord .
|
GenericRowData |
An internal data structure representing data of RowType and other (possibly nested)
structured types such as StructuredType .
|
GenericRowDataKeySelector |
A KeySelector which will extract key from RowData.
|
GenericTypeComparator<T extends Comparable<T>> |
TypeComparator for all types that extend Comparable.
|
GenericTypeInfo<T> |
|
GenericTypeSerializerSnapshot<T,S extends TypeSerializer> |
|
GenericValueMetricGroup |
|
GenericWriteAheadSink<IN> |
Generic Sink that emits its input elements into an arbitrary backend.
|
GetApiVersionHandler |
Handler to get rest api version.
|
GetApiVersionHeaders |
Message headers for getting rest api version.
|
GetApiVersionResponseBody |
|
GetInfoHandler |
Handler to get cluster information.
|
GetInfoHeaders |
Message headers for getting cluster information.
|
GetInfoResponseBody |
|
GetOperationStatusHandler |
Handler to get the status of operation.
|
GetOperationStatusHeaders |
Message headers for getting the status of operation.
|
GetSessionConfigHandler |
Handler to get the session configuration.
|
GetSessionConfigHeaders |
Message headers for getting session configuration.
|
GetSessionConfigResponseBody |
|
GettingStartedExample |
Example for getting started with the Table & SQL API.
|
GettingStartedExample.AddressNormalizer |
We can put frequently used procedures in user-defined functions.
|
GivenJavaClasses |
Equivalent of ArchRuleDefinition.classes() and similar methods with a restriction on Java
classes.
|
GlobalAggCombiner |
An implementation of RecordsCombiner that accumulates local accumulators records into the
window accumulator state.
|
GlobalAggCombiner.Factory |
|
GlobalAggregateManager |
This interface gives access to transient, named, global aggregates.
|
GlobalCommitterOperator<CommT,GlobalCommT> |
Implements the GlobalCommitter .
|
GlobalCommitterTransform<CommT> |
Transformation for global committer.
|
GlobalCommitterTransformationTranslator<CommT> |
|
GlobalConfiguration |
Global configuration object for Flink.
|
GlobalFailureHandler |
An interface for handling global failures.
|
GloballyCleanableResource |
GloballyCleanableResource is supposed to be implemented by any class that provides
artifacts for a given job that need to be cleaned up after the job reached a global terminal
state.
|
GlobalPartitioner<T> |
Partitioner that sends all elements to the downstream operator with subtask ID=0.
|
GlobalRuntimeFilterBuilderOperator |
Global runtime filter builder operator.
|
GlobalStream<T> |
This interface represents a stream that force single parallelism.
|
GlobalStream.ProcessConfigurableAndGlobalStream<T> |
|
GlobalStream.TwoGlobalStreams<T1,T2> |
|
GlobalStreamExchangeMode |
|
GlobalStreamImpl<T> |
|
GlobalWindow |
The default window into which all data is placed (via GlobalWindows ).
|
GlobalWindow.Serializer |
|
GlobalWindow.Serializer.GlobalWindowSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
GlobalWindows |
|
GlobalWindows.EndOfStreamTrigger |
A trigger that fires iff the input stream reaches EndOfStream.
|
GlobalWindows.NeverTrigger |
A trigger that never fires, as default Trigger for GlobalWindows.
|
GlobFilePathFilter |
Class for determining if a particular file should be included or excluded based on a set of
include and exclude glob filters.
|
GPUDriverFactory |
Factory for creating GPUDriver .
|
GPUDriverOptions |
A collection of all configuration options for GPU driver.
|
GPUInfo |
Information for GPU resource.
|
GraphiteReporter |
This class acts as a factory for the GraphiteReporter and
allows using it as a Flink reporter.
|
GraphiteReporterFactory |
|
GroupAggFunction |
Aggregate Function used for the groupby (without window) aggregate.
|
GroupAggregationAnalyzer |
An implementation of PlanAnalyzer to analyze whether group aggregation can be optimized
to local-global two_phase aggregation by tuning table configurations.
|
GroupCache<G,K,V> |
|
GroupCombineFunction<IN,OUT> |
Generic interface used for combine functions ("combiners").
|
GroupCombineOperatorBase<IN,OUT,FT extends GroupCombineFunction<IN,OUT>> |
Base operator for the combineGroup transformation.
|
GroupedPartitionWriter<T> |
|
GroupedProcessingTimeWindowExample |
An example of grouped stream windowing into sliding time windows.
|
GroupedTable |
A table that has been grouped on a set of grouping keys.
|
GroupPattern<T,F extends T> |
Base class for a group pattern definition.
|
GroupReduceCombineDriver<IN,OUT> |
Non-chained combine driver which is used for a CombineGroup transformation or a GroupReduce
transformation where the user supplied a RichGroupReduceFunction with a combine method.
|
GroupReduceDriver<IT,OT> |
GroupReduce task which is executed by a Task Manager.
|
GroupReduceFunction<T,O> |
The interface for group reduce functions.
|
GroupReduceOperator<IN,OUT> |
|
GroupReduceOperatorBase<IN,OUT,FT extends GroupReduceFunction<IN,OUT>> |
|
GroupTableAggFunction |
Aggregate Function used for the groupby (without window) table aggregate.
|
GroupWindow |
A group window specification.
|
GroupWindowAssigner<W extends Window> |
|
GroupWindowedTable |
|
GrpcStateService |
An implementation of the Beam Fn State service.
|
GSBlobIdentifier |
An abstraction for the Google BlobId type.
|
GSBlobStorage |
Abstract blob storage, used to simplify interface to Google storage and make it mockable.
|
GSBlobStorage.BlobMetadata |
Abstract blob metadata.
|
GSBlobStorage.WriteChannel |
Abstract blob write channel.
|
GSBlobStorageImpl |
BlobStorage implementation for Google storage.
|
GSFileSystemFactory |
|
GSFileSystemOptions |
The GS file system options.
|
GSRecoverableWriter |
The recoverable writer implementation for Google storage.
|
GuavaFlinkConnectorRateLimiter |
|
GuavaRateLimiter |
An implementation of RateLimiter based on Guava's RateLimiter.
|
GzipInflaterInputStreamFactory |
Factory for input streams that decompress the GZIP compression format.
|
HadoopBlockLocation |
Implementation of the BlockLocation interface for the Hadoop Distributed File System.
|
HadoopCompressionBulkWriter<T> |
A BulkWriter implementation that writes data that have been compressed using Hadoop
CompressionCodec .
|
HadoopConfigLoader |
This class lazily loads hadoop configuration from resettable Flink's configuration.
|
HadoopConfMountDecorator |
Mount the custom Hadoop Configuration to the JobManager(s)/TaskManagers.
|
HadoopDataInputStream |
|
HadoopDataOutputStream |
|
HadoopDelegationTokenConverter |
Delegation token serializer and deserializer functionality.
|
HadoopDelegationTokenReceiver |
Hadoop delegation token receiver base class.
|
HadoopDependency |
Responsible telling if specific Hadoop dependencies are on classpath.
|
HadoopDummyProgressable |
This is a dummy progress.
|
HadoopDummyReporter |
This is a dummy progress monitor / reporter.
|
HadoopFileCommitter |
The committer publishes an intermediate Hadoop file to the target path after it finishes writing.
|
HadoopFileCommitterFactory |
|
HadoopFileStatus |
Concrete implementation of the FileStatus interface for the Hadoop Distributed File
System.
|
HadoopFileSystem |
|
HadoopFSDelegationTokenProvider |
Delegation token provider for Hadoop filesystems.
|
HadoopFSDelegationTokenReceiver |
Delegation token receiver for Hadoop filesystems.
|
HadoopFsFactory |
A file system factory for Hadoop-based file systems.
|
HadoopFsRecoverable |
An implementation of the resume and commit descriptor objects for Hadoop's/AzureBlob file system
abstraction.
|
HadoopInputFormat<K,V> |
Wrapper for using HadoopInputFormats (mapred-variant) with Flink.
|
HadoopInputFormat<K,V> |
InputFormat implementation allowing to use Hadoop (mapreduce) InputFormats with Flink.
|
HadoopInputFormatBase<K,V,T> |
Common base for Java and Scala API for using Hadoop input formats with Flink.
|
HadoopInputFormatBase<K,V,T> |
Base class shared between the Java and Scala API of Flink.
|
HadoopInputFormatCommonBase<T,SPITTYPE extends InputSplit> |
A common base for both "mapred" and "mapreduce" Hadoop input formats.
|
HadoopInputs |
HadoopInputs is a utility class to use Apache Hadoop InputFormats with Apache Flink.
|
HadoopInputSplit |
A wrapper that represents an input split from the Hadoop mapred API as a Flink InputSplit .
|
HadoopInputSplit |
A wrapper that represents an input split from the Hadoop mapreduce API as a Flink InputSplit .
|
HadoopMapFunction<KEYIN,VALUEIN,KEYOUT,VALUEOUT> |
This wrapper maps a Hadoop Mapper (mapred API) to a Flink FlatMapFunction.
|
HadoopModule |
Responsible for installing a Hadoop login user.
|
HadoopModuleFactory |
|
HadoopOutputCollector<KEY,VALUE> |
A Hadoop OutputCollector that wraps a Flink OutputCollector.
|
HadoopOutputFormat<K,V> |
Wrapper for using HadoopOutputFormats (mapred-variant) with Flink.
|
HadoopOutputFormat<K,V> |
OutputFormat implementation allowing to use Hadoop (mapreduce) OutputFormats with Flink.
|
HadoopOutputFormatBase<K,V,T> |
Common base for the mapred HadoopOutputFormat wrappers.
|
HadoopOutputFormatBase<K,V,T> |
Base class shared between the Java and Scala API of Flink.
|
HadoopOutputFormatCommonBase<T> |
A common base for both "mapred" and "mapreduce" Hadoop output formats.
|
HadoopPathBasedBulkFormatBuilder<IN,BucketID,T extends HadoopPathBasedBulkFormatBuilder<IN,BucketID,T>> |
|
HadoopPathBasedBulkWriter<T> |
Specialized BulkWriter which is expected to write to specified Path .
|
HadoopPathBasedBulkWriter.Factory<T> |
|
HadoopPathBasedPartFileWriter<IN,BucketID> |
The part-file writer that writes to the specified hadoop path.
|
HadoopPathBasedPartFileWriter.HadoopPathBasedBucketWriter<IN,BucketID> |
|
HadoopRecoverableWriter |
|
HadoopReducerWrappedFunction<KEYIN,VALUEIN,KEYOUT,VALUEOUT> |
This wrapper maps a Hadoop Reducer (mapred API) to a Flink window function.
|
HadoopRenameFileCommitter |
The Hadoop file committer that directly rename the in-progress file to the target file.
|
HadoopS3AccessHelper |
An implementation of the S3AccessHelper for the Hadoop S3A filesystem.
|
HadoopSecurityContext |
Hadoop security context which runs a Callable with the previously initialized UGI and appropriate
security credentials.
|
HadoopSecurityContextFactory |
|
HadoopTupleUnwrappingIterator<KEY,VALUE> |
Wraps a Flink Tuple2 (key-value-pair) iterator into an iterator over the second (value) field.
|
HadoopUserUtils |
Utility class for working with Hadoop user related classes.
|
HadoopUtils |
Utility class to work with Apache Hadoop MapRed classes.
|
HadoopUtils |
Utility class to work with next generation of Apache Hadoop MapReduce classes.
|
HadoopUtils |
Utility class to work with Apache Hadoop libraries.
|
HadoopUtils |
Utility class for working with Hadoop-related classes.
|
HaLeadershipControl |
Interface to grant and revoke leadership of HA components.
|
HandlerRedirectUtils |
Utilities to extract a redirect address.
|
HandlerRequest<R extends RequestBody> |
Simple container for the request to a handler, that contains the RequestBody and
path/query parameters.
|
HandlerRequestException |
|
HandlerRequestUtils |
|
HandlerUtils |
Utilities for the REST handlers.
|
HandshakeException |
Exception which signals a handshake failure.
|
HandshakeSuccessMessage |
Handshake success response.
|
Hardware |
Convenience class to extract hardware specifics of the computer executing the running JVM.
|
HardwareDescription |
A hardware description describes the resources available to a task manager.
|
HaServicesJobPersistenceComponentFactory |
|
HashBasedDataBuffer |
* A DataBuffer implementation which sorts all appended records only by subpartition
index.
|
HashBufferAccumulator |
|
HashFunction |
|
HashJoinIteratorBase |
Common methods for all Hash Join Iterators.
|
HashJoinOperator |
Hash join base operator.
|
HashJoinType |
Join type for hash table.
|
HashMapStateBackend |
This state backend holds the working state in the memory (JVM heap) of the TaskManagers and
checkpoints based on the configured CheckpointStorage .
|
HashMapStateBackendFactory |
|
HashMapWrapper |
Helper class to create a HashMap taking Numeric data as key or value from Python side.
|
HashPartition<BT,PT> |
|
HashPartition.BuildSideBuffer |
|
HashPartitionIterator<BT,PT> |
|
HashSubpartitionBufferAccumulator |
|
HashSubpartitionBufferAccumulatorContext |
|
HBaseDelegationTokenProvider |
Delegation token provider implementation for HBase.
|
HBaseDelegationTokenReceiver |
Delegation token receiver implementation for HBase.
|
HeaderlessChannelReaderInputView |
|
HeaderlessChannelWriterOutputView |
|
HeadlessClusterIPService |
The service type of Headless ClusterIP, which is an variant of ClusterIP.
|
HeapArrayVector |
This class represents a nullable heap array column vector.
|
HeapBooleanVector |
This class represents a nullable heap boolean column vector.
|
HeapBroadcastState<K,V> |
|
HeapBytesVector |
This class supports string and binary data by value reference -- i.e. each field is explicitly
present, as opposed to provided by a dictionary reference.
|
HeapByteVector |
This class represents a nullable byte column vector.
|
HeapDoubleVector |
This class represents a nullable double precision floating point column vector.
|
HeapFloatVector |
This class represents a nullable double precision floating point column vector.
|
HeapIntVector |
This class represents a nullable int column vector.
|
HeapKeyedStateBackend<K> |
|
HeapKeyedStateBackendBuilder<K> |
|
HeapKeyValueStateIterator |
|
HeapLongVector |
This class represents a nullable long column vector.
|
HeapMapVector |
This class represents a nullable heap map column vector.
|
HeapPriorityQueue<T extends HeapPriorityQueueElement> |
|
HeapPriorityQueue<T extends org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue.HeapPriorityQueueElement> |
|
HeapPriorityQueueElement |
|
HeapPriorityQueueSet<T extends HeapPriorityQueueElement> |
|
HeapPriorityQueueSetFactory |
|
HeapPriorityQueuesManager |
Manages creating heap priority queues along with their counterpart meta info.
|
HeapPriorityQueueSnapshotRestoreWrapper<T extends HeapPriorityQueueElement> |
This wrapper combines a HeapPriorityQueue with backend meta data.
|
HeapPriorityQueueStateSnapshot<T> |
|
HeapRestoreOperation<K> |
Implementation of heap restore operation.
|
HeapRowVector |
This class represents a nullable heap row column vector.
|
HeapSavepointRestoreOperation<K> |
Implementation of heap savepoint restore operation.
|
HeapShortVector |
This class represents a nullable short column vector.
|
HeapSort |
|
HeapTimestampVector |
This class represents a nullable byte column vector.
|
HeapWindowsGrouping |
A jvm heap implementation of WindowsGrouping , which uses a linked list to buffer all the
inputs of a keyed group belonging to the same window.
|
HeartbeatListener<I,O> |
|
HeartbeatManager<I,O> |
A heartbeat manager has to be able to start/stop monitoring a HeartbeatTarget , and report
heartbeat timeouts for this target.
|
HeartbeatManagerOptions |
The set of configuration options relating to heartbeat manager settings.
|
HeartbeatMonitor<O> |
Heartbeat monitor which manages the heartbeat state of the associated heartbeat target.
|
HeartbeatMonitor.Factory<O> |
|
HeartbeatReceiver<I> |
The receiver implementation of HeartbeatTarget , which mutes the HeartbeatTarget#requestHeartbeat(ResourceID, I) .
|
HeartbeatSender<I> |
The sender implementation of HeartbeatTarget , which mutes the HeartbeatTarget#receiveHeartbeat(ResourceID, I) .
|
HeartbeatServices |
HeartbeatServices gives access to all services needed for heartbeating.
|
HeartbeatServicesImpl |
|
HeartbeatTarget<I> |
Interface for components which can be sent heartbeats and from which one can request a heartbeat
response.
|
HeavyDeploymentStressTestProgram |
End-to-end test for heavy deployment descriptors.
|
HelpOperation |
Operation that represents HELP command.
|
HelpOperationParseStrategy |
|
HighAvailabilityMode |
High availability mode for Flink's cluster execution.
|
HighAvailabilityOptions |
The set of configuration options relating to high-availability settings.
|
HighAvailabilityServices |
The HighAvailabilityServices give access to all services needed for a highly-available setup.
|
HighAvailabilityServicesFactory |
|
HighAvailabilityServicesUtils |
|
HintFlag |
Three-valued flag for representing TRUE , FALSE , and UNKNOWN .
|
Histogram |
Histogram accumulator, which builds a histogram in a distributed manner.
|
Histogram |
Histogram interface to be used with Flink's metrics system.
|
HistogramStatistics |
Histogram statistics represent the current snapshot of elements recorded in the histogram.
|
HistoryServer |
The HistoryServer provides a WebInterface and REST API to retrieve information about finished
jobs for which the JobManager may have already shut down.
|
HistoryServerArchivist |
|
HistoryServerOptions |
The set of configuration options relating to the HistoryServer.
|
HistoryServerStaticFileServerHandler |
Simple file server handler used by the HistoryServer that serves requests to web
frontend's static files, such as HTML, CSS, JS or JSON files.
|
HistoryServerUtils |
Utility class for the HistoryServer.
|
HiveAggDecimalPlusTypeStrategy |
Type strategy that returns the result type of a decimal addition, used internally for
implementing native SUM/AVG aggregations on a Decimal type.
|
HiveOrcBatchWrapper |
Wrap VectorizedRowBatch hive orc batch.
|
HllBuffer |
Buffer used by HyperLogLogPlusPlus and ApproximateCountDistinct.
|
HoppingWindowSpec |
Logical representation of a hopping window specification.
|
HtmlFormatter |
Formatter that transforms Description into Html representation.
|
HttpHeader |
Represents an HTTP header with a name and a value.
|
HttpMethodWrapper |
This class wraps netty's HttpMethod s into an enum, allowing us to use them in switches.
|
HttpRequestHandler |
Simple code which handles all HTTP requests from the user, and passes them to the Router handler
directly if they do not involve file upload requests.
|
HybridSource<T> |
Hybrid source that switches underlying sources based on configured source chain.
|
HybridSource.HybridSourceBuilder<T,EnumT extends SplitEnumerator> |
Builder for HybridSource.
|
HybridSource.SourceFactory<T,SourceT extends Source<T,?,?>,FromEnumT extends SplitEnumerator> |
|
HybridSource.SourceSwitchContext<EnumT> |
Context provided to source factory.
|
HybridSourceEnumeratorState |
The state of hybrid source enumerator.
|
HybridSourceEnumeratorStateSerializer |
|
HybridSourceReader<T> |
Hybrid source reader that delegates to the actual source reader.
|
HybridSourceSplit |
Source split that wraps the actual split type.
|
HybridSourceSplitEnumerator |
Wraps the actual split enumerators and facilitates source switching.
|
HybridSourceSplitSerializer |
Serializes splits by delegating to the source-indexed underlying split serializer.
|
HyperLogLogPlusPlus |
The implement of HyperLogLogPlusPlus is inspired from Apache Spark.
|
ICloseableRegistry |
This class allows to register instances of Closeable , which are all closed if this
registry is closed.
|
IdenticalFileCompactor |
|
IdentifierSnapshotNamespace |
A namespace for the statement with FOR SYSTEM_TIME AS OF TIMESTAMP clause.
|
IdentityConverter<I> |
No-op converter that just forwards its input.
|
IdPartitioner |
Partitioner that partitions by id.
|
IFileSystem |
Interface of all file systems used by Flink.
|
IfNullFunction |
|
IgnoreShutdownRejectedExecutionHandler |
Rejected executions are ignored or logged in debug if the executor is shutdown .
|
IllegalConfigurationException |
An IllegalConfigurationException is thrown when the values in a given Configuration are not valid.
|
IllegalExecutionStateException |
|
IllegalRedistributionModeException |
|
ImageBuildException |
Exception indicating errors when building Flink image.
|
ImmutableAggregatingState<IN,OUT> |
|
ImmutableBatchPhysicalConstantTableFunctionScanRule |
|
ImmutableBatchPhysicalConstantTableFunctionScanRule.BatchPhysicalConstantTableFunctionScanRuleConfig |
|
ImmutableBatchPhysicalConstantTableFunctionScanRule.BatchPhysicalConstantTableFunctionScanRuleConfig.Builder |
|
ImmutableConstantRankNumberColumnRemoveRule |
ImmutableConstantRankNumberColumnRemoveRule contains immutable implementation classes generated from
abstract value types defined as nested inside ConstantRankNumberColumnRemoveRule .
|
ImmutableConstantRankNumberColumnRemoveRule.ConstantRankNumberColumnRemoveRuleConfig |
|
ImmutableConstantRankNumberColumnRemoveRule.ConstantRankNumberColumnRemoveRuleConfig.Builder |
|
ImmutableCorrelateSortToRankRule |
ImmutableCorrelateSortToRankRule contains immutable implementation classes generated from
abstract value types defined as nested inside CorrelateSortToRankRule .
|
ImmutableCorrelateSortToRankRule.CorrelateSortToRankRuleConfig |
|
ImmutableCorrelateSortToRankRule.CorrelateSortToRankRuleConfig.Builder |
|
ImmutableEnumerableToLogicalTableScan |
ImmutableEnumerableToLogicalTableScan contains immutable implementation classes generated from
abstract value types defined as nested inside EnumerableToLogicalTableScan .
|
ImmutableEnumerableToLogicalTableScan.EnumerableToLogicalTableScanConfig |
|
ImmutableEnumerableToLogicalTableScan.EnumerableToLogicalTableScanConfig.Builder |
|
ImmutableEventTimeTemporalJoinRewriteRule |
ImmutableEventTimeTemporalJoinRewriteRule contains immutable implementation classes generated from
abstract value types defined as nested inside EventTimeTemporalJoinRewriteRule .
|
ImmutableEventTimeTemporalJoinRewriteRule.Config |
|
ImmutableEventTimeTemporalJoinRewriteRule.Config.Builder |
Builds instances of type Config .
|
ImmutableFlinkBushyJoinReorderRule |
ImmutableFlinkBushyJoinReorderRule contains immutable implementation classes generated from
abstract value types defined as nested inside FlinkBushyJoinReorderRule .
|
ImmutableFlinkBushyJoinReorderRule.Config |
|
ImmutableFlinkBushyJoinReorderRule.Config.Builder |
Builds instances of type Config .
|
ImmutableFlinkCalcMergeRule |
ImmutableFlinkCalcMergeRule contains immutable implementation classes generated from
abstract value types defined as nested inside FlinkCalcMergeRule .
|
ImmutableFlinkCalcMergeRule.FlinkCalcMergeRuleConfig |
|
ImmutableFlinkCalcMergeRule.FlinkCalcMergeRuleConfig.Builder |
|
ImmutableFlinkFilterIntoJoinRuleConfig |
|
ImmutableFlinkFilterIntoJoinRuleConfig.Builder |
|
ImmutableFlinkFilterJoinRuleConfig |
|
ImmutableFlinkFilterJoinRuleConfig.Builder |
|
ImmutableFlinkJoinReorderRule |
ImmutableFlinkJoinReorderRule contains immutable implementation classes generated from
abstract value types defined as nested inside FlinkJoinReorderRule .
|
ImmutableFlinkJoinReorderRule.Config |
|
ImmutableFlinkJoinReorderRule.Config.Builder |
Builds instances of type Config .
|
ImmutableFlinkJoinToMultiJoinRule |
ImmutableFlinkJoinToMultiJoinRule contains immutable implementation classes generated from
abstract value types defined as nested inside FlinkJoinToMultiJoinRule .
|
ImmutableFlinkJoinToMultiJoinRule.Config |
|
ImmutableFlinkJoinToMultiJoinRule.Config.Builder |
Builds instances of type Config .
|
ImmutableFlinkLimit0RemoveRule |
ImmutableFlinkLimit0RemoveRule contains immutable implementation classes generated from
abstract value types defined as nested inside FlinkLimit0RemoveRule .
|
ImmutableFlinkLimit0RemoveRule.FlinkLimit0RemoveRuleConfig |
|
ImmutableFlinkLimit0RemoveRule.FlinkLimit0RemoveRuleConfig.Builder |
|
ImmutableJoinConditionTypeCoerceRule |
ImmutableJoinConditionTypeCoerceRule contains immutable implementation classes generated from
abstract value types defined as nested inside JoinConditionTypeCoerceRule .
|
ImmutableJoinConditionTypeCoerceRule.JoinConditionTypeCoerceRuleConfig |
|
ImmutableJoinConditionTypeCoerceRule.JoinConditionTypeCoerceRuleConfig.Builder |
|
ImmutableJoinTableFunctionScanToCorrelateRule |
ImmutableJoinTableFunctionScanToCorrelateRule contains immutable implementation classes generated from
abstract value types defined as nested inside JoinTableFunctionScanToCorrelateRule .
|
ImmutableJoinTableFunctionScanToCorrelateRule.Config |
|
ImmutableJoinTableFunctionScanToCorrelateRule.Config.Builder |
Builds instances of type Config .
|
ImmutableListState<V> |
A read-only ListState that does not allow for modifications.
|
ImmutableLogicalUnnestRule |
ImmutableLogicalUnnestRule contains immutable implementation classes generated from
abstract value types defined as nested inside LogicalUnnestRule .
|
ImmutableLogicalUnnestRule.LogicalUnnestRuleConfig |
|
ImmutableLogicalUnnestRule.LogicalUnnestRuleConfig.Builder |
|
ImmutableMapState<K,V> |
A read-only MapState that does not allow for modifications.
|
ImmutableProjectSnapshotTransposeRule |
ImmutableProjectSnapshotTransposeRule contains immutable implementation classes generated from
abstract value types defined as nested inside ProjectSnapshotTransposeRule .
|
ImmutableProjectSnapshotTransposeRule.Config |
|
ImmutableProjectSnapshotTransposeRule.Config.Builder |
Builds instances of type Config .
|
ImmutablePushCalcPastChangelogNormalizeRule |
ImmutablePushCalcPastChangelogNormalizeRule contains immutable implementation classes generated from
abstract value types defined as nested inside PushCalcPastChangelogNormalizeRule .
|
ImmutablePushCalcPastChangelogNormalizeRule.Config |
|
ImmutablePushCalcPastChangelogNormalizeRule.Config.Builder |
Builds instances of type Config .
|
ImmutablePushFilterIntoLegacyTableSourceScanRule |
|
ImmutablePushFilterIntoLegacyTableSourceScanRule.PushFilterIntoLegacyTableSourceScanRuleConfig |
|
ImmutablePushFilterIntoLegacyTableSourceScanRule.PushFilterIntoLegacyTableSourceScanRuleConfig.Builder |
|
ImmutablePushLimitIntoLegacyTableSourceScanRule |
ImmutablePushLimitIntoLegacyTableSourceScanRule contains immutable implementation classes generated from
abstract value types defined as nested inside PushLimitIntoLegacyTableSourceScanRule .
|
ImmutablePushLimitIntoLegacyTableSourceScanRule.PushLimitIntoLegacyTableSourceScanRuleConfig |
|
ImmutablePushLimitIntoLegacyTableSourceScanRule.PushLimitIntoLegacyTableSourceScanRuleConfig.Builder |
|
ImmutablePushProjectIntoTableSourceScanRule |
ImmutablePushProjectIntoTableSourceScanRule contains immutable implementation classes generated from
abstract value types defined as nested inside PushProjectIntoTableSourceScanRule .
|
ImmutablePushProjectIntoTableSourceScanRule.Config |
|
ImmutablePushProjectIntoTableSourceScanRule.Config.Builder |
Builds instances of type Config .
|
ImmutableReducingState<V> |
|
ImmutableRemoveUnreachableCoalesceArgumentsRule |
ImmutableRemoveUnreachableCoalesceArgumentsRule contains immutable implementation classes generated from
abstract value types defined as nested inside RemoveUnreachableCoalesceArgumentsRule .
|
ImmutableRemoveUnreachableCoalesceArgumentsRule.Config |
|
ImmutableRemoveUnreachableCoalesceArgumentsRule.Config.Builder |
Builds instances of type Config .
|
ImmutableReplaceIntersectWithSemiJoinRule |
ImmutableReplaceIntersectWithSemiJoinRule contains immutable implementation classes generated from
abstract value types defined as nested inside ReplaceIntersectWithSemiJoinRule .
|
ImmutableReplaceIntersectWithSemiJoinRule.ReplaceIntersectWithSemiJoinRuleConfig |
|
ImmutableReplaceIntersectWithSemiJoinRule.ReplaceIntersectWithSemiJoinRuleConfig.Builder |
|
ImmutableReplaceMinusWithAntiJoinRule |
ImmutableReplaceMinusWithAntiJoinRule contains immutable implementation classes generated from
abstract value types defined as nested inside ReplaceMinusWithAntiJoinRule .
|
ImmutableReplaceMinusWithAntiJoinRule.ReplaceMinusWithAntiJoinRuleConfig |
|
ImmutableReplaceMinusWithAntiJoinRule.ReplaceMinusWithAntiJoinRuleConfig.Builder |
|
ImmutableRewriteMinusAllRule |
ImmutableRewriteMinusAllRule contains immutable implementation classes generated from
abstract value types defined as nested inside RewriteMinusAllRule .
|
ImmutableRewriteMinusAllRule.RewriteMinusAllRuleConfig |
|
ImmutableRewriteMinusAllRule.RewriteMinusAllRuleConfig.Builder |
|
ImmutableRewriteMultiJoinConditionRule |
ImmutableRewriteMultiJoinConditionRule contains immutable implementation classes generated from
abstract value types defined as nested inside RewriteMultiJoinConditionRule .
|
ImmutableRewriteMultiJoinConditionRule.RewriteMultiJoinConditionRuleConfig |
|
ImmutableRewriteMultiJoinConditionRule.RewriteMultiJoinConditionRuleConfig.Builder |
|
ImmutableSimplifyJoinConditionRule |
ImmutableSimplifyJoinConditionRule contains immutable implementation classes generated from
abstract value types defined as nested inside SimplifyJoinConditionRule .
|
ImmutableSimplifyJoinConditionRule.SimplifyJoinConditionRuleConfig |
|
ImmutableSimplifyJoinConditionRule.SimplifyJoinConditionRuleConfig.Builder |
|
ImmutableSplitPythonConditionFromCorrelateRule |
ImmutableSplitPythonConditionFromCorrelateRule contains immutable implementation classes generated from
abstract value types defined as nested inside SplitPythonConditionFromCorrelateRule .
|
ImmutableSplitPythonConditionFromCorrelateRule.SplitPythonConditionFromCorrelateRuleConfig |
|
ImmutableSplitPythonConditionFromCorrelateRule.SplitPythonConditionFromCorrelateRuleConfig.Builder |
|
ImmutableStreamPhysicalConstantTableFunctionScanRule |
|
ImmutableStreamPhysicalConstantTableFunctionScanRule.StreamPhysicalConstantTableFunctionScanRuleConfig |
|
ImmutableStreamPhysicalConstantTableFunctionScanRule.StreamPhysicalConstantTableFunctionScanRuleConfig.Builder |
|
ImmutableTemporalJoinRewriteWithUniqueKeyRule |
ImmutableTemporalJoinRewriteWithUniqueKeyRule contains immutable implementation classes generated from
abstract value types defined as nested inside TemporalJoinRewriteWithUniqueKeyRule .
|
ImmutableTemporalJoinRewriteWithUniqueKeyRule.TemporalJoinRewriteWithUniqueKeyRuleConfig |
|
ImmutableTemporalJoinRewriteWithUniqueKeyRule.TemporalJoinRewriteWithUniqueKeyRuleConfig.Builder |
|
ImmutableTwoStageOptimizedAggregateRule |
ImmutableTwoStageOptimizedAggregateRule contains immutable implementation classes generated from
abstract value types defined as nested inside TwoStageOptimizedAggregateRule .
|
ImmutableTwoStageOptimizedAggregateRule.TwoStageOptimizedAggregateRuleConfig |
|
ImmutableTwoStageOptimizedAggregateRule.TwoStageOptimizedAggregateRuleConfig.Builder |
|
ImmutableUncollectToTableFunctionScanRule |
ImmutableUncollectToTableFunctionScanRule contains immutable implementation classes generated from
abstract value types defined as nested inside UncollectToTableFunctionScanRule .
|
ImmutableUncollectToTableFunctionScanRule.UncollectToTableFunctionScanRuleConfig |
|
ImmutableUncollectToTableFunctionScanRule.UncollectToTableFunctionScanRuleConfig.Builder |
|
ImmutableValueState<V> |
A read-only ValueState that does not allow for modifications.
|
ImmutableWatermarkAssignerChangelogNormalizeTransposeRule |
|
ImmutableWatermarkAssignerChangelogNormalizeTransposeRule.Config |
|
ImmutableWatermarkAssignerChangelogNormalizeTransposeRule.Config.Builder |
Builds instances of type Config .
|
ImmutableWrapJsonAggFunctionArgumentsRule |
ImmutableWrapJsonAggFunctionArgumentsRule contains immutable implementation classes generated from
abstract value types defined as nested inside WrapJsonAggFunctionArgumentsRule .
|
ImmutableWrapJsonAggFunctionArgumentsRule.Config |
|
ImmutableWrapJsonAggFunctionArgumentsRule.Config.Builder |
Builds instances of type Config .
|
ImperativeAggregateFunction<T,ACC> |
|
ImportOptions |
Provide the most used ImportOption .
|
ImportOptions.ExcludeScalaImportOption |
Excludes Scala classes on a best-effort basis.
|
ImportOptions.ExcludeShadedImportOption |
Exclude locations that look shaded.
|
ImportOptions.MavenMainClassesOnly |
Only import class files residing in maven main classes target directory.
|
InboundChannelHandlerFactory |
Custom netty inbound handler factory in order to make custom changes on netty inbound data.
|
IncompleteFuturesTracker |
This tracker remembers CompletableFutures as long as they are incomplete and allows us to fail
them later.
|
IncrementalDelayRetryStrategy |
An implementation of RetryStrategy that retries at an incremental delay with a cap.
|
IncrementalKeyedStateHandle |
|
IncrementalKeyedStateHandle.HandleAndLocalPath |
A Holder of StreamStateHandle and the corresponding localPath.
|
IncrementalLocalKeyedStateHandle |
|
IncrementalRemoteKeyedStateHandle |
The handle to states of an incremental snapshot.
|
IndexArgumentTypeStrategy |
|
IndexedCombinedWatermarkStatus |
Represents combined value and status of a watermark for a set number of input partial watermarks.
|
IndexedInputGate |
|
IndexedSortable |
|
IndexedSorter |
|
IndexLookupGeneratorFunction<OUT> |
A stream generator function that returns elements from the collection based on their index.
|
IndexRange |
This class represents the range of index.
|
InflaterInputStreamFactory<T extends InputStream> |
|
InflightDataRescalingDescriptor |
Captures ambiguous mappings of old channels to new channels for a particular gate or partition.
|
InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor |
Captures ambiguous mappings of old channels to new channels.
|
InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor.MappingType |
Type of mapping which should be used for this in-flight data.
|
InfluxdbReporter |
|
InfluxdbReporterFactory |
|
InfluxdbReporterOptions |
|
InfluxdbReporterOptions.Scheme |
|
InfoMessage |
Abstract base interface of all info messages exchanged between the JobManager an for example the
runtime monitor.
|
IngestionTimeAssigner<T> |
A timestamp assigner that assigns timestamps based on the machine's wall clock.
|
InitContext |
|
InitializationStatus |
Status of the initialization.
|
InitializationTypeConflictException |
|
InitializeOnMaster |
This interface may be implemented by OutputFormat s to have the master initialize them
globally.
|
InitJobManagerDecorator |
An initializer for the JobManager FlinkPod .
|
InitTaskManagerDecorator |
An initializer for the TaskManager FlinkPod .
|
InjectClusterClient |
|
InlineElement |
Part of description that represents an element inside a block e.g. a link.
|
InMemoryChangelogStateHandle |
|
InMemoryPartition<T> |
|
InMemorySorter<T> |
|
InMemorySorterFactory<T> |
|
InMemoryStateChangelogStorage |
|
InMemoryStateChangelogStorageFactory |
|
InnerJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> |
|
InnerPayLoadAvro |
|
InnerPayLoadAvro.Builder |
RecordBuilder for InnerPayLoadAvro instances.
|
InPlaceMutableHashTable<T> |
This hash table supports updating elements.
|
InProgressFileWriter<IN,BucketID> |
|
InProgressFileWriter.InProgressFileRecoverable |
A handle can be used to recover in-progress file..
|
InProgressFileWriter.PendingFileRecoverable |
The handle can be used to recover pending file.
|
Input<IN> |
|
InputBase |
|
InputBuffersGauge |
Gauge metric measuring the number of queued input buffers for SingleInputGate s.
|
InputBuffersSizeGauge |
Gauge metric measuring the size in bytes of queued input buffers for SingleInputGate s.
|
InputChannel |
|
InputChannel.BufferAndAvailability |
A combination of a Buffer and a flag indicating availability of further buffers, and
the backlog length indicating how many non-event buffers are available in the subpartitions.
|
InputChannelID |
Identifier for input channels.
|
InputChannelInfo |
|
InputChannelMetrics |
|
InputChannelStateHandle |
|
InputConsumableDecider |
InputConsumableDecider is responsible for determining whether the input of an
executionVertex or a consumed partition group is consumable.
|
InputConsumableDecider.Factory |
|
InputConversionOperator<E> |
Operator that converts to internal data structures and wraps atomic records if necessary.
|
InputFormat<OT,T extends InputSplit> |
The base interface for data sources that produces records.
|
InputFormatBasedReader<T> |
|
InputFormatBasedReader.Factory<T> |
|
InputFormatCacheLoader |
|
InputFormatOperatorFactory<OUT> |
Input format source operator factory.
|
InputFormatProvider |
|
InputFormatSourceFunction<OUT> |
Deprecated.
|
InputFormatTableSource<T> |
Deprecated.
|
InputGate |
An input gate consumes one or more partitions of a single produced intermediate result.
|
InputGate.InputWithData<INPUT,DATA> |
Simple pojo for INPUT, DATA and moreAvailable.
|
InputGateDeploymentDescriptor |
Deployment descriptor for a single input gate instance.
|
InputGateID |
|
InputGateMetrics |
Collects metrics of an input gate.
|
InputGateSpecUtils |
|
InputGateUtil |
Utility for dealing with input gates.
|
InputGateWithMetrics |
This class wraps InputGate provided by shuffle service and it is mainly used for
increasing general input metrics from TaskIOMetricGroup .
|
InputGroup |
A list of commonly used pre-defined groups of similar types for accepting more than just one data
type as an input argument in DataTypeHint s.
|
InputOrderCalculator |
|
InputOutputFormatContainer |
|
InputOutputFormatContainer.FormatUserCodeTable |
|
InputOutputFormatVertex |
A task vertex that runs an initialization and a finalization on the master.
|
InputPriorityConflictResolver |
|
InputPriorityGraphGenerator |
This class contains algorithm to detect and resolve input priority conflict in an ExecNode graph.
|
InputProcessorUtil |
|
InputProperty |
|
InputProperty.Builder |
|
InputProperty.DamBehavior |
Enumeration which describes how an input record may trigger the output behavior of the target
ExecNode .
|
InputProperty.DistributionType |
Enumeration which describes the type of the input data distribution.
|
InputProperty.HashDistribution |
The input will read the records whose keys hash to a particular hash value.
|
InputProperty.KeepInputAsIsDistribution |
A special distribution which indicators the data distribution is the same as its input. '
|
InputProperty.RequiredDistribution |
The required input data distribution for records when they are read in.
|
InputSelectable |
Interface for stream operators that can select the input to get StreamRecord .
|
InputSelection |
Describe the input selection that stream operators want to read records.
|
InputSelection.Builder |
|
InputSelectionHandler |
|
InputSelectionSpec |
Describe the inputId and read order of MultipleInput operator.
|
InputSideHasNoUniqueKeyBundle |
For the case that input has no uniqueKey.
|
InputSideHasUniqueKeyBundle |
For the case that input has uniqueKey which is not contained by joinKey.
|
InputsLocationsRetriever |
|
InputSortedExecNode<T> |
A BatchExecNode which does not sort the input data within the operator, but requires the
input data is already sorted.
|
InputSpec |
Describe the info of Input .
|
InputSplit |
This interface must be implemented by all kind of input splits that can be assigned to input
formats.
|
InputSplitAssigner |
An input split assigner distributes the InputSplit s among the instances on which a data
source exists.
|
InputSplitCacheLoadTask |
|
InputSplitProvider |
An input split provider can be successively queried to provide a series of InputSplit
objects a task is supposed to consume in the course of its execution.
|
InputSplitProviderException |
|
InputSplitSource<T extends InputSplit> |
|
InputStatus |
An InputStatus indicates the availability of data from an asynchronous input.
|
InputStreamFSInputWrapper |
|
InputTypeConfigurable |
OutputFormat s can implement this interface to be
configured with the data type they will operate on.
|
InputTypeStrategies |
Strategies for inferring and validating input arguments in a function call.
|
InputTypeStrategy |
Strategy for inferring and validating input arguments in a function call.
|
InputViewIterator<E> |
|
InsensitiveOverFrame |
The insensitive window frame calculates the statements which shouldn't care the window frame, for
example RANK/DENSE_RANK/PERCENT_RANK/NTILE/ROW_NUMBER.
|
InstanceID |
Class for statistically unique instance IDs.
|
InstantComparator |
Comparator for comparing Java Instant.
|
InstantiationUtil |
Utility class to create instances from class objects and checking failure reasons.
|
InstantiationUtil.ClassLoaderObjectInputStream |
A custom ObjectInputStream that can load classes using a specific ClassLoader.
|
InstantiationUtil.FailureTolerantObjectInputStream |
|
InstantSerializer |
Serializer for serializing/deserializing Instant values including null values.
|
InstantSerializer.InstantSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
IntArrayList |
Minimal implementation of an array-backed list of ints
|
IntColumnReader |
|
IntColumnVector |
Int column vector.
|
IntComparator |
|
IntCounter |
An accumulator that sums up Integer values.
|
IntegerResourceVersion |
|
IntegerTypeInfo<T> |
Type information for numeric integer primitive types: int, long, byte, short, character.
|
IntermediateDataSet |
An intermediate data set is the data set produced by an operator - either a source or any
intermediate operation.
|
IntermediateDataSetID |
|
IntermediateResult |
|
IntermediateResultInfo |
|
IntermediateResultPartition |
|
IntermediateResultPartitionID |
|
Internal |
Annotation to mark methods within stable, public APIs as an internal developer API.
|
InternalAggregateProcessAllWindowFunction<T,ACC,V,R,W extends Window> |
|
InternalAggregateProcessWindowFunction<T,ACC,V,R,K,W extends Window> |
|
InternalAggregatingState<K,N,IN,SV,OUT> |
|
InternalAggregatingState<K,N,IN,ACC,OUT> |
This class defines the internal interface for aggregating state.
|
InternalAppendingState<K,N,IN,SV,OUT> |
|
InternalAppendingState<K,N,IN,SV,OUT,SYNCOUT> |
This class defines the internal interface for appending state.
|
InternalCacheMetricGroup |
A CacheMetricGroup which register all cache related metrics under a subgroup of the
parent metric group.
|
InternalCheckpointListener |
|
InternalConfigOptions |
This class holds internal configuration constants used by Flink's table module.
|
InternalDataStreamQueryOperation<E> |
Deprecated. |
InternalExecutionGraphAccessor |
This interface encapsulates all methods needed by ExecutionJobVertex / ExecutionVertices /
Execution from the DefaultExecutionGraph.
|
InternalFailuresListener |
This interface enables subscribing to failures that are detected from the JobMaster side (e.g.,
from within the ExecutionGraph ).
|
InternalFunctionDefinitions |
Dictionary of function definitions for all internal used functions.
|
InternalIterableAllWindowFunction<IN,OUT,W extends Window> |
Internal window function for wrapping an AllWindowFunction that takes an Iterable
when the window state also is an Iterable .
|
InternalIterableProcessAllWindowFunction<IN,OUT,W extends Window> |
Internal window function for wrapping a ProcessAllWindowFunction that takes an
Iterable when the window state also is an Iterable .
|
InternalIterableProcessWindowFunction<IN,OUT,KEY,W extends Window> |
Internal window function for wrapping a ProcessWindowFunction that takes an
Iterable when the window state also is an Iterable .
|
InternalIterableWindowFunction<IN,OUT,KEY,W extends Window> |
Internal window function for wrapping a WindowFunction that takes an Iterable
when the window state also is an Iterable .
|
InternalKeyContext<K> |
This interface is the current context of a keyed state.
|
InternalKeyContextImpl<K> |
|
InternalKeyedState<K,N,V> |
This class defines the internal interface for all keyed state.
|
InternalKvState<K,N,V> |
The InternalKvState is the root of the internal state type hierarchy, similar to the
State being the root of the public API state hierarchy.
|
InternalKvState.StateIncrementalVisitor<K,N,V> |
The state entry visitor which supports remove and update of the last returned entries.
|
InternalListState<K,N,T> |
The peer to the ListState in the internal state type hierarchy.
|
InternalListState<K,N,V> |
This class defines the internal interface for list state.
|
InternalMapState<K,N,UK,UV> |
The peer to the MapState in the internal state type hierarchy.
|
InternalMapState<K,N,UK,UV> |
This class defines the internal interface for map state.
|
InternalMergingState<K,N,IN,SV,OUT> |
The peer to the MergingState in the internal state type hierarchy.
|
InternalMergingState<K,N,IN,SV,OUT,SYNCOUT> |
This class defines the internal interface for merging state.
|
InternalOperatorCoordinatorMetricGroup |
Special MetricGroup representing an OperatorCoordinator.
|
InternalOperatorIOMetricGroup |
Metric group that contains shareable pre-defined IO-related metrics.
|
InternalOperatorMetricGroup |
|
InternalPartitionedState<N> |
A state that is partitioned into different namespaces.
|
InternalPlan |
Internal interface wrapping a plan.
|
InternalPriorityQueue<T> |
Interface for collection that gives in order access to elements w.r.t their priority.
|
InternalProcessAllWindowContext<IN,OUT,W extends Window> |
Internal reusable context wrapper.
|
InternalProcessApplyAllWindowContext<IN,OUT,W extends Window> |
Internal reusable context wrapper.
|
InternalProcessApplyWindowContext<IN,OUT,KEY,W extends Window> |
Internal reusable context wrapper.
|
InternalProcessWindowContext<IN,OUT,KEY,W extends Window> |
Internal reusable context wrapper.
|
InternalReducingState<K,N,T> |
The peer to the ReducingState in the internal state type hierarchy.
|
InternalReducingState<K,N,T> |
This class defines the internal interface for reducing state.
|
InternalRowMergerFunction |
Merges two rows into a single row with unique field names.
|
InternalSerializers |
|
InternalServiceDecorator |
Creates an internal Service which forwards the requests from the TaskManager(s) to the active
JobManager.
|
InternalSingleValueAllWindowFunction<IN,OUT,W extends Window> |
Internal window function for wrapping an AllWindowFunction that takes an Iterable
when the window state is a single value.
|
InternalSingleValueProcessAllWindowFunction<IN,OUT,W extends Window> |
Internal window function for wrapping a ProcessAllWindowFunction that takes an
Iterable when the window state is a single value.
|
InternalSingleValueProcessWindowFunction<IN,OUT,KEY,W extends Window> |
Internal window function for wrapping a ProcessWindowFunction that takes an
Iterable when the window state is a single value.
|
InternalSingleValueWindowFunction<IN,OUT,KEY,W extends Window> |
Internal window function for wrapping a WindowFunction that takes an Iterable
when the window state is a single value.
|
InternalSinkCommitterMetricGroup |
|
InternalSinkWriterMetricGroup |
|
InternalSourceReaderMetricGroup |
|
InternalSplitEnumeratorMetricGroup |
|
InternalStateFuture<T> |
The Internal definition of StateFuture , add some method that will be used by framework.
|
InternalTimer<K,N> |
Internal interface for in-flight timers.
|
InternalTimerService<N> |
Interface for working with time and timers.
|
InternalTimerServiceAsyncImpl<K,N> |
An implementation of InternalTimerService that is used by org.apache.flink.streaming.runtime.operators.asyncprocessing.AbstractAsyncStateStreamOperator .
|
InternalTimerServiceImpl<K,N> |
|
InternalTimerServiceSerializationProxy<K> |
Serialization proxy for the timer services for a given key-group.
|
InternalTimersSnapshot<K,N> |
A snapshot of internal timers, containing event and processing timers and the serializers to use
to write / read them.
|
InternalTimersSnapshotReaderWriters |
|
InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader<K,N> |
|
InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter |
|
InternalTimersSnapshotReaderWriters.LegacyTimerSerializer<K,N> |
|
InternalTimeServiceManager<K> |
An entity keeping all the time-related services.
|
InternalTimeServiceManager.Provider |
|
InternalTimeServiceManager.ShouldStopAdvancingFn |
Signals whether the watermark should continue advancing.
|
InternalTimeServiceManagerImpl<K> |
An entity keeping all the time-related services.
|
InternalTimeWindowAssigner |
The internal time window assigner which has some useful methods.
|
InternalTypeInfo<T> |
Type information that wraps a serializer that originated from a LogicalType .
|
InternalValueState<K,N,T> |
The peer to the ValueState in the internal state type hierarchy.
|
InternalValueState<K,N,V> |
This class defines the internal interface for value state.
|
InternalWatermark |
The Watermark that contains extra information to be used internally.
|
InternalWindowFunction<IN,OUT,KEY,W extends Window> |
Internal interface for functions that are evaluated over keyed (grouped) windows.
|
InternalWindowFunction.InternalWindowContext |
|
InternalWindowProcessFunction<K,W extends Window> |
The internal interface for functions that process over grouped windows.
|
InternalWindowProcessFunction.Context<K,W extends Window> |
|
IntervalFreshness |
|
IntervalFreshness.TimeUnit |
An enumeration of time unit representing the unit of interval freshness.
|
IntervalFreshnessUtils |
|
IntervalJoinFunction |
|
IntervalJoinOperator<K,T1,T2,OUT> |
An operator to execute time-bounded stream inner joins.
|
IntervalJoinOperator.BufferEntry<T> |
A container for elements put in the left/write buffer.
|
IntervalJoinOperator.BufferEntrySerializer<T> |
|
IntervalJoinOperator.BufferEntrySerializerSnapshot<T> |
|
IntervalJoinSpec |
IntervalJoinSpec describes how two tables will be joined in interval join.
|
IntervalJoinSpec.WindowBounds |
WindowBounds describes the time range condition of a Interval Join.
|
IntHashSet |
Int hash set.
|
IntMaximum |
An accumulator that finds the maximum integer value.
|
IntMinimum |
An accumulator that finds the minimum integer value.
|
IntParser |
Parses a decimal text field into a IntValue.
|
IntPrimitiveArrayComparator |
|
IntPrimitiveArraySerializer |
A serializer for int arrays.
|
IntPrimitiveArraySerializer.IntPrimitiveArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
IntSerializer |
Type serializer for Integer (and int , via auto-boxing).
|
IntSerializer.IntSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
IntType |
Logical type of a 4-byte signed integer with values from -2,147,483,648 to 2,147,483,647.
|
IntValue |
Boxed serializable and comparable integer type, representing the primitive type int .
|
IntValueComparator |
Specialized comparator for IntValue based on CopyableValueComparator.
|
IntValueParser |
Parses a decimal text field into a IntValue.
|
IntValueSerializer |
|
IntValueSerializer.IntValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
IntWriter<T> |
|
IntWriter.IntWriterForArray |
|
IntWriter.IntWriterForRow |
|
InvalidProgramException |
An exception thrown to indicate that the composed program is invalid.
|
InvalidTypesException |
A special case of the InvalidProgramException , indicating that the types used in an
operation are invalid or inconsistent.
|
IOManager |
The facade for the provided I/O manager services.
|
IOManagerAsync |
A version of the IOManager that uses asynchronous I/O.
|
IOMetrics |
An instance of this class represents a snapshot of the io-related metrics of a single task.
|
IOMetricsInfo |
IO metrics information.
|
IOReadableWritable |
This interface must be implemented by every class whose objects have to be serialized to their
binary representation and vice-versa.
|
IOUtils |
An utility class for I/O related functionality.
|
IsProcessingBacklogEvent |
A source event that notify the source operator of the backlog status.
|
IsSlotAvailableAndFreeFunction |
Functional interface for checking whether a slot is available and free.
|
ITCaseRules |
Rules for Integration Tests.
|
ItemAtIndexArgumentTypeStrategy |
|
ItemAtTypeStrategy |
|
IterableIterator<E> |
|
IterableStateSnapshot<K,N,S> |
|
IterableUtils |
A collection of utilities that expand the usage of Iterable .
|
IterateType |
The type of the Python map state iterate request.
|
IterationAggregatorBroker |
|
IterationEventWithAggregators |
Base class for iteration TaskEvent transmitting operator aggregators.
|
IterationHeadTask<X,Y,S extends Function,OT> |
The head is responsible for coordinating an iteration and can run a Driver inside.
|
IterationIntermediateTask<S extends Function,OT> |
An intermediate iteration task, which runs a Driver
inside.
|
IterationOperator |
|
IterationRuntimeContext |
A specialization of the RuntimeContext available in iterative computations of the DataSet
API.
|
IterationSynchronizationSinkTask |
The task responsible for synchronizing all iteration heads, implemented as an output task.
|
IterationTailTask<S extends Function,OT> |
An iteration tail, which runs a driver inside.
|
IterativeCondition<T> |
A user-defined condition that decides if an element should be accepted in the pattern or not.
|
IterativeCondition.Context<T> |
The context used when evaluating the condition .
|
IterativeConditionRunner |
|
IteratorResultIterator<E> |
|
IteratorSourceEnumerator<SplitT extends IteratorSourceSplit<?,?>> |
|
IteratorSourceReader<E,IterT extends Iterator<E>,SplitT extends IteratorSourceSplit<E,IterT>> |
|
IteratorSourceReaderBase<E,O,IterT extends Iterator<E>,SplitT extends IteratorSourceSplit<E,IterT>> |
|
IteratorSourceSplit<E,IterT extends Iterator<E>> |
A SourceSplit that represents a sequence of elements captured in an iterator.
|
JaasModule |
Responsible for installing a process-wide JAAS configuration.
|
JaasModuleFactory |
|
JacksonMapperFactory |
Factory for Jackson mappers.
|
JarDeleteHandler |
Handles requests for deletion of jars.
|
JarDeleteHeaders |
|
JarDeleteMessageParameters |
|
JarFileChecker |
Checks the Jar files created by the build process.
|
JarHandlerUtils |
Utils for jar handlers.
|
JarHandlerUtils.JarHandlerContext |
Standard jar handler parameters parsed from request.
|
JarIdPathParameter |
Path parameter to identify uploaded jar files.
|
JarListHandler |
Handle request for listing uploaded jars.
|
JarListHeaders |
|
JarListInfo |
|
JarListInfo.JarEntryInfo |
Nested class to encapsulate the jar entry info.
|
JarListInfo.JarFileInfo |
Nested class to encapsulate the jar file info.
|
JarLocation |
Enum for specifying jar locations.
|
JarManifestParser |
Utility that parses JAR manifest attributes.
|
JarPlanGetHeaders |
|
JarPlanHandler |
This handler handles requests to fetch the plan for a jar.
|
JarPlanPostHeaders |
|
JarPlanRequestBody |
|
JarRequestBody |
Base class for RequestBody for running a jar or querying the plan.
|
JarRunHandler |
Handler to submit jobs uploaded via the Web UI.
|
JarRunHeaders |
|
JarRunMessageParameters |
|
JarRunRequestBody |
|
JarRunResponseBody |
|
JarUploadHandler |
Handles .jar file uploads.
|
JarUploadHeaders |
|
JarUploadResponseBody |
|
JarUtils |
Utility functions for jar files.
|
JavaCodeSplitter |
Rewrite generated java code so that the length of each method becomes smaller and can be
compiled.
|
JavaEitherSerializerSnapshot<L,R> |
|
JavaFieldPredicates |
Fine-grained predicates focus on the JavaField.
|
JavaJob |
Simple batch job in pure Java.
|
JavaJobWithKryoSerializer |
Simple batch job in pure Java that uses a custom Kryo serializer.
|
JavaLexer |
|
JavaParser |
|
JavaParser.AnnotationConstantRestContext |
|
JavaParser.AnnotationContext |
|
JavaParser.AnnotationMethodOrConstantRestContext |
|
JavaParser.AnnotationMethodRestContext |
|
JavaParser.AnnotationTypeBodyContext |
|
JavaParser.AnnotationTypeDeclarationContext |
|
JavaParser.AnnotationTypeElementDeclarationContext |
|
JavaParser.AnnotationTypeElementRestContext |
|
JavaParser.ArgumentsContext |
|
JavaParser.ArrayCreatorRestContext |
|
JavaParser.ArrayInitializerContext |
|
JavaParser.BlockContext |
|
JavaParser.BlockStatementContext |
|
JavaParser.CatchClauseContext |
|
JavaParser.CatchTypeContext |
|
JavaParser.ClassBodyContext |
|
JavaParser.ClassBodyDeclarationContext |
|
JavaParser.ClassCreatorRestContext |
|
JavaParser.ClassDeclarationContext |
|
JavaParser.ClassOrInterfaceModifierContext |
|
JavaParser.ClassOrInterfaceTypeContext |
|
JavaParser.ClassTypeContext |
|
JavaParser.CompilationUnitContext |
|
JavaParser.ConstantDeclaratorContext |
|
JavaParser.ConstDeclarationContext |
|
JavaParser.ConstructorCallContext |
|
JavaParser.ConstructorDeclarationContext |
|
JavaParser.CreatedNameContext |
|
JavaParser.CreatorContext |
|
JavaParser.DefaultValueContext |
|
JavaParser.ElementValueArrayInitializerContext |
|
JavaParser.ElementValueContext |
|
JavaParser.ElementValuePairContext |
|
JavaParser.ElementValuePairsContext |
|
JavaParser.EnhancedForControlContext |
|
JavaParser.EnumBodyDeclarationsContext |
|
JavaParser.EnumConstantContext |
|
JavaParser.EnumConstantsContext |
|
JavaParser.EnumDeclarationContext |
|
JavaParser.ExplicitGenericInvocationContext |
|
JavaParser.ExplicitGenericInvocationSuffixContext |
|
JavaParser.ExpressionContext |
|
JavaParser.ExpressionListContext |
|
JavaParser.FieldDeclarationContext |
|
JavaParser.FinallyBlockContext |
|
JavaParser.FloatLiteralContext |
|
JavaParser.ForControlContext |
|
JavaParser.ForInitContext |
|
JavaParser.FormalParameterContext |
|
JavaParser.FormalParameterListContext |
|
JavaParser.FormalParametersContext |
|
JavaParser.GenericConstructorDeclarationContext |
|
JavaParser.GenericInterfaceMethodDeclarationContext |
|
JavaParser.GenericMethodDeclarationContext |
|
JavaParser.ImportDeclarationContext |
|
JavaParser.InnerCreatorContext |
|
JavaParser.IntegerLiteralContext |
|
JavaParser.InterfaceBodyContext |
|
JavaParser.InterfaceBodyDeclarationContext |
|
JavaParser.InterfaceDeclarationContext |
|
JavaParser.InterfaceMemberDeclarationContext |
|
JavaParser.InterfaceMethodDeclarationContext |
|
JavaParser.InterfaceMethodModifierContext |
|
JavaParser.LambdaBodyContext |
|
JavaParser.LambdaExpressionContext |
|
JavaParser.LambdaParametersContext |
|
JavaParser.LastFormalParameterContext |
|
JavaParser.LiteralContext |
|
JavaParser.LocalTypeDeclarationContext |
|
JavaParser.LocalVariableDeclarationContext |
|
JavaParser.MemberDeclarationContext |
|
JavaParser.MethodBodyContext |
|
JavaParser.MethodCallContext |
|
JavaParser.MethodDeclarationContext |
|
JavaParser.ModifierContext |
|
JavaParser.NonWildcardTypeArgumentsContext |
|
JavaParser.NonWildcardTypeArgumentsOrDiamondContext |
|
JavaParser.PackageDeclarationContext |
|
JavaParser.ParExpressionContext |
|
JavaParser.PrimaryContext |
|
JavaParser.PrimitiveTypeContext |
|
JavaParser.QualifiedNameContext |
|
JavaParser.QualifiedNameListContext |
|
JavaParser.ResourceContext |
|
JavaParser.ResourcesContext |
|
JavaParser.ResourceSpecificationContext |
|
JavaParser.StatementContext |
|
JavaParser.SuperSuffixContext |
|
JavaParser.SwitchBlockStatementGroupContext |
|
JavaParser.SwitchLabelContext |
|
JavaParser.TypeArgumentContext |
|
JavaParser.TypeArgumentsContext |
|
JavaParser.TypeArgumentsOrDiamondContext |
|
JavaParser.TypeBoundContext |
|
JavaParser.TypeDeclarationContext |
|
JavaParser.TypeListContext |
|
JavaParser.TypeParameterContext |
|
JavaParser.TypeParametersContext |
|
JavaParser.TypeTypeContext |
|
JavaParser.TypeTypeOrVoidContext |
|
JavaParser.VariableDeclaratorContext |
|
JavaParser.VariableDeclaratorIdContext |
|
JavaParser.VariableDeclaratorsContext |
|
JavaParser.VariableInitializerContext |
|
JavaParser.VariableModifierContext |
|
JavaParserBaseListener |
This class provides an empty implementation of JavaParserListener ,
which can be extended to create a listener which only needs to handle a subset
of the available methods.
|
JavaParserBaseVisitor<T> |
This class provides an empty implementation of JavaParserVisitor ,
which can be extended to create a visitor which only needs to handle a subset
of the available methods.
|
JavaParserListener |
This interface defines a complete listener for a parse tree produced by
JavaParser .
|
JavaParserVisitor<T> |
This interface defines a complete generic visitor for a parse tree produced
by JavaParser .
|
JavaProgramTestBase |
Base class for unit tests that run a single test with object reuse enabled/disabled and against
collection environments.
|
JavaProgramTestBaseJUnit4 |
Deprecated.
|
JavaSerializer<T> |
This is a reimplementation of Kryo's JavaSerializer , that additionally makes sure the ObjectInputStream used for deserialization specifically uses Kryo's registered classloader.
|
JavaSerializer<T extends Serializable> |
|
JavaSerializer.JavaSerializerSnapshot<T extends Serializable> |
Serializer configuration snapshot for compatibility and format evolution.
|
JavaToValueConverter |
|
JMTMRegistrationRejection |
|
JMTMRegistrationSuccess |
|
JMXReporter |
|
JMXReporter.JmxCounterMBean |
The MBean interface for an exposed counter.
|
JMXReporter.JmxGaugeMBean |
The MBean interface for an exposed gauge.
|
JMXReporter.JmxHistogramMBean |
The MBean interface for an exposed histogram.
|
JMXReporter.JmxMeterMBean |
The MBean interface for an exposed meter.
|
JMXReporter.MetricMBean |
The common MBean interface for all metrics.
|
JMXReporterFactory |
|
JMXServerOptions |
The set of configuration options relating to JMX server.
|
JMXService |
Provide a JVM-wide singleton JMX Service.
|
JobAccumulatorsHandler |
Request handler that returns the aggregated accumulators of a job.
|
JobAccumulatorsHeaders |
|
JobAccumulatorsInfo |
|
JobAccumulatorsInfo.JobAccumulator |
|
JobAccumulatorsInfo.UserTaskAccumulator |
|
JobAccumulatorsMessageParameters |
|
JobAllocationsInformation |
Information about allocations of Job Vertices.
|
JobAllocationsInformation.VertexAllocationInformation |
Information about the allocations of a single Job Vertex.
|
JobCancellationException |
An exception which is thrown by the JobClient if a job is aborted as a result of a user
cancellation.
|
JobCancellationFailedException |
JobCancellationFailedException is thrown if the cancellation of a job failed.
|
JobCancellationHandler |
Request handler for the cancel and stop request.
|
JobCancellationHeaders |
|
JobCancellationMessageParameters |
Parameters for job related REST handlers.
|
JobCheckpointingSettings |
The JobCheckpointingSettings are attached to a JobGraph and describe the settings for the
asynchronous checkpoints of the JobGraph, such as interval.
|
JobClient |
A client that is scoped to a specific job.
|
JobClientHeartbeatHandler |
Receive the heartbeat from the client.
|
JobClientHeartbeatHeaders |
|
JobClientHeartbeatParameters |
The parameter when the client reports heartbeat.
|
JobClientHeartbeatRequestBody |
|
JobClusterEntrypoint |
Deprecated.
|
JobConfigHandler |
Handler serving the job configuration.
|
JobConfigHeaders |
|
JobConfigInfo |
|
JobConfigInfo.Deserializer |
|
JobConfigInfo.ExecutionConfigInfo |
Nested class to encapsulate the execution configuration.
|
JobConfigInfo.Serializer |
|
JobController |
Controller for interacting with a job.
|
JobCreatedEvent |
Basic job created event.
|
JobDetails |
An actor message with a detailed overview of the current status of a job.
|
JobDetails.CurrentAttempts |
The CurrentAttempts holds the attempt number of the current representative execution attempt,
the attempt numbers of all the running attempts, and whether the current execution has
reached terminal state.
|
JobDetailsHandler |
Handler returning the details for the specified job.
|
JobDetailsHeaders |
|
JobDetailsInfo |
Details about a job.
|
JobDetailsInfo.JobVertexDetailsInfo |
Detailed information about a job vertex.
|
JobDispatcherFactory |
|
JobDispatcherLeaderProcess |
DispatcherLeaderProcess implementation for the per-job mode.
|
JobDispatcherLeaderProcessFactory |
|
JobDispatcherLeaderProcessFactoryFactory |
|
JobEdge |
This class represent edges (communication channels) in a job graph.
|
JobEvent |
A class that represents an event that happens during the job execution.
|
JobEventManager |
The manager for recording and replaying JobEvent .
|
JobEventReplayHandler |
The interface for process job event.
|
JobEvents |
A class hosts all the type ids of events.
|
JobEventStore |
|
JobEventStoreOptions |
Configuration options for the job events.
|
JobException |
Indicates that a job has failed.
|
JobExceptionsHandler |
Handler serving the job exceptions.
|
JobExceptionsHeaders |
|
JobExceptionsInfoWithHistory |
JobExceptionsInfoWithHistory providing a history of previously caused failures.
|
JobExceptionsInfoWithHistory.ExceptionInfo |
|
JobExceptionsInfoWithHistory.JobExceptionHistory |
JobExceptionHistory collects all previously caught errors.
|
JobExceptionsInfoWithHistory.RootExceptionInfo |
|
JobExceptionsMessageParameters |
|
JobExecutionException |
This exception is the base exception for all exceptions that denote any failure during the
execution of a job.
|
JobExecutionResult |
The result of a job execution.
|
JobExecutionResultHandler |
|
JobExecutionResultHeaders |
|
JobExecutionResultResponseBody |
|
JobExecutionStatusEvent |
Job execution status event.
|
JobFailureMetricReporter |
Helper class to simplify job failure reporting through a metric group.
|
JobGraph |
The JobGraph represents a Flink dataflow program, at the low level that the JobManager accepts.
|
JobGraphBuilder |
|
JobGraphJobInformation |
|
JobGraphRetriever |
Interface which allows to retrieve the JobGraph .
|
JobID |
Unique (at least statistically unique) identifier for a Flink Job.
|
JobIDDeserializer |
Json deserializer for JobID .
|
JobIDPathParameter |
Path parameter identifying jobs.
|
JobIDSerializer |
Json serializer for JobID .
|
JobIdsHandler |
Handler for job IDs.
|
JobIdsWithStatusesOverviewHeaders |
|
JobIdsWithStatusOverview |
An overview of how many jobs are in which status.
|
JobIdsWithStatusOverview.JobIdWithStatus |
|
JobInfo |
The JobInfo represents the meta information of current job.
|
JobInfo |
JobInfo contains all the meta information of the job.
|
JobInfo.ExecutionMode |
Execution mode of this current job.
|
JobInfoImpl |
The default implementation of JobInfo .
|
JobInformation |
Container class for job information which is stored in the ExecutionGraph .
|
JobInformation |
Information about the job.
|
JobInformation.VertexInformation |
Information about a single vertex.
|
JobInitializationException |
An exception indicating that the job has failed in the INITIALIZING job status.
|
JobLeaderIdActions |
|
JobLeaderIdService |
Service which retrieves for a registered job the current job leader id (the leader id of the job
manager responsible for the job).
|
JobLeaderListener |
|
JobLeaderService |
This service has the responsibility to monitor the job leaders (the job manager which is leader
for a given job) for all registered jobs.
|
JobListener |
A listener that is notified on specific job status changed, which should be firstly registered by
#registerJobListener of execution environments.
|
JobManagerCheckpointStorage |
The CheckpointStorage checkpoints state directly to the JobManager's memory (hence the
name), but savepoints will be persisted to a file system.
|
JobManagerCustomLogHandler |
Rest handler which serves the custom log file from JobManager.
|
JobManagerCustomLogHeaders |
|
JobManagerEnvironmentHandler |
Handler which serves the jobmanager's environment variables.
|
JobManagerEnvironmentHeaders |
|
JobManagerException |
|
JobManagerFlinkMemory |
Flink internal memory components of Job Manager.
|
JobManagerFlinkMemoryUtils |
|
JobManagerJobConfigurationHandler |
Handler which serves the jobmanager's configuration of a specific job.
|
JobManagerJobConfigurationHeaders |
|
JobManagerJobEnvironmentHandler |
Handler which serves the jobmanager's environment variables of a specific job.
|
JobManagerJobEnvironmentHeaders |
|
JobManagerJobMetricGroup |
Special MetricGroup representing everything belonging to a
specific job, running on the JobManager.
|
JobManagerJobMetricGroupFactory |
|
JobManagerJobScopeFormat |
|
JobManagerLogFileHandler |
Rest handler which serves the log files from JobManager.
|
JobManagerLogFileHeader |
|
JobManagerLogListHandler |
Handler which serves detailed JobManager log list information.
|
JobManagerLogListHeaders |
|
JobManagerLogUrlHeaders |
Headers for the log url retriever of JobManager.
|
JobManagerMetricGroup |
|
JobManagerMetricGroupFactory |
|
JobManagerMetricsHandler |
Handler that returns JobManager metrics.
|
JobManagerMetricsHeaders |
|
JobManagerMetricsMessageParameters |
|
JobManagerOperatorMetricGroup |
Special MetricGroup representing everything belonging to the
components running on the JobManager of an Operator.
|
JobManagerOperatorMetricsHandler |
Handler that returns job manager operator metrics.
|
JobManagerOperatorMetricsHeaders |
|
JobManagerOperatorMetricsMessageParameters |
|
JobManagerOperatorScopeFormat |
|
JobManagerOptions |
Configuration options for the JobManager.
|
JobManagerOptions.HybridPartitionDataConsumeConstraint |
Constraints of upstream hybrid partition data consumption by downstream.
|
JobManagerOptions.JobStoreType |
Type of job store implementation.
|
JobManagerOptions.SchedulerType |
Type of scheduler implementation.
|
JobManagerProcessSpec |
Describe the specifics of different resource dimensions of the JobManager process.
|
JobManagerProcessUtils |
|
JobManagerProfilingFileHandler |
Rest handler which serves the profiler result file from JobManager.
|
JobManagerProfilingFileHeaders |
|
JobManagerProfilingHandler |
Rest handler which serves the profiling info from the JobManager.
|
JobManagerProfilingHeaders |
|
JobManagerProfilingListHandler |
Rest handler which serves the profiling list from the JobManager.
|
JobManagerProfilingListHeaders |
|
JobManagerRegistration |
Container for JobManager related registration information, such as the leader id or the job id.
|
JobManagerRunner |
Interface for a runner which executes a JobMaster .
|
JobManagerRunnerFactory |
|
JobManagerRunnerRegistry |
|
JobManagerRunnerResult |
|
JobManagerScopeFormat |
|
JobManagerSharedServices |
Utility class which holds all auxiliary shared services used by the JobMaster .
|
JobManagerStdoutFileHeader |
Headers for the JobManagerStdoutFileHandler .
|
JobManagerTaskRestore |
This class encapsulates the data from the job manager to restore a task.
|
JobManagerThreadDumpHandler |
Rest handler which serves the thread dump info from the JobManager.
|
JobManagerThreadDumpHeaders |
|
JobMaster |
JobMaster implementation.
|
JobMasterConfiguration |
|
JobMasterException |
|
JobMasterGateway |
|
JobMasterId |
|
JobMasterOperatorEventGateway |
|
JobMasterPartitionTracker |
Utility for tracking partitions and issuing release calls to task executors and shuffle masters.
|
JobMasterPartitionTrackerImpl |
Utility for tracking partitions and issuing release calls to task executors and shuffle masters.
|
JobMasterRegistrationSuccess |
Base class for responses from the ResourceManager to a registration attempt by a JobMaster.
|
JobMasterService |
Interface which specifies the JobMaster service.
|
JobMasterServiceFactory |
|
JobMasterServiceLeadershipRunner |
|
JobMasterServiceLeadershipRunnerFactory |
|
JobMasterServiceProcess |
|
JobMasterServiceProcess.WaitingForLeadership |
|
JobMasterServiceProcessFactory |
|
JobMessageParameters |
Message parameters which require a job path parameter.
|
JobMetricGroup<C extends ComponentMetricGroup<C>> |
Special abstract MetricGroup representing everything belonging
to a specific job.
|
JobMetricsHandler |
Request handler that returns for a given job a list of all available metrics or the values for a
set of metrics.
|
JobMetricsHeaders |
|
JobMetricsMessageParameters |
|
JobNotFinishedException |
Exception indicating that a Flink job has not been finished.
|
JobPermanentBlobService |
|
JobPersistenceComponentFactory |
Factory for components that are responsible for persisting a job for recovery.
|
JobPlanHandler |
Handler serving the job execution plan.
|
JobPlanHeaders |
|
JobPlanInfo |
|
JobPlanInfo.RawJson |
Simple wrapper around a raw JSON string.
|
JobPlanInfo.RawJson.Deserializer |
|
JobPlanInfo.RawJson.Serializer |
|
JobResourceRequirements |
Information about the parallelism of job vertices.
|
JobResourceRequirements.Builder |
|
JobResourceRequirementsBody |
Body for change job requests.
|
JobResourceRequirementsHandler |
|
JobResourceRequirementsHeaders |
Headers for REST request to get details on job's resources.
|
JobResourceRequirementsUpdateHandler |
|
JobResourcesRequirementsUpdateHeaders |
Headers for REST request to patch a job.
|
JobRestEndpointFactory |
|
JobResult |
|
JobResult.Builder |
|
JobResultDeserializer |
|
JobResultEntry |
|
JobResultSerializer |
|
JobResultStore |
A storage for the results of globally terminated jobs.
|
JobResultStoreOptions |
The set of configuration options relating to the Job Result Store.
|
JobSchedulingPlan |
A plan that describes how to execute JobGraph .
|
JobSchedulingPlan.SlotAssignment |
Assignment of a slot to some target (e.g. a slot sharing group).
|
JobsFilterQueryParameter |
|
JobShuffleContext |
Job level shuffle context which can offer some job information like job ID and through it, the
shuffle plugin notify the job to stop tracking the lost result partitions.
|
JobShuffleContextImpl |
|
JobsOverview |
An overview of how many jobs are in which status.
|
JobsOverviewHandler |
Overview handler for jobs.
|
JobsOverviewHeaders |
|
JobStatus |
Possible states of a job once it has been accepted by the dispatcher.
|
JobStatusChangedEvent |
Basic job status event.
|
JobStatusChangedListener |
When job is created or its status is changed, Flink will generate job event and notify job status
changed listener.
|
JobStatusChangedListenerFactory |
Factory for job status changed listener.
|
JobStatusChangedListenerFactory.Context |
|
JobStatusChangedListenerUtils |
|
JobStatusHandler |
Handler for requesting job status.
|
JobStatusHook |
Hooks on job status changing.
|
JobStatusInfo |
The status of a specific job.
|
JobStatusInfoHeaders |
|
JobStatusListener |
Interface for observers that monitor the status of a job.
|
JobStatusMessage |
A simple message that holds the state of a job execution.
|
JobStatusMetrics |
Metrics that capture the time that a job spends in each JobStatus .
|
JobStatusProvider |
Interface for querying the state of a job and the timestamps of state transitions.
|
JobStatusStore |
Listens for and exposes the current job state and state timestamps.
|
JobSubmission |
Programmatic definition of a job-submission.
|
JobSubmission.JobSubmissionBuilder |
|
JobSubmissionException |
This exception denotes an error while submitting a job to the JobManager.
|
JobSubmissionResult |
The result of submitting a job to a JobManager.
|
JobSubmitHandler |
This handler can be used to submit jobs to a Flink cluster.
|
JobSubmitHeaders |
These headers define the protocol for submitting a job to a flink cluster.
|
JobSubmitRequestBody |
Request for submitting a job.
|
JobSubmitRequestBody.DistributedCacheFile |
Descriptor for a distributed cache file.
|
JobSubmitResponseBody |
Response to the submission of a job, containing a URL from which the status of the job can be
retrieved from.
|
JobTable |
|
JobTable.Connection |
A connection contains services bound to the lifetime of a connection with a JobManager.
|
JobTable.Job |
A job contains services which are bound to the lifetime of a Flink job.
|
JobTable.JobServices |
Services associated with a job.
|
JobTaskManagerMessageParameters |
Message parameters which require a job path parameter and a TaskManager id path parameter.
|
JobType |
Enum to distinguish JobGraphs between batch and streaming, currently used by the scheduler.
|
JobVertex |
The base class for job vertexes.
|
JobVertex.FinalizeOnMasterContext |
The context exposes some runtime infos for finalization.
|
JobVertex.InitializeOnMasterContext |
|
JobVertexAccumulatorsHandler |
Request handler for the job vertex accumulators.
|
JobVertexAccumulatorsHeaders |
|
JobVertexAccumulatorsInfo |
|
JobVertexBackPressureHandler |
Request handler for the job vertex back pressure.
|
JobVertexBackPressureHeaders |
|
JobVertexBackPressureInfo |
|
JobVertexBackPressureInfo.SubtaskBackPressureInfo |
Nested class to encapsulate the sub tasks back pressure.
|
JobVertexBackPressureInfo.VertexBackPressureLevel |
Level of vertex back-pressure.
|
JobVertexBackPressureInfo.VertexBackPressureStatus |
Status of vertex back-pressure.
|
JobVertexBuildContext |
Helper class encapsulates all necessary information and configurations required during the
construction of job vertices.
|
JobVertexDetailsHandler |
Request handler for the job vertex details.
|
JobVertexDetailsHeaders |
|
JobVertexDetailsInfo |
|
JobVertexFlameGraphHandler |
Request handler for the job vertex Flame Graph.
|
JobVertexFlameGraphHeaders |
|
JobVertexFlameGraphParameters |
Message parameters for job vertex Flame Graph REST handler.
|
JobVertexID |
A class for statistically unique job vertex IDs.
|
JobVertexIDDeserializer |
|
JobVertexIDKeyDeserializer |
|
JobVertexIDKeySerializer |
Jackson serializer for JobVertexID used as a key serializer.
|
JobVertexIdPathParameter |
|
JobVertexIDSerializer |
|
JobVertexInputInfo |
This class describe how a job vertex consume an input(intermediate result).
|
JobVertexMessageParameters |
Message parameters for job vertex REST handlers.
|
JobVertexMetricsHandler |
Deprecated.
|
JobVertexMetricsHeaders |
|
JobVertexMetricsMessageParameters |
|
JobVertexResourceRequirements |
Information about the parallelism of job vertices.
|
JobVertexResourceRequirements.Parallelism |
|
JobVertexTaskManagersHandler |
A request handler that provides the details of a job vertex, including id, name, and the runtime
and metrics of all its subtasks aggregated by TaskManager.
|
JobVertexTaskManagersHeaders |
|
JobVertexTaskManagersInfo |
|
JobVertexTaskManagersInfo.TaskManagersInfo |
Detailed information about task managers.
|
JobVertexWatermarksHandler |
|
JobVertexWatermarksHeaders |
|
JoinCondition |
Interface for code generated condition function for [[org.apache.calcite.rel.core.Join]].
|
JoinConditionTypeCoerceRule |
Planner rule that coerces the both sides of EQUALS(`=`) operator in Join condition to the same
type while sans nullability.
|
JoinConditionTypeCoerceRule.JoinConditionTypeCoerceRuleConfig |
Rule configuration.
|
JoinConditionWithNullFilters |
Utility to take null filters into consideration when apply join condition.
|
JoinDriver<IT1,IT2,OT> |
The join driver implements the logic of a join operator at runtime.
|
JoinedRowData |
An implementation of RowData which is backed by two concatenated RowData .
|
JoinedStreams<T1,T2> |
JoinedStreams represents two DataStreams that have been joined.
|
JoinedStreams.WithWindow<T1,T2,KEY,W extends Window> |
|
JoinFunction<IN1,IN2,OUT> |
Interface for Join functions.
|
JoinHashMap<BT> |
|
JoinHelper<STATE_VIEW,OUTER_STATE_VIEW extends STATE_VIEW> |
A helper to do the logic of streaming join.
|
JoinInputSideSpec |
The JoinInputSideSpec is ap specification which describes input side information of a
Join.
|
JoinKeyContainsUniqueKeyBundle |
For the case that input has joinKey contains uniqueKey.
|
JoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> |
|
JoinOperatorBase.JoinHint |
An enumeration of hints, optionally usable to tell the system how exactly execute the join.
|
JoinQueryOperation |
Table operation that joins two relational operations based on given condition.
|
JoinQueryOperation.JoinType |
Specifies how the two Tables should be joined.
|
JoinRecordAsyncStateView |
|
JoinRecordAsyncStateViews |
|
JoinRecordStateView |
|
JoinRecordStateViews |
|
JoinSpec |
JoinSpec describes how two tables will be joined.
|
JoinStrategy |
Currently available join strategies and corresponding join hint names.
|
JoinTableFunctionScanToCorrelateRule |
Rule that rewrites Join on TableFunctionScan to Correlate .
|
JoinTableFunctionScanToCorrelateRule.Config |
|
JoinTaskIterator<V1,V2,O> |
Interface of an iterator that performs the logic of a match task.
|
JoinTypeUtil |
|
JoinWithSolutionSetFirstDriver<IT1,IT2,OT> |
|
JoinWithSolutionSetSecondDriver<IT1,IT2,OT> |
|
JsonArchivist |
Interface for all classes that want to participate in the archiving of job-related json
responses.
|
JsonArrayAggFunction |
|
JsonArrayAggFunction.Accumulator |
|
JsonDeserializationSchema<T> |
DeserializationSchema that deserializes a JSON String.
|
JsonExistsOnError |
|
JsonFactory |
A holder for the singleton Jackson JSON factory.
|
JsonFormatFactory |
|
JsonFormatOptions |
Options for the JSON format.
|
JsonFormatOptions.MapNullKeyMode |
Handling mode for map data with null key.
|
JsonFormatOptionsUtil |
|
JSONGenerator |
Helper class for generating a JSON representation from a StreamGraph .
|
JsonObjectAggFunction |
|
JsonObjectAggFunction.Accumulator |
|
JsonOnNull |
|
JsonParseException |
Exception which refers to parse errors in converters.
|
JsonParserRowDataDeserializationSchema |
Tool class used to convert fields from JsonParser to RowData which has a higher
parsing efficiency.
|
JsonParserToRowDataConverters |
Tool class used to convert fields from JsonParser to RowData .
|
JsonParserToRowDataConverters.JsonParserToRowDataConverter |
Runtime converter that converts JsonParser s into objects of Flink Table & SQL
internal data structures.
|
JsonPathCache |
The default cache for the jsonpath com.jayway.jsonpath.spi.cache.CacheProvider .
|
JsonPlanGenerator |
|
JsonQueryOnEmptyOrError |
|
JsonQueryOnErrorEmptyArgumentTypeStrategy |
|
JsonQueryWrapper |
|
JsonQuoteFunction |
|
JsonRowDataDeserializationSchema |
Deserialization schema from JSON to Flink Table/SQL internal data structure RowData .
|
JsonRowDataSerializationSchema |
Serialization schema that serializes an object of Flink internal data structure into a JSON
bytes.
|
JsonRowDeserializationSchema |
Deserialization schema from JSON to Flink types.
|
JsonRowDeserializationSchema.Builder |
|
JsonRowSchemaConverter |
Converts a JSON schema into Flink's type information.
|
JsonRowSerializationSchema |
Serialization schema that serializes an object of Flink types into a JSON bytes.
|
JsonRowSerializationSchema.Builder |
|
JsonSerdeUtil |
|
JsonSerdeUtil |
A utility class that provide abilities for JSON serialization and deserialization.
|
JsonSerializationSchema<T> |
SerializationSchema that serializes an object to a JSON String.
|
JsonToRowDataConverters |
Tool class used to convert from JsonNode to RowData .
|
JsonToRowDataConverters.JsonToRowDataConverter |
Runtime converter that converts JsonNode s into objects of Flink Table & SQL internal
data structures.
|
JsonType |
|
JsonUnquoteFunction |
|
JsonValueOnEmptyOrError |
|
JvmMetaspaceAndOverhead |
JVM metaspace and overhead memory sizes.
|
JvmMetaspaceAndOverheadOptions |
Options to calculate JVM Metaspace and Overhead.
|
JvmShutdownSafeguard |
A utility that guards against blocking shutdown hooks that block JVM shutdown.
|
JvmUtils |
|
KafkaStandaloneGenerator |
A generator that pushes the data into Kafka.
|
KeepAliveWrite |
Utilities to write.
|
KerberosLoginProvider |
Provides Kerberos login functionality.
|
KerberosMountDecorator |
Mount the custom Kerberos Configuration and Credential to the JobManager(s)/TaskManagers.
|
KerberosUtils |
|
Key<T> |
Deprecated.
|
KeyAccountingUnit<K> |
Key accounting unit holds the current in-flight key and tracks the corresponding ongoing records,
which is used to preserve the ordering of independent chained StateFuture .
|
KeyByKeySelector |
KeyByKeySelector is responsible for extracting the first field of the input row as key.
|
KeyCheckedOutputCollector<KEY,OUT> |
This output checks whether the current key of the output record and the key extracted with a
specific key selector are exactly the same.
|
KeyContext |
Interface for setting and querying the current key of keyed operations.
|
KeyContextHandler |
|
Keyed<K> |
Interface for objects that have a key attribute.
|
KeyedBackendSerializationProxy<K> |
Serialization proxy for all meta data in keyed state backends.
|
KeyedBroadcastProcessFunction<KS,IN1,IN2,OUT> |
|
KeyedBroadcastStateTransformation<KEY,IN1,IN2,OUT> |
|
KeyedBroadcastStateTransformationTranslator<KEY,IN1,IN2,OUT> |
|
KeyedCoProcessFunction<K,IN1,IN2,OUT> |
A function that processes elements of two keyed streams and produces a single output one.
|
KeyedCoProcessOperator<K,IN1,IN2,OUT> |
|
KeyedCoProcessOperatorWithWatermarkDelay<K,IN1,IN2,OUT> |
|
KeyedLookupJoinWrapper |
The lookup join handler which holds a LookupJoinRunner to process lookup for insert or
update_after record and directly process delete and update_before record via local state.
|
KeyedMapBundleOperator<K,V,IN,OUT> |
|
KeyedMultipleInputTransformation<OUT> |
|
KeyedPartitionStream<K,T> |
This interface represents a kind of partitioned data stream.
|
KeyedPartitionStream.ProcessConfigurableAndKeyedPartitionStream<K,T> |
|
KeyedPartitionStream.ProcessConfigurableAndTwoKeyedPartitionStreams<K,T1,T2> |
|
KeyedPartitionStreamImpl<K,V> |
|
KeyedPartitionWindowedStream<T,KEY> |
|
KeyedProcessFunction<K,I,O> |
A keyed function that processes elements of a stream.
|
KeyedProcessFunctionWithCleanupState<K,IN,OUT> |
A function that processes elements of a stream, and could cleanup state.
|
KeyedProcessOperator<KEY,IN,OUT> |
|
KeyedProcessOperator<K,IN,OUT> |
|
KeyedSortPartitionOperator<INPUT,KEY> |
|
KeyedStateBackend<K> |
A keyed state backend provides methods for managing keyed state.
|
KeyedStateBackend.KeySelectionListener<K> |
|
KeyedStateBackendParametersImpl<K> |
|
KeyedStateBootstrapFunction<K,IN> |
A function that writes keyed state to a new operator.
|
KeyedStateBootstrapOperator<K,IN> |
|
KeyedStateCheckpointOutputStream |
Checkpoint output stream that allows to write raw keyed state in a partitioned way, split into
key-groups.
|
KeyedStateFactory |
This factory produces concrete internal state objects.
|
KeyedStateFunction<K,S extends State> |
A function to be applied to all keyed states.
|
KeyedStateHandle |
Base for the handles of the checkpointed states in keyed streams.
|
KeyedStateInputFormat<K,N,OUT> |
Input format for reading partitioned state.
|
KeyedStateReaderFunction<K,OUT> |
A function that processes keys from a restored operator
|
KeyedStateReaderFunction.Context |
|
KeyedStateReaderOperator<KEY,OUT> |
|
KeyedStateStore |
This interface contains methods for registering keyed state with a managed store.
|
KeyedStateStoreV2 |
This interface contains methods for registering State .
|
KeyedStateTransformation<K,T> |
|
KeyedStream<T,KEY> |
|
KeyedStream.IntervalJoin<T1,T2,KEY> |
Perform a join over a time interval.
|
KeyedStream.IntervalJoined<IN1,IN2,KEY> |
IntervalJoined is a container for two streams that have keys for both sides as well as the
time boundaries over which elements should be joined.
|
KeyedTwoInputBroadcastProcessOperator<KEY,IN1,IN2,OUT> |
|
KeyedTwoInputNonBroadcastProcessOperator<KEY,IN1,IN2,OUT> |
|
KeyedTwoOutputProcessOperator<KEY,IN,OUT_MAIN,OUT_SIDE> |
|
KeyExtractorFunction<T> |
Function to extract a key from a given object.
|
KeyFieldOutOfBoundsException |
An exception specifying that a required key field was not set in a record, i.e. was null
.
|
KeyGroup |
Part of a savepoint representing data for a single key group.
|
KeyGroupedInternalPriorityQueue<T> |
This interface exists as (temporary) adapter between the new InternalPriorityQueue and
the old way in which timers are written in a snapshot.
|
KeyGroupedIterator<E> |
|
KeyGroupEntry |
Part of a savepoint representing data for a single state entry in a key group.
|
KeyGroupPartitionedPriorityQueue<T,PQ extends InternalPriorityQueue<T> & HeapPriorityQueueElement> |
This implementation of InternalPriorityQueue is internally partitioned into sub-queues
per key-group and essentially works as a heap-of-heaps.
|
KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory<T,PQS extends InternalPriorityQueue<T> & HeapPriorityQueueElement> |
|
KeyGroupPartitioner<T> |
Class that contains the base algorithm for partitioning data into key-groups.
|
KeyGroupPartitioner.ElementReaderFunction<T> |
This functional interface defines how one element is read from a DataInputView .
|
KeyGroupPartitioner.ElementWriterFunction<T> |
This functional interface defines how one element is written to a DataOutputView .
|
KeyGroupPartitioner.KeyGroupElementsConsumer<T> |
Functional interface to consume elements from a key group.
|
KeyGroupPartitioner.PartitioningResult<T> |
This represents the result of key-group partitioning.
|
KeyGroupRange |
This class defines a range of key-group indexes.
|
KeyGroupRangeAssignment |
|
KeyGroupRangeInputSplit |
An input split representing a key-group range from a savepoint.
|
KeyGroupRangeOffsets |
This class combines a key-group range with offsets that correspond to the key-groups in the
range.
|
KeyGroupsList |
This interface offers ordered random read access to multiple key group ids.
|
KeyGroupsSavepointStateHandle |
|
KeyGroupsStateHandle |
A handle to the partitioned stream operator state after it has been checkpointed.
|
KeyGroupStatePartitionStreamProvider |
This class provides access to an input stream that contains state data for one key group and the
key group id.
|
KeyGroupStreamPartitioner<T,K> |
Partitioner selects the target channel based on the key group index.
|
KeyMap<K,V> |
A special Hash Map implementation that can be traversed efficiently in sync with other hash maps.
|
KeyMap.Entry<K,V> |
An entry in the hash table.
|
KeyMap.LazyFactory<V> |
A factory for lazy/on-demand instantiation of values.
|
KeyMap.TraversalEvaluator<K,V> |
A visitor for a traversal over the union of multiple hash maps.
|
Keys<T> |
|
Keys.ExpressionKeys<T> |
Represents (nested) field access through string and integer-based keys
|
Keys.IncompatibleKeysException |
|
Keys.SelectorFunctionKeys<T,K> |
|
KeySelector<IN,KEY> |
The KeySelector allows to use deterministic objects for operations such as reduce,
reduceGroup, join, coGroup, etc.
|
KeySelectorUtil |
Utility class that contains helper methods to manipulating KeySelector for streaming.
|
KeySelectorUtil |
Utility for KeySelector.
|
KeySelectorUtil.ArrayKeySelector<IN> |
A key selector for selecting individual array fields as keys and returns them as a Tuple.
|
KeySelectorUtil.ComparableKeySelector<IN> |
A key selector for selecting key fields via a TypeComparator.
|
KeySelectorUtil.OneKeySelector<IN,K> |
Key extractor that extracts a single field via a generic comparator.
|
KeyValueDataType |
A data type that contains a key and value data type (e.g.
|
KeyValueIterator<K,V> |
An internal iterator interface which presents a more restrictive API than Iterator .
|
KeyValueStateIterator |
|
KMeansData |
Test data for KMeans programs.
|
KryoRegistration |
A KryoRegistration resembles a registered class and its serializer in Kryo.
|
KryoRegistration.SerializerDefinitionType |
IMPORTANT: the order of the enumerations must not change, since their ordinals are used for
serialization.
|
KryoSerializer<T> |
A type serializer that serializes its type using the Kryo serialization framework
(https://github.com/EsotericSoftware/kryo).
|
KryoSerializerSnapshot<T> |
|
KryoUtils |
Convenience methods for Kryo
|
KubernetesApplicationClusterEntrypoint |
|
KubernetesArtifactUploader |
Local artifact uploader for Kubernetes programs.
|
KubernetesCheckpointIDCounter |
|
KubernetesCheckpointRecoveryFactory |
|
KubernetesCheckpointStoreUtil |
|
KubernetesClusterClientFactory |
|
KubernetesClusterDescriptor |
|
KubernetesConfigMap |
Represent ConfigMap resource in kubernetes.
|
KubernetesConfigMapSharedInformer |
The shared informer for ConfigMap , it can be used as a shared watcher.
|
KubernetesConfigMapSharedWatcher |
The shared watcher interface for ConfigMap.
|
KubernetesConfigOptions |
This class holds configuration constants used by Flink's kubernetes runners.
|
KubernetesConfigOptions.ImagePullPolicy |
The container image pull policy.
|
KubernetesConfigOptions.NodePortAddressType |
The flink rest service exposed type.
|
KubernetesConfigOptions.ServiceExposedType |
The flink rest service exposed type.
|
KubernetesConfigOptionsInternal |
Kubernetes configuration options that are not meant to be set by the user.
|
KubernetesDeploymentTarget |
A class containing all the supported deployment target names for Kubernetes.
|
KubernetesException |
Kubernetes related checked exceptions.
|
KubernetesExecutionPlanStoreUtil |
|
KubernetesHaServicesFactory |
Factory for creating Kubernetes high availability services.
|
KubernetesHighAvailabilityOptions |
The set of configuration options relating to Kubernetes high-availability settings.
|
KubernetesJobManagerFactory |
Utility class for constructing all the Kubernetes components on the client-side.
|
KubernetesJobManagerParameters |
A utility class helps parse, verify, and manage the Kubernetes side parameters that are used for
constructing the JobManager Pod and all accompanying resources connected to it.
|
KubernetesJobManagerSpecification |
Composition of the created Kubernetes components that represents a Flink application.
|
KubernetesLeaderElectionConfiguration |
|
KubernetesLeaderElectionDriver |
|
KubernetesLeaderElectionDriverFactory |
|
KubernetesLeaderElectionHaServices |
Kubernetes HA services that use a single leader election service per JobManager.
|
KubernetesLeaderElector |
|
KubernetesLeaderElector.LeaderCallbackHandler |
Callback handler for leader election.
|
KubernetesLeaderRetrievalDriver |
|
KubernetesLeaderRetrievalDriverFactory |
|
KubernetesOwnerReference |
Represent Owner reference resource in kubernetes.
|
KubernetesParameters |
A common collection of parameters that is used to construct the JobManager/TaskManager Pods,
including the accompanying Kubernetes resources that together represent a Flink application.
|
KubernetesPod |
Represent KubernetesPod resource in kubernetes.
|
KubernetesPodsWatcher |
Watcher for pods in Kubernetes.
|
KubernetesResource<T> |
Represent a kubernetes resource.
|
KubernetesResourceManagerDriver |
|
KubernetesResourceManagerDriverConfiguration |
|
KubernetesResourceManagerFactory |
|
KubernetesSecretEnvVar |
Represents EnvVar resource in Kubernetes.
|
KubernetesService |
Represent Service resource in kubernetes.
|
KubernetesSessionCli |
Kubernetes customized commandline.
|
KubernetesSessionClusterEntrypoint |
Entry point for a Kubernetes session cluster.
|
KubernetesSessionClusterExecutor |
The PipelineExecutor to be used when executing a job on an already running cluster.
|
KubernetesSessionClusterExecutorFactory |
|
KubernetesSharedInformer<T extends io.fabric8.kubernetes.api.model.HasMetadata,R> |
Base class for shared watcher based on SharedIndexInformer .
|
KubernetesSharedWatcher<T> |
The interface for the Kubernetes shared watcher.
|
KubernetesSharedWatcher.Watch |
The Watch returned after creating watching, which can be used to close the watching.
|
KubernetesStateHandleStore<T extends Serializable> |
|
KubernetesStepDecorator |
A set of functions that together represent a feature in pods that are deployed for the
JobManager(s) or the TaskManager(s), which provides an extension to the way the given Flink
application works.
|
KubernetesTaskExecutorRunner |
This class is the executable entry point for running a TaskExecutor in a Kubernetes pod.
|
KubernetesTaskManagerFactory |
Utility class for constructing the TaskManager Pod on the JobManager.
|
KubernetesTaskManagerParameters |
A utility class helps parse, verify, and manage the Kubernetes side parameters that are used for
constructing the TaskManager Pod.
|
KubernetesToleration |
Represent Toleration resource in kubernetes.
|
KubernetesTooOldResourceVersionException |
Kubernetes too old resource version exception.
|
KubernetesUtils |
Common utils for Kubernetes.
|
KubernetesWatch |
Watch resource in Kubernetes.
|
KubernetesWorkerNode |
A stored Kubernetes worker, which contains the kubernetes pod.
|
KubernetesWorkerResourceSpecFactory |
|
KvStateChangeLogger<Value,Namespace> |
A logger for some key-partitioned state (not only ValueState .
|
KvStateClientProxy |
An interface for the Queryable State Client Proxy running on each Task Manager in the cluster.
|
KvStateClientProxyHandler |
This handler acts as an internal (to the Flink cluster) client that receives the requests from
external clients, executes them by contacting the Job Manager (if necessary) and the Task Manager
holding the requested state, and forwards the answer back to the client.
|
KvStateClientProxyImpl |
|
KvStateEntry<K,N,V> |
|
KvStateHandler |
Handler for common queryable state logic.
|
KvStateID |
Identifier for state instances.
|
KvStateInfo<K,N,V> |
|
KvStateInternalRequest |
|
KvStateInternalRequest.KvStateInternalRequestDeserializer |
|
KvStateLocation |
|
KvStateLocationOracle |
|
KvStateLocationRegistry |
|
KvStateRegistry |
|
KvStateRegistryGateway |
Gateway to report key-value state registration and deregistrations.
|
KvStateRegistryListener |
|
KvStateRequest |
|
KvStateRequest.KvStateRequestDeserializer |
|
KvStateRequestStats |
Simple statistics for monitoring the state server and the client proxy.
|
KvStateResponse |
The response containing the (serialized) state sent by the State Server to the
Client Proxy , and then forwarded by the proxy to the original Queryable State Client .
|
KvStateResponse.KvStateResponseDeserializer |
|
KvStateSerializer |
Serialization and deserialization the different state types and namespaces.
|
KvStateServer |
An interface for the Queryable State Server running on each Task Manager in the cluster.
|
KvStateServerHandler |
This handler dispatches asynchronous tasks, which query InternalKvState instances and
write the result to the channel.
|
KvStateServerImpl |
|
KvStateService |
|
LabeledGlobalFailureHandler |
An interface for handling and associating global failures with labels from FailureEnricher .
|
LabelSurrogate |
A label surrogate.
|
LabelSurrogate.Type |
An exemplary enum.
|
LagAggFunction<T> |
|
LagAggFunction.LagAcc<T> |
Accumulator for LAG.
|
LambdaUtil |
This class offers utility functions for Java's lambda features.
|
LargeRecordHandler<T> |
|
LastDatedValueFunction<T> |
Implementation of an AggregateFunction that returns a row containing the latest non-null
value with its corresponding date.
|
LastDatedValueFunction.Accumulator<T> |
Generic accumulator for representing state.
|
LastStateConnectionStateListener |
ConnectionStateListener which records the last state it was notified about.
|
LastValueAggFunction<T> |
Built-in LAST_VALUE aggregate function.
|
LastValueWithRetractAggFunction<T> |
Built-in LAST_VALUE with retraction aggregate function.
|
LastValueWithRetractAggFunction.LastValueWithRetractAccumulator<T> |
Accumulator for LAST_VALUE with retraction.
|
LatencyMarker |
Special record type carrying a timestamp of its creation time at a source operator and the
vertexId and subtask index of the operator.
|
LatencyStats |
The LatencyStats objects are used to track and report on the behavior of latencies across
measurements.
|
LatencyStats.Granularity |
Granularity for latency metrics.
|
LatencyTrackingStateConfig |
Config to create latency tracking state metric.
|
LatencyTrackingStateConfig.Builder |
|
LatencyTrackingStateFactory<K,N,V,S extends State,IS extends InternalKvState<K,N,?>> |
Factory to create AbstractLatencyTrackState .
|
LazyBinaryFormat<T> |
An abstract implementation fo BinaryFormat which is lazily serialized into binary or
lazily deserialized into Java object.
|
LazyMemorySegmentPool |
|
LazyTimerService |
A timer service that initializes its internal timer service lazily.
|
LeaderContender |
Interface which has to be implemented to take part in the leader election process of the LeaderElectionService .
|
LeaderElection |
LeaderElection serves as a proxy between LeaderElectionService and LeaderContender .
|
LeaderElectionDriver |
A leader election driver that allows to write LeaderInformation for multiple components.
|
LeaderElectionDriver.Listener |
|
LeaderElectionDriverFactory |
|
LeaderElectionException |
This exception is used in leader election-related scenarios.
|
LeaderElectionService |
Interface for a service which allows to elect a leader among a group of contenders.
|
LeaderElectionUtils |
LeaderElectionUtils collects helper methods to handle LeaderElection-related issues.
|
LeaderGatewayRetriever<T extends RpcGateway> |
|
LeaderInformation |
Information about leader including the confirmed leader session id and leader address.
|
LeaderInformationRegister |
A register containing the LeaderInformation for multiple contenders based on their
componentId .
|
LeaderRetrievalDriver |
|
LeaderRetrievalDriverFactory |
|
LeaderRetrievalEventHandler |
|
LeaderRetrievalException |
This exception is thrown by the LeaderRetrievalUtils when
the method retrieveLeaderGateway fails to retrieve the current leader's gateway.
|
LeaderRetrievalHandler<T extends RestfulGateway> |
SimpleChannelInboundHandler which encapsulates the leader retrieval logic for the REST
endpoints.
|
LeaderRetrievalListener |
Classes which want to be notified about a changing leader by the LeaderRetrievalService
have to implement this interface.
|
LeaderRetrievalService |
This interface has to be implemented by a service which retrieves the current leader and notifies
a listener about it.
|
LeaderRetrievalUtils |
|
LeaderRetrievalUtils.LeaderInformationListener |
Helper class which is used by the retrieveLeaderInformation method to retrieve the leader's
rpc URL and the current leader session ID.
|
LeaderRetriever |
Retrieves and stores the current leader address.
|
LeadershipLostException |
This exception is used in the scenario that the leadership is lost.
|
LeadLagAggFunction |
LEAD and LAG aggregate functions return the value of given expression evaluated at given offset.
|
LeadLagAggFunction.BooleanLeadLagAggFunction |
BooleanLeadLagAggFunction.
|
LeadLagAggFunction.ByteLeadLagAggFunction |
ByteLeadLagAggFunction.
|
LeadLagAggFunction.CharLeadLagAggFunction |
CharLeadLagAggFunction.
|
LeadLagAggFunction.DateLeadLagAggFunction |
DateLeadLagAggFunction.
|
LeadLagAggFunction.DecimalLeadLagAggFunction |
DecimalLeadLagAggFunction.
|
LeadLagAggFunction.DoubleLeadLagAggFunction |
DoubleLeadLagAggFunction.
|
LeadLagAggFunction.FloatLeadLagAggFunction |
FloatLeadLagAggFunction.
|
LeadLagAggFunction.IntLeadLagAggFunction |
IntLeadLagAggFunction.
|
LeadLagAggFunction.LongLeadLagAggFunction |
LongLeadLagAggFunction.
|
LeadLagAggFunction.ShortLeadLagAggFunction |
ShortLeadLagAggFunction.
|
LeadLagAggFunction.StringLeadLagAggFunction |
StringLeadLagAggFunction.
|
LeadLagAggFunction.TimeLeadLagAggFunction |
TimeLeadLagAggFunction.
|
LeadLagAggFunction.TimestampLeadLagAggFunction |
TimestampLeadLagAggFunction.
|
LeadLagInputTypeStrategy |
|
LeftOuterJoinDriver<IT1,IT2,OT> |
The left outer join driver implements the logic of an outer join operator at runtime.
|
LegacyInstantTypeInfo |
|
LegacyKeyedCoProcessOperator<K,IN1,IN2,OUT> |
Deprecated.
|
LegacyKeyedProcessOperator<K,IN,OUT> |
Deprecated.
|
LegacyLocalDateTimeTypeInfo |
|
LegacyRawTypeTransformation |
This type transformation transforms the LEGACY('RAW', ...) type to the RAW(..., ?)
|
LegacyScalarFunctionConvertRule |
|
LegacySerializerSnapshotTransformer<T> |
|
LegacySinkTransformation<T> |
This Transformation represents a stream Sink.
|
LegacySinkTransformationTranslator<IN> |
|
LegacySourceTransformation<T> |
This represents a Source.
|
LegacySourceTransformationTranslator<OUT> |
|
LegacyTimestampTypeInfo |
|
LegacyToNonLegacyTransformation |
|
LegacyTypeInfoDataTypeConverter |
Deprecated.
|
LegacyTypeInformationType<T> |
This type is a temporary solution to fully support the old type system stack through the new
stack.
|
LegacyUserDefinedFunctionInference |
Deprecated. |
LevelDelegation |
To delegate repetition level and definition level.
|
LevelIndexHeader |
Head level index for skip list.
|
LibraryCacheManager |
The LibraryCacheManager is responsible for creating and managing the user code class loaders.
|
LibraryCacheManager.ClassLoaderHandle |
Handle to retrieve a user code class loader for the associated job.
|
LibraryCacheManager.ClassLoaderLease |
Lease which allows to signal when the user code class loader is no longer needed.
|
LicenseChecker |
Utility for checking all things related to License and Notice files.
|
LikeType |
Like types enums.
|
LimitableBulkFormat<T,SplitT extends FileSourceSplit> |
|
LimitableTableSource<T> |
Deprecated.
|
LimitedConnectionsFileSystem |
A file system that limits the number of concurrently open input streams, output streams, and
total streams for a target file system.
|
LimitedConnectionsFileSystem.ConnectionLimitingSettings |
A simple configuration data object capturing the settings for limited connections.
|
LimitedConnectionsFileSystem.StreamTimeoutException |
A special IOException, indicating a timeout in the data output stream.
|
LimitOperator |
Operator for batch limit.
|
LimitPushDownSpec |
|
LineageDataset |
Lineage dataset represents the source or sink in the job.
|
LineageDatasetFacet |
Facet interface for dataset.
|
LineageEdge |
Lineage edge from source to sink.
|
LineageGraph |
Job lineage graph that users can get sources, sinks and relationships from lineage and manage the
relationship between jobs and tables.
|
LineageGraphUtils |
Utils for building lineage graph from transformations.
|
LineageVertex |
Lineage vertex represents the connectors in lineage graph, including source SourceLineageVertex and sink.
|
LineageVertexProvider |
Create lineage vertex for source and sink in DataStream.
|
LineBreakElement |
|
LinkedListSerializer<T> |
|
LinkedListSerializer.LinkedListSerializerSnapshot<T> |
|
LinkedOptionalMap<K,V> |
A LinkedOptionalMap is an order preserving map (like LinkedHashMap ) where keys have a
unique string name, but are optionally present, and the values are optional.
|
LinkedOptionalMap.ConsumerWithException<K,V,E extends Throwable> |
|
LinkedOptionalMap.KeyValue<K,V> |
Key-value pairs stored by the underlying map.
|
LinkedOptionalMap.MergeResult<K,V> |
|
LinkedOptionalMapSerializer |
|
LinkElement |
|
ListAccumulator<T> |
This accumulator stores a collection of objects.
|
ListAggFunction |
built-in listagg aggregate function.
|
ListAggWithRetractAggFunction |
Built-in LISTAGG with retraction aggregate function.
|
ListAggWithRetractAggFunction.ListAggWithRetractAccumulator |
Accumulator for LISTAGG with retraction.
|
ListAggWsWithRetractAggFunction |
Built-in LISTAGGWS with retraction aggregate function.
|
ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator |
Accumulator for LISTAGGWS with retraction.
|
ListCheckpointed<T extends Serializable> |
Deprecated.
|
ListCollector<T> |
A Collector that puts the collected elements into a given list.
|
ListDelimitedSerializer |
Encapsulates a logic of serialization and deserialization of a list with a delimiter.
|
ListDelimitedSerializer |
Encapsulates a logic of serialization and deserialization of a list with a delimiter.
|
ListElement |
|
ListenableCollector<T> |
A listenable collector for lookup join that can be called when an original record was collected.
|
ListenableCollector.CollectListener<T> |
An interface can listen on collecting original record.
|
ListKeyGroupedIterator<E> |
The KeyValueIterator returns a key and all values that belong to the key (share the same key).
|
ListMemorySegmentPool |
MemorySegment pool of a MemorySegment list.
|
ListMemorySegmentSource |
Simple memory segment source that draws segments from a list.
|
ListOptions |
Command line options for the LIST command.
|
ListSerializer<T> |
|
ListSerializerSnapshot<T> |
|
ListState<T> |
State interface for partitioned list state in Operations.
|
ListState<T> |
State interface for partitioned list state in Operations.
|
ListStateAdaptor<K,N,V> |
|
ListStateDeclaration<T> |
This represents a declaration of the list state.
|
ListStateDeclaration.RedistributionStrategy |
|
ListStateDescriptor<T> |
|
ListStateDescriptor<T> |
|
ListStateInputFormat<OT> |
Input format for reading operator list state.
|
ListTypeDescriptorImpl<T> |
|
ListTypeInfo<T> |
|
ListValue<V extends Value> |
Generic list base type for PACT programs that implements the Value and List interfaces.
|
ListView<T> |
|
ListViewSerializer<T> |
Deprecated. |
ListViewSerializerSnapshot<T> |
Deprecated. |
ListViewSpec |
|
ListViewTypeInfo<T> |
Deprecated. |
ListViewTypeInfoFactory<T> |
Deprecated. |
LiteralArgumentTypeStrategy |
Strategy that checks if an argument is a literal.
|
LoadBalancerService |
The service type of LoadBalancer.
|
LoadModuleOperation |
Operation to describe a LOAD MODULE statement.
|
Local |
Marks an RPC invocation for only being supported as a local invocation.
|
LocalAggCombiner |
An implementation of RecordsCombiner that accumulates input records into local
accumulators.
|
LocalAggCombiner.Factory |
|
LocalBlockLocation |
Implementation of the BlockLocation interface for a local file system.
|
LocalBufferPool |
|
LocalChangelogRegistry |
This registry is responsible for deleting changlog's local handles which are not in use.
|
LocalChangelogRegistryImpl |
|
LocalConnectionManager |
A connection manager implementation to bypass setup overhead for task managers running in local
execution mode.
|
LocalDataInputStream |
The LocalDataInputStream class is a wrapper class for a data input stream to the
local file system.
|
LocalDataOutputStream |
The LocalDataOutputStream class is a wrapper class for a data output stream to the
local file system.
|
LocalDateComparator |
This class can not extend BasicTypeComparator , because LocalDate is a Comparable of
ChronoLocalDate instead of Comparable of LocalDate.
|
LocalDateSerializer |
|
LocalDateSerializer.LocalDateSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
LocalDateTimeComparator |
This class can not extend BasicTypeComparator , because LocalDateTime is a Comparable of
ChronoLocalDateTime instead of Comparable of LocalDateTime.
|
LocalDateTimeSerializer |
|
LocalDateTimeSerializer.LocalDateTimeSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
LocalExecutor |
|
LocalExecutorFactory |
|
LocalFencedMessage<F extends Serializable,P> |
|
LocalFileStatus |
The class LocalFileStatus provides an implementation of the FileStatus
interface for the local file system.
|
LocalFileSystem |
The class LocalFileSystem is an implementation of the FileSystem interface for
the local file system of the machine where the JVM runs.
|
LocalFileSystemFactory |
|
LocalInputChannel |
An input channel, which requests a local subpartition.
|
Locality |
|
LocalityAwareSplitAssigner |
A FileSplitAssigner that assigns to each host preferably splits that are local, before
assigning splits that are not local.
|
LocallyCleanableResource |
LocallyCleanableResource is supposed to be implemented by any class that provides
artifacts for a given job that need to be cleaned up after the job reached a local terminal
state.
|
LocalOverWindow |
Local over window created during expression resolution.
|
LocalRecoverableFsDataOutputStream |
|
LocalRecoverableWriter |
|
LocalRecoveredInputChannel |
An input channel reads recovered state from previous unaligned checkpoint snapshots and then
converts into LocalInputChannel finally.
|
LocalRecoveryConfig |
This class encapsulates the completed configuration for local recovery, i.e. the root directories
into which all file-based snapshots can be written and the general mode for the local recover
feature.
|
LocalReferenceExpression |
|
LocalRpcInvocation |
Local rpc invocation message containing the remote procedure name, its parameter types and the
corresponding call arguments.
|
LocalRuntimeFilterBuilderOperator |
Local runtime filter builder operator.
|
LocalSlicingWindowAggOperator |
The operator used for local window aggregation.
|
LocalSnapshotDirectoryProvider |
Provides directories for local backup or local recovery.
|
LocalSnapshotDirectoryProviderImpl |
|
LocalStandaloneFlinkResource |
Flink resource that start local standalone clusters.
|
LocalStandaloneFlinkResourceFactory |
|
LocalStrategy |
Enumeration of all available local processing strategies tasks.
|
LocalStreamEnvironment |
The LocalStreamEnvironment is a StreamExecutionEnvironment that runs the program locally,
multi-threaded, in the JVM where the environment is instantiated.
|
LocalTimeComparator |
|
LocalTimeSerializer |
|
LocalTimeSerializer.LocalTimeSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
LocalTimeTypeInfo<T extends Temporal> |
Type information for Java LocalDate/LocalTime/LocalDateTime.
|
LocalTransportException |
|
LocalZonedTimestampInstantConverter |
|
LocalZonedTimestampIntConverter |
|
LocalZonedTimestampLongConverter |
|
LocalZonedTimestampTimestampConverter |
|
LocalZonedTimestampType |
Logical type of a timestamp WITH LOCAL time zone consisting of year-month-day
hour:minute:second[.fractional] zone with up to nanosecond precision and values ranging from
0000-01-01 00:00:00.000000000 +14:59 to 9999-12-31 23:59:59.999999999 -14:59 .
|
LocatableInputSplit |
A locatable input split is an input split referring to input data which is located on one or more
hosts.
|
LocatableInputSplitAssigner |
The locatable input split assigner assigns to each host splits that are local, before assigning
splits that are not local.
|
LocatedFileStatus |
A LocatedFileStatus is a FileStatus that contains additionally the location
information of the file directly.
|
LocatedHadoopFileStatus |
Concrete implementation of the LocatedFileStatus interface for the Hadoop Distributed
File System.
|
LocationPreferenceConstraint |
Defines the location preference constraint.
|
LocationPreferenceSlotSelectionStrategy |
|
Lockable<T> |
Implements locking logic for incoming event and SharedBufferNode using a lock reference
counter.
|
Lockable.LockableTypeSerializer<E> |
|
LockableTypeSerializerSnapshot<E> |
|
LogFileNamePathParameter |
|
LoggerAuditingExtension |
Utility for auditing logged messages.
|
LoggerOutputFormat |
A basic output format that logs all records at level INFO.
|
LogicalDistribution |
LogicalDistribution is used to represent the expected distribution of the data, similar to Hive's
SORT BY, DISTRIBUTE BY, and CLUSTER BY semantics.
|
LogicalEdge |
|
LogicalFile |
An abstraction of logical files in file-merging checkpoints.
|
LogicalFile.LogicalFileId |
|
LogicalPipelinedRegion |
Pipelined region on logical level, i.e., JobVertex level.
|
LogicalPipelinedRegionComputeUtil |
|
LogicalRelDataTypeConverter |
Symmetric converter between LogicalType and RelDataType .
|
LogicalResult |
|
LogicalScopeProvider |
Extension for metric groups that support logical scopes.
|
LogicalScriptTransform |
LogicalScriptTransform is used to represent the sql semantic "TRANSFORM c1, c2, xx USING
'script'".
|
LogicalSlot |
A logical slot represents a resource on a TaskManager into which a single task can be deployed.
|
LogicalSlot.Payload |
Payload for a logical slot.
|
LogicalSnapshot |
Sub-class of Snapshot not targeted at any particular engine
or calling convention.
|
LogicalTableScan |
A LogicalTableScan reads all the rows from a RelOptTable .
|
LogicalTopology |
Represents a logical topology, i.e.
|
LogicalType |
A logical type that describes the data type of a value.
|
LogicalTypeCasts |
|
LogicalTypeChecks |
Utilities for checking LogicalType and avoiding a lot of type casting and repetitive
work.
|
LogicalTypeDataTypeConverter |
Deprecated. |
LogicalTypeDataTypeConverter |
|
LogicalTypeDefaultVisitor<R> |
|
LogicalTypeDuplicator |
|
LogicalTypeFamily |
An enumeration of logical type families for clustering LogicalTypeRoot s into categories.
|
LogicalTypeJsonDeserializer |
|
LogicalTypeJsonSerializer |
|
LogicalTypeMerging |
|
LogicalTypeParser |
|
LogicalTypeRoot |
An enumeration of logical type roots containing static information about logical data types.
|
LogicalTypeUtils |
|
LogicalTypeVisitor<R> |
|
LogicalUnnestRule |
Planner rule that rewrites UNNEST to explode function.
|
LogicalUnnestRule.LogicalUnnestRuleConfig |
Rule configuration.
|
LogicalVertex |
|
LogInfo |
Contains information about one log of TaskManager.
|
LogLevelExtension |
A extension that sets the log level for specific class/package loggers for a test.
|
LogListInfo |
Class containing a collection of LogInfo .
|
LogUrlResponse |
Response of log URLs.
|
LogUrlUtil |
Util for log url pattern.
|
LolCache |
|
LolCacheFactory |
|
LongArrayList |
Minimal implementation of an array-backed list of longs
|
LongColumnReader |
|
LongColumnVector |
Long column vector.
|
LongComparator |
|
LongCounter |
An accumulator that sums up long values.
|
LongFunctionWithException<R,E extends Throwable> |
|
LongHashPartition |
|
LongHashPartitionChannelReaderInputViewIterator |
A simple iterator over the input read though an I/O channel.
|
LongHashSet |
Long hash set.
|
LongHybridHashTable |
Special optimized hashTable with key long.
|
LongMaximum |
An accumulator that finds the maximum long value.
|
LongMinimum |
An accumulator that finds the minimum long value.
|
LongParser |
Parses a decimal text field into a LongValue.
|
LongPrimitiveArrayComparator |
|
LongPrimitiveArraySerializer |
A serializer for long arrays.
|
LongPrimitiveArraySerializer.LongPrimitiveArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
LongSerializer |
Type serializer for Long .
|
LongSerializer.LongSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
LongSumAggregator |
|
LongValue |
Boxed serializable and comparable long integer type, representing the primitive type
long .
|
LongValueComparator |
Specialized comparator for LongValue based on CopyableValueComparator.
|
LongValueParser |
Parses a decimal text field into a LongValue.
|
LongValueSequenceIterator |
The LongValueSequenceIterator is an iterator that returns a sequence of numbers (as
LongValue )s.
|
LongValueSerializer |
|
LongValueSerializer.LongValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
LongZeroConvergence |
|
LookupableTableSource<T> |
Deprecated.
|
LookupBucketIterator |
Build iterator from bucket to match probe row.
|
LookupCache |
A semi-persistent mapping from keys to values for storing entries of lookup table.
|
LookupCacheManager |
Managing shared caches across different subtasks.
|
LookupCacheManager.RefCountedCache |
A wrapper class of LookupCache which also tracks the reference count of it.
|
LookupCallContext |
|
LookupCallExpression |
A call expression where the target function has not been resolved yet.
|
LookupCallResolver |
Resolves calls with function names to calls with actual function definitions.
|
LookupFullCache |
|
LookupFunction |
A wrapper class of TableFunction for synchronously lookup rows matching the lookup keys
from external system.
|
LookupFunctionProvider |
|
LookupJoinHintOptions |
This class holds hint option name definitions for LOOKUP join hints based on ConfigOption .
|
LookupJoinHintOptions.RetryStrategy |
Supported retry strategies.
|
LookupJoinRunner |
The join runner to lookup the dimension table.
|
LookupJoinUtil |
|
LookupJoinUtil.AsyncLookupOptions |
AsyncLookupOptions includes async related options.
|
LookupJoinUtil.ConstantLookupKey |
|
LookupJoinUtil.FieldRefLookupKey |
|
LookupJoinUtil.LookupKey |
A field used as an equal condition when querying content from a dimension table.
|
LookupJoinUtil.RetryLookupOptions |
RetryOptions includes retry lookup related options.
|
LookupJoinWithCalcRunner |
The join runner with an additional calculate function on the dimension table.
|
LookupOptions |
Predefined options for lookup table.
|
LookupOptions.LookupCacheType |
Types of the lookup cache.
|
LookupOptions.ReloadStrategy |
|
LookupRuntimeProviderContext |
|
LookupTableSource |
A DynamicTableSource that looks up rows of an external storage system by one or more keys
during runtime.
|
LookupTableSource.LookupContext |
|
LookupTableSource.LookupRuntimeProvider |
Provides actual runtime implementation for reading the data.
|
LRUMap<K,V> |
An LRU cache, based on LinkedHashMap .
|
LRUMap.RemovalListener<K,V> |
An object that can receive a notification when an entry is removed from a LRUMap.
|
Lz4BlockCompressionFactory |
|
Lz4BlockCompressor |
Encode data into LZ4 format (not compatible with the LZ4 Frame format).
|
Lz4BlockDecompressor |
|
Mail |
An executable bound to a specific operator in the chain, such that it can be picked for
downstream mailbox.
|
MailboxDefaultAction |
Interface for the default action that is repeatedly invoked in the mailbox-loop.
|
MailboxDefaultAction.Controller |
This controller is a feedback interface for the default action to interact with the mailbox
execution.
|
MailboxDefaultAction.Suspension |
|
MailboxExecutor |
Executor like interface for a build around a mailbox-based execution
model.
|
MailboxExecutor.MailOptions |
Extra options to configure enqueued mails.
|
MailboxExecutorFactory |
A factory for creating mailbox executors with a given priority.
|
MailboxExecutorImpl |
Implementation of an executor service build around a mailbox-based execution model.
|
MailboxMetricsController |
Mailbox metrics controller class.
|
MailboxProcessor |
This class encapsulates the logic of the mailbox-based execution model.
|
MailboxProcessor.MailboxController |
|
MailboxWatermarkProcessor<OUT> |
A helper class to let operators emit watermarks incrementally from mailbox.
|
MailOptionsImpl |
Options to configure behaviour of executing mailbox mails.
|
MainThreadExecutable |
Interface to execute Runnable and Callable in the main thread of the underlying
RPC endpoint.
|
MainThreadValidatorUtil |
This utility exists to bridge between the visibility of the currentMainThread field in
the RpcEndpoint .
|
MalformedPatternException |
An exception used to indicate that a Pattern was not
specified correctly.
|
ManagedInitializationContext |
This interface provides a context in which operators can initialize by registering to managed
state (i.e. state that is managed by state backends).
|
ManagedMemoryUseCase |
Use cases of managed memory.
|
ManagedMemoryUseCase.Scope |
Scope at which memory is managed for a use case.
|
ManagedMemoryUtils |
Utils for configuration and calculations related to managed memory and its various use cases.
|
ManagedSnapshotContext |
This interface provides a context in which operators that use managed state (i.e. state that is
managed by state backends) can perform a snapshot.
|
ManagedTableFactory |
Deprecated.
|
ManagedTableListener |
Deprecated.
|
ManualClock |
A Clock implementation which allows to advance time manually.
|
ManuallyTriggeredScheduledExecutorService |
|
ManuallyTriggeredScheduledExecutorService.RunnableCaller<T> |
|
MapBundleFunction<K,V,IN,OUT> |
Basic interface for map bundle processing.
|
MapBundleOperator<K,V,IN,OUT> |
|
MapColumnVector |
Map column vector.
|
MapData |
|
MapDataSerializer |
|
MapDataSerializer |
|
MapDataSerializer.BaseMapSerializerSnapshot |
|
MapDataSerializer.MapDataSerializerSnapshot |
|
MapDataUtil |
|
MapDriver<IT,OT> |
Map task which is executed by a Task Manager.
|
MapEntriesFunction |
|
MapFromArraysFunction |
|
MapFunction<T,O> |
Base interface for Map functions.
|
MapKeysFunction |
|
MapMapConverter<K,V> |
|
MapOperatorBase<IN,OUT,FT extends MapFunction<IN,OUT>> |
|
MapPartitionDriver<IT,OT> |
MapPartition task which is executed by a Task Manager.
|
MapPartitionFunction<T,O> |
Interface for "mapPartition" functions.
|
MapPartitionIterator<IN> |
|
MapPartitionOperator<IN,OUT> |
|
MapPartitionOperatorBase<IN,OUT,FT extends MapPartitionFunction<IN,OUT>> |
|
MappingBasedRepartitioner<T> |
A repartitioner that assigns the same channel state to multiple subtasks according to some
mapping.
|
MappingTypeStrategy |
|
MapSerializer<K,V> |
|
MapSerializerSnapshot<K,V> |
|
MapState<UK,UV> |
State interface for partitioned key-value state.
|
MapState<UK,UV> |
State interface for partitioned key-value state.
|
MapStateAdaptor<K,N,UK,UV> |
|
MapStateDeclaration<K,V> |
This represents a declaration of the map state.
|
MapStateDescriptor<UK,UV> |
|
MapStateDescriptor<UK,UV> |
|
MapType |
Logical type of an associative array that maps keys (including NULL ) to values (including
NULL ).
|
MapTypeDescriptorImpl<K,V> |
|
MapTypeInfo<K,V> |
|
MapUnionFunction |
|
MapValue<K extends Value,V extends Value> |
Generic map base type for PACT programs that implements the Value and Map interfaces.
|
MapValuesFunction |
|
MapView<K,V> |
|
MapViewSerializer<K,V> |
Deprecated. |
MapViewSerializerSnapshot<K,V> |
Deprecated. |
MapViewSpec |
|
MapViewTypeInfo<K,V> |
Deprecated. |
MapViewTypeInfoFactory<K,V> |
Deprecated. |
MapWriter<T> |
|
MapWriter.MapWriterForArray |
|
MapWriter.MapWriterForRow |
|
MarkPartitionFinishedStrategy |
This strategy is used to decide whether partition needs to be marked as finished.
|
MaskUtils |
Utilities for reading and writing binary masks.
|
MasterHooks |
Collection of methods to deal with checkpoint master hooks.
|
MasterState |
Simple encapsulation of state generated by checkpoint coordinator.
|
MasterTriggerRestoreHook<T> |
The interface for hooks that can be called by the checkpoint coordinator when triggering or
restoring a checkpoint.
|
MasterTriggerRestoreHook.Factory |
A factory to instantiate a MasterTriggerRestoreHook .
|
MatchFamilyTypeStrategy |
Type strategy that returns the given argument if it is of the same logical type family.
|
MatchRowTimeFunction |
The function used to access a rowtime attribute with TIMESTAMP or TIMESTAMP_LTZ type from
MATCH_RECOGNIZE clause.
|
MatchSpec |
MatchSpec describes the MATCH_RECOGNIZE info, see Match .
|
MaterializationExpiredException |
|
MaterializedCollectBatchResult |
Collects results and returns them as table snapshots.
|
MaterializedCollectResultBase |
Base class to collect results and returns them as table snapshots.
|
MaterializedCollectStreamResult |
Collects results and returns them as table snapshots.
|
MaterializedResult |
A result that is materialized and can be viewed by navigating through a snapshot.
|
MaterializedTableConfigOptions |
This class holds ConfigOption s used by table module for
materialized table.
|
MaterializedTableIdentifierPathParameter |
|
MaterializedTableManager |
|
MaterializedTableOperation |
The marker interface for materialized table.
|
MaterializedTableUtils |
The utils for materialized table.
|
MathUtils |
Collection of simple mathematical routines.
|
MatrixVectorMul |
Implements the matrix-vector multiplication program that shows how to use GPU resources in Flink.
|
MaxAggFunction |
built-in max aggregate function.
|
MaxAggFunction.BooleanMaxAggFunction |
Built-in Boolean Max aggregate function.
|
MaxAggFunction.ByteMaxAggFunction |
Built-in Byte Max aggregate function.
|
MaxAggFunction.DateMaxAggFunction |
Built-in Date Max aggregate function.
|
MaxAggFunction.DecimalMaxAggFunction |
Built-in Decimal Max aggregate function.
|
MaxAggFunction.DoubleMaxAggFunction |
Built-in Double Max aggregate function.
|
MaxAggFunction.FloatMaxAggFunction |
Built-in Float Max aggregate function.
|
MaxAggFunction.IntMaxAggFunction |
Built-in Int Max aggregate function.
|
MaxAggFunction.LongMaxAggFunction |
Built-in Long Max aggregate function.
|
MaxAggFunction.ShortMaxAggFunction |
Built-in Short Max aggregate function.
|
MaxAggFunction.StringMaxAggFunction |
Built-in String Max aggregate function.
|
MaxAggFunction.TimeMaxAggFunction |
Built-in Time Max aggregate function.
|
MaxAggFunction.TimestampLtzMaxAggFunction |
Built-in TimestampLtz Max aggregate function.
|
MaxAggFunction.TimestampMaxAggFunction |
Built-in Timestamp Max aggregate function.
|
MaxwellJsonDecodingFormat |
|
MaxwellJsonDeserializationSchema |
Deserialization schema from Maxwell JSON to Flink Table/SQL internal data structure RowData .
|
MaxwellJsonFormatFactory |
|
MaxwellJsonFormatOptions |
Option utils for maxwell-json format.
|
MaxwellJsonSerializationSchema |
Serialization schema from Flink Table/SQL internal data structure RowData to
maxwell-Json.
|
MaxWithRetractAggFunction<T extends Comparable<T>> |
Built-in MAX with retraction aggregate function.
|
MaxWithRetractAggFunction.MaxWithRetractAccumulator<T> |
Accumulator for MAX with retraction.
|
MdcUtils |
Utility class to manage common Flink attributes in MDC (only JobID ATM).
|
MdcUtils.MdcCloseable |
|
MemberFieldRewriter |
Group member variables with the same type into arrays to reduce the number of members.
|
MemCheckpointStreamFactory |
|
MemCheckpointStreamFactory.MemoryCheckpointOutputStream |
A CheckpointStateOutputStream that writes into a byte array.
|
MemoryAllocationException |
An exception to be thrown when a memory allocation operation is not successful.
|
MemoryBackendCheckpointStorageAccess |
|
MemoryBlockIterator |
The memory block iterator is an iterator that always buffers a block of elements in memory.
|
MemoryExecutionGraphInfoStore |
|
MemoryLogger |
A thread the periodically logs statistics about:
Heap and non-heap memory usage
Memory pools and pool usage
Garbage collection times and counts
|
MemoryManager |
The memory manager governs the memory that Flink uses for sorting, hashing, caching or off-heap
state backends (e.g.
|
MemoryReservationException |
An exception to be thrown when a memory reservation operation is not successful.
|
MemorySegment |
This class represents a piece of memory managed by Flink.
|
MemorySegmentFactory |
|
MemorySegmentInputStreamWithPos |
Un-synchronized input stream using the given memory segment.
|
MemorySegmentPool |
MemorySegment pool to hold pages in memory.
|
MemorySegmentProvider |
The provider used for requesting and releasing batch of memory segments.
|
MemorySegmentSource |
Interface describing entities that can provide memory segments.
|
MemorySegmentWritable |
Provides the interface for write(Segment).
|
MemorySize |
MemorySize is a representation of a number of bytes, viewable in different units.
|
MemorySize.MemoryUnit |
Enum which defines memory unit, mostly used to parse value from configuration file.
|
MemoryTierConsumerAgent |
The data client is used to fetch data from memory tier.
|
MemoryTierFactory |
|
MemoryTierProducerAgent |
|
MemoryUtils |
Utility class for memory operations.
|
MergeCallback<W,R> |
Callback to be used in when merging slices or windows for specifying which slices or windows
should be merged.
|
MergeIterator<E> |
An iterator that returns a sorted merge of the sequences of elements from a set of iterators,
assuming those sequences are ordered themselves.
|
MergeOperatorStates |
|
MergeTableAsUtil |
A utility class with logic for handling the CREATE TABLE ... AS SELECT clause.
|
MergingState<IN,OUT> |
|
MergingState<IN,OUT,SYNCOUT> |
|
MergingStateAdaptor<K,N,IN,ACC,OUT,SYNCOUT> |
|
MergingWindowAssigner<T,W extends Window> |
A WindowAssigner that can merge windows.
|
MergingWindowAssigner<W extends Window> |
A WindowAssigner that can merge windows.
|
MergingWindowAssigner.MergeCallback<W> |
|
MergingWindowProcessFunction<K,W extends Window> |
|
MergingWindowProcessFunction.DefaultAccMergingConsumer<W extends Window> |
A default merging consumer that merges the accumulators in state windows that waiting to be
merged into the target state window.
|
MergingWindowProcessFunction.MergingContext<K,W extends Window> |
|
MergingWindowSet<W extends Window> |
|
MergingWindowSet<W extends Window> |
|
MergingWindowSet.MergeFunction<W> |
|
MergingWindowSet.MergeFunction<W> |
|
Message |
Marker interface for all Flink RPC related messages.
|
MessageBody |
The base class for every message exchanged during the communication between client and server .
|
MessageDeserializer<M extends MessageBody> |
A utility used to deserialize a message .
|
MessageHeaders<R extends RequestBody,P extends ResponseBody,M extends MessageParameters> |
|
MessageParameter<X> |
This class represents a single path/query parameter that can be used for a request.
|
MessageParameter.MessageParameterRequisiteness |
Enum for indicating whether a parameter is mandatory or optional.
|
MessageParameters |
This class defines the path/query MessageParameter s that can be used for a request.
|
MessagePathParameter<X> |
This class represents path parameters of a request.
|
MessageQueryParameter<X> |
This class represents query parameters of a request.
|
MessageSerializer<REQ extends MessageBody,RESP extends MessageBody> |
Serialization and deserialization of messages exchanged between client and server .
|
MessageType |
Expected message types during the communication between client and server .
|
MetadataOutputStreamWrapper |
The wrapper manages metadata output stream close and commit.
|
MetadataSerializer |
Deserializer for checkpoint metadata.
|
MetadataSerializers |
|
MetadataV1Serializer |
Deserializer for checkpoints written in format 1 (Flink 1.2.x format).
|
MetadataV2Serializer |
(De)serializer for checkpoint metadata format version 2.
|
MetadataV2V3SerializerBase |
Base (De)serializer for checkpoint metadata format version 2 and 3.
|
MetadataV2V3SerializerBase.DeserializationContext |
A context that keeps information needed during serialization.
|
MetadataV3Serializer |
(De)serializer for checkpoint metadata format version 3.
|
MetadataV4Serializer |
|
MetadataV5Serializer |
V5 serializer that adds Operator name and uid.
|
MetastoreCommitPolicy |
Partition commit policy to update metastore.
|
Meter |
Metric for measuring throughput.
|
MeterView |
A MeterView provides an average rate of events per second over a given time period.
|
Metric |
Common super interface for all metrics.
|
Metric |
Response type for a Metric and Metric-Value-Pair.
|
MetricAssertions |
This class provides access to AssertJ assertions for Metric s.
|
MetricAssertions.CounterAssert |
This class provides AssertJ assertions for Counter s.
|
MetricAssertions.GaugeAssert<T> |
This class provides AssertJ assertions for Gauge s.
|
MetricCollectionResponseBody |
Response type for a collection of metrics.
|
MetricCollectionResponseBody.Deserializer |
|
MetricCollectionResponseBody.Serializer |
|
MetricConfig |
A properties class with added utility method to extract primitives.
|
MetricDistribution |
Flink Gauge for Python Distribution.
|
MetricDump |
A container for a dumped metric that contains the scope, name and value(s) of the metric.
|
MetricDump.CounterDump |
Container for the value of a Counter .
|
MetricDump.GaugeDump |
Container for the value of a Gauge as a string.
|
MetricDump.HistogramDump |
|
MetricDump.MeterDump |
Container for the rate of a Meter .
|
MetricDumpSerialization |
Utility class for the serialization of metrics.
|
MetricDumpSerialization.MetricDumpDeserializer |
|
MetricDumpSerialization.MetricDumpSerializer |
|
MetricDumpSerialization.MetricSerializationResult |
This class encapsulates all serialized metrics and a count for each metric type.
|
MetricFetcher |
The MetricFetcher can be used to fetch metrics from the JobManager and all registered
TaskManagers.
|
MetricFetcherImpl<T extends RestfulGateway> |
|
MetricFilter |
A filter for metrics.
|
MetricGauge |
Flink Gauge for Python Gauge.
|
MetricGroup |
A MetricGroup is a named container for Metrics and further metric subgroups.
|
MetricListener |
A MetricListener listens metric and group registration under the provided root metric group, and
stores them in an internal HashMap for fetching.
|
MetricMetadata |
Metadata associated with a given metric, stored alongside it so that it can be provided during
reporting time.
|
MetricMetaData |
All metadata associated with a given metric.
|
MetricNames |
Collection of metric names.
|
MetricOptions |
Configuration options for metrics and metric reporters.
|
MetricOptions.JobStatusMetrics |
Enum describing the different kinds of job status metrics.
|
MetricOptions.JobStatusMetricsSettings |
Describes which job status metrics have been enabled.
|
MetricQuerier |
The querier used to get job metrics by rest API.
|
MetricQueryService |
The MetricQueryService creates a key-value representation of all metrics currently registered
with Flink when queried.
|
MetricQueryServiceGateway |
|
MetricQueryServiceRetriever |
|
MetricRegistry |
Interface for a metric registry.
|
MetricRegistryConfiguration |
|
MetricRegistryImpl |
A MetricRegistry keeps track of all registered Metrics .
|
MetricReporter |
Metric reporters are used to export Metrics to an external backend.
|
MetricReporterFactory |
|
MetricsAggregationParameter |
TODO: add javadoc.
|
MetricsAggregationParameter.AggregationMode |
The available aggregations.
|
MetricsFilterParameter |
|
MetricsRegistrar |
A component that can register metrics.
|
MetricStore |
Nested data-structure to store metrics.
|
MetricStore.ComponentMetricStore |
Structure containing metrics of a single component.
|
MetricStore.SubtaskMetricStore |
Sub-structure containing metrics of a single subtask.
|
MetricStore.TaskManagerMetricStore |
Sub-structure containing metrics of a single TaskManager.
|
MetricStore.TaskMetricStore |
Sub-structure containing metrics of a single Task.
|
MetricType |
Metric types supported by Datadog.
|
MetricType |
Enum describing the different metric types.
|
MetricUtils |
Utility class to register pre-defined metric sets.
|
MigrationTest |
Interface for state migration tests.
|
MigrationTest.ParameterizedSnapshotsGenerator |
Marks a method as parameterized snapshots generator.
|
MigrationTest.SnapshotsGenerator |
Marks a method as snapshots generator.
|
MigrationTestsSnapshotGenerator |
This class aims to generate the snapshots for all the state migration tests.
|
MimeTypes |
Simple utility class that resolves file extensions to MIME types.
|
MinAggFunction |
built-in min aggregate function.
|
MinAggFunction.BooleanMinAggFunction |
Built-in Boolean Min aggregate function.
|
MinAggFunction.ByteMinAggFunction |
Built-in Byte Min aggregate function.
|
MinAggFunction.DateMinAggFunction |
Built-in Date Min aggregate function.
|
MinAggFunction.DecimalMinAggFunction |
Built-in Decimal Min aggregate function.
|
MinAggFunction.DoubleMinAggFunction |
Built-in Double Min aggregate function.
|
MinAggFunction.FloatMinAggFunction |
Built-in Float Min aggregate function.
|
MinAggFunction.IntMinAggFunction |
Built-in Int Min aggregate function.
|
MinAggFunction.LongMinAggFunction |
Built-in Long Min aggregate function.
|
MinAggFunction.ShortMinAggFunction |
Built-in Short Min aggregate function.
|
MinAggFunction.StringMinAggFunction |
Built-in String Min aggregate function.
|
MinAggFunction.TimeMinAggFunction |
Built-in Time Min aggregate function.
|
MinAggFunction.TimestampLtzMinAggFunction |
Built-in TimestampLtz Min aggregate function.
|
MinAggFunction.TimestampMinAggFunction |
Built-in Timestamp Min aggregate function.
|
MiniBatchGlobalGroupAggFunction |
Aggregate Function used for the global groupby (without window) aggregate in miniBatch mode.
|
MiniBatchGroupAggFunction |
Aggregate Function used for the groupby (without window) aggregate in miniBatch mode.
|
MiniBatchIncrementalGroupAggFunction |
Aggregate Function used for the incremental groupby (without window) aggregate in miniBatch mode.
|
MiniBatchInterval |
The pojo class that describes the mini-batch interval and mini-batch mode.
|
MiniBatchLocalGroupAggFunction |
Aggregate Function used for the local groupby (without window) aggregate in miniBatch mode.
|
MiniBatchMode |
The type of mini-batch interval: rowtime or proctime.
|
MiniBatchStreamingJoinOperator |
Streaming unbounded Join base operator which support mini-batch join.
|
MinibatchUtil |
Utility class for mini-batch related config.
|
MiniCluster |
MiniCluster to execute Flink jobs locally.
|
MiniCluster.CommonRpcServiceFactory |
Factory which returns always the common RpcService .
|
MiniCluster.HaServices |
HA Services to use.
|
MiniCluster.RpcServiceFactory |
|
MiniClusterClient |
|
MiniClusterClient.MiniClusterId |
|
MiniClusterConfiguration |
|
MiniClusterConfiguration.Builder |
Builder for the MiniClusterConfiguration.
|
MiniClusterExtension |
|
MiniClusterJobClient |
|
MiniClusterJobClient.JobFinalizationBehavior |
|
MiniClusterPipelineExecutorServiceLoader |
|
MiniClusterTestEnvironment |
Test environment for running jobs on Flink mini-cluster.
|
MiniClusterWithClientResource |
Starts a Flink mini cluster as a resource and registers the StreamExecutionEnvironment.
|
MiniDispatcher |
|
MiniDispatcherRestEndpoint |
|
MinWatermarkGauge |
|
MinWithRetractAggFunction<T extends Comparable<T>> |
Built-in MIN with retraction aggregate function.
|
MinWithRetractAggFunction.MinWithRetractAccumulator<T> |
Accumulator for MIN with retraction.
|
MissingTypeInfo |
A special type information signifying that the type extraction failed.
|
MissingTypeStrategy |
Placeholder for a missing type strategy.
|
ModelAlreadyExistException |
Exception for trying to create a model that already exists.
|
ModelNotExistException |
Exception for trying to operate on a model that doesn't exist.
|
ModifiableClusterConfiguration |
Configuration class which contains the parsed command line arguments for the ClusterEntrypoint .
|
ModifiableClusterConfigurationParserFactory |
A class can be used to extract the configuration from command line and modify it.
|
ModifyKind |
Lists all kinds of modify operations that happen in a changelog.
|
ModifyKindSet |
The set of modify operations contained in a changelog.
|
ModifyKindSet.Builder |
|
ModifyOperation |
A Operation that describes the DML queries such as e.g.
|
ModifyOperationVisitor<T> |
Class that implements visitor pattern.
|
ModifyRefreshWorkflow<T extends RefreshHandler> |
|
ModifyType |
The type of sink modification.
|
Module |
Modules define a set of metadata, including functions, user defined types, operators, rules, etc.
|
ModuleEntry |
A POJO to represent a module's name and use status.
|
ModuleException |
Exception related to modules.
|
ModuleFactory |
A factory to create configured module instances based on string-based properties.
|
ModuleFactory.Context |
Context provided when a module is created.
|
ModuleManager |
Responsible for loading/unloading modules, managing their life cycles, and resolving module
objects.
|
MountSecretsDecorator |
Support mounting Secrets on the JobManager or TaskManager pod..
|
MultiInputSortingDataInput<IN,K> |
An input that wraps an underlying input and sorts the incoming records.
|
MultiInputSortingDataInput.SelectableSortingInputs |
A wrapper that combines sorting inputs with a InputSelectable
that should be used to choose which input to consume next from.
|
MultiInputTransformationTranslator<OUT> |
|
MultipartRoutes |
|
MultipartRoutes.Builder |
|
MultipleConnectedStreams |
|
MultipleExecNodeMetadata |
|
MultipleFuturesAvailabilityHelper |
This class is semi-thread safe.
|
MultipleInputNodeCreationProcessor |
|
MultipleInputSelectionHandler |
|
MultipleInputStreamOperator<OUT> |
Interface for stream operators with multiple Input s.
|
MultipleInputStreamOperatorBase |
|
MultipleInputStreamTask<OUT> |
|
MultipleInputTransformation<OUT> |
|
MultipleJobsDetails |
An actor messages describing details of various jobs.
|
MultipleParameterTool |
This class provides simple utility methods for reading and parsing program arguments from
different sources.
|
MultipleProgramsTestBase |
Base class for unit tests that run multiple tests and want to reuse the same Flink cluster.
|
MultipleProgramsTestBase.TestExecutionMode |
Enum that defines which execution environment to run the next test on: An embedded local
flink cluster, or the collection execution backend.
|
MultipleProgramsTestBaseJUnit4 |
Deprecated.
|
MultipleProgramsTestBaseJUnit4.TestExecutionMode |
Enum that defines which execution environment to run the next test on: An embedded local
flink cluster, or the collection execution backend.
|
MultipleRecordWriters<T extends IOReadableWritable> |
The specific delegate implementation for the multiple outputs case.
|
MultipleTransformationTranslator<T> |
|
MultisetType |
Logical type of a multiset (=bag).
|
MultisetTypeInfo<T> |
|
MultiShotLatch |
Latch for synchronizing parts of code in tests.
|
MultiStateKeyIterator<K> |
An iterator for reading all keys in a state backend across multiple partitioned states.
|
MurmurHashUtil |
Murmur hasher.
|
MutableByteArrayInputStream |
An extension of the ByteArrayInputStream that allows to change a buffer that should be read
without creating a new ByteArrayInputStream instance.
|
MutableConfig |
|
MutableHashTable<BT,PT> |
An implementation of a Hybrid Hash Join.
|
MutableHashTable.HashBucketIterator<BT,PT> |
|
MutableHashTable.ProbeIterator<PT> |
|
MutableHashTable.UnmatchedBuildIterator<BT,PT> |
Iterate all the elements in memory which has not been probed during probe phase.
|
MutableIOMetrics |
This class is a mutable version of the IOMetrics class that allows adding up IO-related
metrics.
|
MutableObjectIterator<E> |
A simple iterator interface.
|
MutableReader<T extends IOReadableWritable> |
A record-oriented reader for mutable record types.
|
MutableRecordAndPosition<E> |
|
MutableRecordReader<T extends IOReadableWritable> |
Implementation of the record-oriented reader for mutable record types.
|
MutableURLClassLoader |
URL class loader that exposes the `addURL` method in URLClassLoader.
|
MutableVertexAttemptNumberStore |
|
MutableVertexParallelismStore |
|
MutatedConfigurationException |
|
NamedWindowProperty |
Deprecated.
|
NamespaceAggsHandleFunction<N> |
The base class for handling aggregate functions with namespace.
|
NamespaceAggsHandleFunctionBase<N> |
The base class for handling aggregate or table aggregate functions.
|
NamespaceTableAggsHandleFunction<N> |
The base class for handling table aggregate functions with namespace.
|
NestedColumnReader |
This ColumnReader mainly used to read `Group` type in parquet such as `Map`, `Array`, `Row`.
|
NestedFieldReferenceExpression |
A reference to a nested field in an input.
|
NestedFieldsProjectableTableSource<T> |
Deprecated.
|
NestedPositionUtil |
Utils to calculate nested type position.
|
NestedPrimitiveColumnReader |
Reader to read nested primitive column.
|
NestedPrimitiveColumnReader.NullIntIterator |
Reading zero always.
|
NestedPrimitiveColumnReader.RLEIntIterator |
Reading int from RunLengthBitPackingHybridDecoder .
|
NestedPrimitiveColumnReader.ValuesReaderIntIterator |
Reading int from ValuesReader .
|
NestedRowData |
Its memory storage structure is exactly the same with BinaryRowData .
|
NestedSerializersSnapshotDelegate |
A NestedSerializersSnapshotDelegate represents the snapshots of multiple serializers that are
used by an outer serializer.
|
NettyBufferPool |
Wrapper around Netty's PooledByteBufAllocator with strict control over the number of
created arenas.
|
NettyBufferPool |
Extends around Netty's PooledByteBufAllocator with strict control over the number of
created arenas.
|
NettyConfig |
|
NettyConnectionId |
|
NettyConnectionManager |
|
NettyConnectionReader |
|
NettyConnectionReaderImpl |
|
NettyConnectionWriter |
|
NettyConnectionWriterImpl |
|
NettyMessage |
A simple and generic interface to serialize messages to Netty's buffer space.
|
NettyMessageClientDecoderDelegate |
Decodes messages from the received netty buffers.
|
NettyPartitionRequestClient |
Partition request client for remote partition requests.
|
NettyPartitionRequestListener |
|
NettyPayload |
The NettyPayload represents the payload that will be transferred to netty connection.
|
NettyPayloadManager |
|
NettyProtocol |
Defines the server and client channel handlers, i.e. the protocol, used by netty.
|
NettyServiceProducer |
|
NettyShuffleDescriptor |
|
NettyShuffleDescriptor.LocalExecutionPartitionConnectionInfo |
Local partition connection information.
|
NettyShuffleDescriptor.NetworkPartitionConnectionInfo |
Remote partition connection information with index to query partition.
|
NettyShuffleDescriptor.PartitionConnectionInfo |
Information for connection to partition producer for shuffle exchange.
|
NettyShuffleEnvironment |
The implementation of ShuffleEnvironment based on netty network communication, local
memory and disk files.
|
NettyShuffleEnvironmentConfiguration |
Configuration object for the network stack.
|
NettyShuffleEnvironmentOptions |
The set of configuration options relating to network stack.
|
NettyShuffleEnvironmentOptions.CompressionCodec |
Supported compression codec.
|
NettyShuffleMaster |
Default ShuffleMaster for netty and local file based shuffle implementation.
|
NettyShuffleMemoryControlTestProgram |
Test program to verify the direct memory consumption of Netty.
|
NettyShuffleMetricFactory |
Factory for netty shuffle service metrics.
|
NettyShuffleServiceFactory |
Netty based shuffle service implementation.
|
NettyShuffleUtils |
Utils to calculate network memory requirement of a vertex from network configuration and details
of input and output.
|
NetUtils |
Utility for various network related tasks (such as finding free ports).
|
NetUtils.Port |
Port wrapper class which holds a FileLock until it releases.
|
NetUtils.SocketFactory |
A factory for a local socket from port number.
|
NetworkActionsLogger |
Utility class for logging actions that happened in the network stack for debugging purposes.
|
NetworkBuffer |
|
NetworkBufferPool |
The NetworkBufferPool is a fixed size pool of MemorySegment instances for the network
stack.
|
NetworkClientHandler |
Channel handler to read and write network messages on client side.
|
NetworkSequenceViewReader |
Simple wrapper for the partition readerQueue iterator, which increments a sequence number for
each returned buffer and remembers the receiver ID.
|
NeverCompleteFuture |
A future that never completes.
|
NeverFireProcessingTimeService |
A processing time service whose timers never fire so all timers are included in savepoints.
|
NFA<T> |
Non-deterministic finite automaton implementation.
|
NFACompiler |
|
NFACompiler.NFAFactory<T> |
Factory interface for NFA .
|
NFAState |
|
NFAStateNameHandler |
A utility class used to handle name conventions and guarantee unique names for the states of our
NFA .
|
NFAStateSerializer |
|
NFAStateSerializerSnapshot |
|
NoCompressionBulkWriter<T> |
A BulkWriter implementation that does not compress data.
|
NodeId |
|
NodeId.NodeIdSerializer |
|
NodeId.NodeIdSerializer.NodeIdSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
NodePortService |
The service type of NodePort.
|
NodeStatus |
Status of the node.
|
NoFetchingInput |
|
NoHivePhysicalWriterImpl |
Protobuf is relocated in orc-core-nohive, therefore method calls involving PB classes need to use
the relocated class names here.
|
NoMatchingTableFactoryException |
Deprecated.
|
NoMatchingTableFactoryException |
Exception for not finding a TableFactory for the given properties.
|
NoMatchSecurityFactoryException |
Exception for not finding suitable security factories.
|
NoMoreSplitsEvent |
A source event sent from the SplitEnumerator to the SourceReader to indicate that no more splits
will be assigned to the source reader anymore.
|
NonBlockingPhysicalFilePool |
A Non-Blocking PhysicalFilePool which will always provide usable physical file without
blocking.
|
NonBufferOverWindowOperator |
The operator for OVER window don't need cache data.
|
NonChainedOutput |
Used by operator chain and represents a non-chained output of the corresponding stream operator.
|
NonClosingCheckpointOutputStream<T extends StreamStateHandle> |
Abstract class to implement custom checkpoint output streams which should not be closable for
user code.
|
NonClosingInputStreamDecorator |
|
NonClosingOutputStreamDecorator |
|
NonDeterministicUpdateAnalyzer |
|
NonKeyedPartitionStream<T> |
This interface represents a kind of partitioned data stream.
|
NonKeyedPartitionStream.ProcessConfigurableAndNonKeyedPartitionStream<T> |
|
NonKeyedPartitionStream.ProcessConfigurableAndTwoNonKeyedPartitionStream<OUT1,OUT2> |
|
NonKeyedPartitionStreamImpl<T> |
|
NonKeyedPartitionWindowedStream<T> |
|
NonLeaderRetrievalRestfulGateway |
* Gateway for restful endpoints without leader retrieval logic. * *
|
NonParallelInput |
This interface acts as a marker for input formats for inputs which cannot be split.
|
NonPartitionedContext<OUT> |
This interface represents the context associated with all operations must be applied to all
partitions.
|
NonPersistentMetadataCheckpointStorageLocation |
|
NonPojo |
Simple type that needs to go through Kryo for serialization.
|
NonPojoSerializer |
|
NonRecordWriter<T extends IOReadableWritable> |
The specific delegate implementation for the non output case like sink task.
|
NonReusingBlockResettableIterator<T> |
Implementation of an iterator that fetches a block of data into main memory and offers resettable
access to the data in that block.
|
NonReusingBuildFirstHashJoinIterator<V1,V2,O> |
An implementation of the JoinTaskIterator that
uses a hybrid-hash-join internally to match the records with equal key.
|
NonReusingBuildFirstReOpenableHashJoinIterator<V1,V2,O> |
|
NonReusingBuildSecondHashJoinIterator<V1,V2,O> |
An implementation of the JoinTaskIterator that
uses a hybrid-hash-join internally to match the records with equal key.
|
NonReusingBuildSecondReOpenableHashJoinIterator<V1,V2,O> |
|
NonReusingDeserializationDelegate<T> |
|
NonReusingKeyGroupedIterator<E> |
The key grouped iterator returns a key and all values that share the same key.
|
NonReusingMergeInnerJoinIterator<T1,T2,O> |
|
NonReusingMergeOuterJoinIterator<T1,T2,O> |
|
NonReusingMutableToRegularIteratorWrapper<T> |
|
NonReusingSortMergeCoGroupIterator<T1,T2> |
|
NonSerializableUserCodeException |
An special case of the InvalidProgramException , indicating that a part of the program
that needs to be serializable (for shipping) is not serializable.
|
NonSplittingRecursiveAllDirEnumerator |
This FileEnumerator enumerates all files under the given paths recursively except the
hidden directories.
|
NonSplittingRecursiveEnumerator |
This FileEnumerator enumerates all files under the given paths recursively.
|
NonSupportedResourceAllocatorImpl |
ResourceAllocator that not support to allocate/release resources.
|
NoOpBlocklistHandler |
|
NoOpBlocklistHandler.Factory |
|
NoOpChainedDriver<IT> |
A chained driver that just passes on the input as the output
|
NoOpCheckpointStatsTracker |
|
NoOpDeclareResourceRequirementServiceConnectionManager |
|
NoOpDelegationTokenManager |
|
NoOpDispatcherBootstrap |
|
NoOpDriver<T> |
A driver that does nothing but forward data from its input to its output.
|
NoOpEnumerator |
Mock enumerator.
|
NoOpEnumState |
Mock enumerator state.
|
NoOpEnumStateSerializer |
Mock enumerator state serializer.
|
NoOpExecutionDeploymentListener |
|
NoOpExecutionPlanStoreWatcher |
|
NoOpFunction |
|
NoOpHeartbeatManager<I,O> |
|
NoOpHeartbeatServices |
|
NoOpMasterAgent |
|
NoOpMetricRegistry |
Metric registry which does nothing.
|
NoOpRateLimiter |
A convenience implementation of RateLimiter that does not throttle requests.
|
NoOpResultSubpartitionView |
|
NoOpScalingStrategy<T> |
NoOpScalingStrategy does not scale up / down the given value.
|
NoOpSecurityContext |
A security context that simply runs a Callable without performing a login action.
|
NoOpSecurityContextFactory |
|
NoOpSlotAllocationSnapshotPersistenceService |
|
NoOpTaskActions |
A dummy implementation of the TaskActions which is mainly used for tests.
|
NoOpTaskLocalStateStoreImpl |
This class implements a TaskLocalStateStore with no functionality and is used when local
recovery is disabled.
|
NoOpTestExtension |
A special TestTemplateInvocationContextProvider that return default TestTemplateInvocationContext .
|
NoOpTierShuffleDescriptor |
|
NoOpTimestampsAndWatermarks<T> |
|
NoOutputUntilEndOfInput |
|
NopOperation |
An Operation to represent that nothing needs to be done.
|
NoResourceAvailableException |
Indicates resource allocation failures.
|
NoRestartBackoffTimeStrategy |
Restart strategy which does not restart tasks when tasks fail.
|
NoRestartBackoffTimeStrategy.NoRestartBackoffTimeStrategyFactory |
|
NormalizableKey<T> |
The base interface for normalizable keys.
|
NormalizedKeyComputer |
|
NormalizedKeySorter<T> |
|
NormalizedKeyUtil |
|
NoSkipStrategy |
Every possible match will be emitted.
|
NotDuplicatingCheckpointStateToolset |
|
NotFoundException |
A special exception that indicates that an element was not found and that the request should be
answered with a 404 return code.
|
Nothing |
A type for (synthetic) operators that do not output data.
|
NothingTypeInfo |
Placeholder type information for the Nothing type.
|
NoticeContents |
Represents the parsed contents of a NOTICE file.
|
NoticeFileChecker |
Utility class checking for proper NOTICE files based on the maven build output.
|
NoticeParser |
Parsing utils for NOTICE files.
|
NotificationListener |
|
NotReadyFetchResultResponse |
|
NotReadyResult |
To represent that the execution result is not ready to fetch.
|
NotReleasingPartitionGroupReleaseStrategy |
Does not release intermediate result partitions during job execution.
|
NotReleasingPartitionGroupReleaseStrategy.Factory |
|
NoWatermarksGenerator<E> |
|
NTILEAggFunction |
built-in NTILE agg function.
|
NullableIfArgsTypeStrategy |
A type strategy that can be used to make a result type nullable if any or all of the selected
input arguments are nullable.
|
NullableSerializer<T> |
Serializer wrapper to add support of null value serialization.
|
NullableSerializer.NullableSerializerSnapshot<T> |
Snapshot for serializers of nullable types, containing the snapshot of its original
serializer.
|
NullAwareComparator<T> |
Null-aware comparator that wraps a comparator which does not support null references.
|
NullAwareGetters |
Provides null related getters.
|
NullAwareJoinHelper |
Helper for null aware join.
|
NullAwareMapIterator<K,V> |
An Iterator implementation that iterate on a map iterator and a null entry.
|
NullAwareMapIterator.NullMapEntry<K,V> |
A Map Entry that the entry key is always null.
|
NullAwareMapSerializer<K,V> |
Deprecated. |
NullAwareMapSerializerSnapshot<K,V> |
Deprecated. |
NullByteKeySelector<T> |
Used as a dummy KeySelector to allow using keyed operators for non-keyed use cases.
|
NullFieldException |
An exception specifying that a required field was not set in a record, i.e. was null
.
|
NullKeyFieldException |
An exception specifying that a required key field was not set in a record, i.e. was null
.
|
NullSerializer |
A serializer for null.
|
NullSerializer.NullSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
NullType |
Logical type for representing untyped NULL values.
|
NullValue |
Null base type for programs that implements the Key interface.
|
NullValueComparator |
Specialized comparator for NullValue based on CopyableValueComparator.
|
NullValueSerializer |
|
NullValueSerializer.NullValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
NullWriter<T> |
|
NumberSequenceIterator |
The NumberSequenceIterator is an iterator that returns a sequence of numbers (as
Long )s.
|
NumberSequenceSource |
A data source that produces a sequence of numbers (longs).
|
NumberSequenceSource.NumberSequenceSplit |
A split of the source, representing a number sub-sequence.
|
NumericExceptFirstOperandChecker |
Parameter type-checking strategy where all operand types except first one must be numeric type.
|
NumericTypeInfo<T> |
Type information for numeric primitive types: int, long, double, byte, short, float, char.
|
ObjectArrayTypeInfo<T,C> |
|
ObjectContainer |
This class is used for scalar function, in that it is used for comparing Objects using code
generated hashCode and equals instead of using the Object#equals/Object#hashcode versions.
|
ObjectHashSet<T> |
Wrap HashSet with hashSet interface.
|
ObjectIdentifier |
Identifies an object in a catalog.
|
ObjectPath |
A database name and object (table/view/function) name combo in a catalog.
|
OffsetAwareOutputStream |
|
OffsetOverFrame |
The offset window frame calculates frames containing LEAD/LAG statements.
|
OffsetOverFrame.CalcOffsetFunc |
Calc offset from base row.
|
OggJsonDecodingFormat |
|
OggJsonDeserializationSchema |
Deserialization schema from Ogg JSON to Flink Table/SQL internal data structure RowData .
|
OggJsonFormatFactory |
|
OggJsonFormatOptions |
Option utils for ogg-json format.
|
OggJsonSerializationSchema |
Serialization schema from Flink Table/SQL internal data structure RowData to Ogg JSON.
|
OldCsvValidator |
Deprecated.
|
OnCheckpointRollingPolicy<IN,BucketID> |
|
OnCompletionActions |
Interface for completion actions once a Flink job has reached a terminal state.
|
OneInput |
|
OneInputStateTransformation<T> |
OneInputStateTransformation represents a user defined transformation applied on an OperatorTransformation with one input.
|
OneInputStreamOperator<IN,OUT> |
Interface for stream operators with one input.
|
OneInputStreamOperatorFactory<IN,OUT> |
|
OneInputStreamOperatorOutput |
|
OneInputStreamProcessFunction<IN,OUT> |
This contains all logical related to process records from single input.
|
OneInputStreamTask<IN,OUT> |
|
OneInputTransformation<IN,OUT> |
|
OneInputTransformationTranslator<IN,OUT> |
|
OneShotLatch |
Latch for synchronizing parts of code in tests.
|
OnHeapLevelIndexHeader |
|
OnlyExecutionGraphJsonArchivist |
Interface for all classes that want to participate in the archiving of job-related json responses
but only provide AccessExecutionGraph -related information.
|
OnMainThreadJobManagerRunnerRegistry |
OnMainThreadJobManagerRunnerRegistry implements JobManagerRunnerRegistry guarding
the passed JobManagerRunnerRegistry instance in a way that it only allows modifying
methods to be executed on the component's main thread.
|
OnWatermarkCallback<KEY> |
A callback registered with the InternalWatermarkCallbackService service.
|
OpaqueMemoryResource<T> |
An opaque memory resource, meaning a memory resource not understood by Flink or the JVM.
|
OpenApiSpecGenerator |
OpenAPI spec generator for the Rest API.
|
OpenApiSpecGenerator.NameClashDetectingTypeNameResolver |
A TypeNameResolver that detects name-clashes between top-level and inner classes.
|
OpenContext |
|
OpenSessionHandler |
Handler to open session.
|
OpenSessionHeaders |
Message headers for opening a session.
|
OpenSessionRequestBody |
|
OpenSessionResponseBody |
|
OpenTelemetryMetricReporter |
A Flink MetricReporter which is made to export metrics
using Open Telemetry's MetricExporter .
|
OpenTelemetryMetricReporterFactory |
|
OpenTelemetryReporterBase |
A Flink MetricReporter which is made to export metrics using Open Telemetry's MetricExporter .
|
OpenTelemetryReporterOptions |
|
OpenTelemetryTraceReporter |
A Flink TraceReporter which is made to export spans
using Open Telemetry's SpanExporter .
|
OpenTelemetryTraceReporterFactory |
|
OperatingSystem |
An enumeration indicating the operating system that the JVM runs on.
|
OperatingSystemRestriction |
Utility for tests/resources to restrict test execution to certain operating systems.
|
Operation |
Covers all sort of Table operations such as queries(DQL), modifications(DML), definitions(DDL),
or control actions(DCL).
|
OperationAlreadyFailedException |
Exception indicating that a requested operation already exists and has failed.
|
OperationConverterUtils |
Utils methods for converting sql to operations.
|
OperationExecutor |
|
OperationExpressionsUtils |
|
OperationExpressionsUtils.CategorizedExpressions |
Container for extracted expressions of the same family.
|
OperationHandle |
|
OperationHandleIdPathParameter |
|
OperationInfo |
Information of the Operation .
|
OperationKey |
|
OperationManager |
|
OperationMessageParameters |
|
OperationResult<R> |
Encapsulates the result of an asynchronous operation.
|
OperationResultStatus |
Current status of an asynchronous operation.
|
OperationStatus |
Status to describe the Operation .
|
OperationStatusResponseBody |
|
OperationTreeBuilder |
|
OperationUtils |
|
Operator<OUT> |
Abstract base class for all operators.
|
OperatorAttributes |
OperatorAttributes element provides Job Manager with information that can be used to optimize job
performance.
|
OperatorAttributesBuilder |
|
OperatorBackendSerializationProxy |
Serialization proxy for all meta data in operator state backends.
|
OperatorBindingCallContext |
|
OperatorChain<OUT,OP extends StreamOperator<OUT>> |
The OperatorChain contains all operators that are executed as one chain within a single
StreamTask .
|
OperatorChain.ChainedSource |
Wrapper class to access the chained sources and their's outputs.
|
OperatorChainInfo |
Helper class to help maintain the information of an operator chain.
|
OperatorCoordinator |
A coordinator for runtime operators.
|
OperatorCoordinator.Context |
The context gives the OperatorCoordinator access to contextual information and provides a
gateway to interact with other components, such as sending operator events.
|
OperatorCoordinator.Provider |
|
OperatorCoordinator.SubtaskGateway |
The SubtaskGateway is the way to interact with a specific parallel instance of the
Operator (an Operator subtask), like sending events to the operator.
|
OperatorCoordinatorCheckpointContext |
|
OperatorCoordinatorHandler |
|
OperatorCoordinatorHolder |
The OperatorCoordinatorHolder holds the OperatorCoordinator and manages all its
interactions with the remaining components.
|
OperatorCoordinatorMetricGroup |
Special MetricGroup representing an Operator coordinator.
|
OperatorEvent |
|
OperatorEventDispatcher |
The dispatcher through which Operators receive OperatorEvent s and through which they can
send OperatorEvents back to the OperatorCoordinator .
|
OperatorEventDispatcherImpl |
|
OperatorEventGateway |
|
OperatorEventHandler |
Interface for handlers of operator events on the operator side.
|
OperatorFusionCodegenFactory<OUT> |
Stream operator factory for multiple operator fusion codegen.
|
OperatorID |
A class for statistically unique operator IDs.
|
OperatorIdentifier |
Identifies an operator, either based on a uid or uidHash .
|
OperatorIDGenerator |
Utility for generating Operator Id's from uid strings.
|
OperatorIDPair |
Formed of a mandatory operator ID and optionally a user defined operator ID.
|
OperatorInfo |
An interface to access basic properties of an operator in the context of its coordinator.
|
OperatorInfo |
Helper class to help maintain the information of an operator.
|
OperatorInformation<OUT> |
A class for holding information about an operator, such as input/output TypeInformation.
|
OperatorInstanceID |
An ID for physical instance of the operator.
|
OperatorIOMetricGroup |
Metric group that contains shareable pre-defined IO-related metrics for operators.
|
OperatorMetricGroup |
|
OperatorScopeFormat |
|
OperatorSnapshotFinalizer |
|
OperatorSnapshotFutures |
|
OperatorState |
Simple container class which contains the raw/managed operator state and key-group state handles
from all subtasks of an operator and therefore represents the complete state of a logical
operator.
|
OperatorStateBackend |
|
OperatorStateBackendParametersImpl |
|
OperatorStateCheckpointOutputStream |
Checkpoint output stream that allows to write raw operator state in a partitioned way.
|
OperatorStateHandle |
Interface of a state handle for operator state.
|
OperatorStateHandle.Mode |
|
OperatorStateHandle.StateMetaInfo |
Meta information about the operator state handle.
|
OperatorStateInputSplit |
An input split containing state handles for operator state.
|
OperatorStateRepartitioner<T> |
Interface that allows to implement different strategies for repartitioning of operator state as
parallelism changes.
|
OperatorStateRestoreOperation |
Implementation of operator state restore operation.
|
OperatorStateStore |
This interface contains methods for registering operator state with a managed store.
|
OperatorStreamStateHandle |
State handle for partitionable operator state.
|
OperatorSubtaskDescriptionText |
This class generates a string that can be used to identify an operator subtask.
|
OperatorSubtaskState |
This class encapsulates the state for one parallel instance of an operator.
|
OperatorSubtaskState.Builder |
|
OperatorSubtaskStateReducer |
|
OperatorTransformation |
|
OperatorType |
|
OperatorUidPathParameter |
Path parameter identifying operators.
|
OperatorValidationUtils |
Utils for checking operators' resource and parallelism settings.
|
OpFusionCodegenSpec |
An interface for those physical operators that support operator fusion codegen.
|
OpFusionCodegenSpecGenerator |
OpFusionCodegenSpecGenerator is used to operator fusion codegen that generate the fusion
code, it has multiple inputs and outputs, then form a DAG.
|
OpFusionContext |
A OpFusionContext contains information about the context in which OpFusionCodegenSpec
needed to do operator fusion codegen.
|
OptimizableHashSet |
A type-specific hash set with with a fast, small-footprint implementation.
|
OptimizerConfigOptions |
This class holds configuration constants used by Flink's table planner module.
|
OptimizerConfigOptions.NonDeterministicUpdateStrategy |
Strategy for handling non-deterministic updates.
|
OptimizerOptions |
Configuration options for the optimizer.
|
OptionalConsumer<T> |
Utility class which allows to run code depending on whether the optional has a value or is empty.
|
OptionalFailure<T> |
Wrapper around an object representing either a success (with a given value) or a failure cause.
|
OptionalUtils |
|
OptionsClassLocation |
Simple descriptor for the location of a class containing ConfigOptions .
|
OptionWithMetaInfo |
|
OrArgumentTypeStrategy |
Strategy for inferring and validating an argument using a disjunction of multiple ArgumentTypeStrategy s into one like f(NUMERIC || STRING) .
|
OrcArrayColumnVector |
This column vector is used to adapt hive's ListColumnVector to Flink's ArrayColumnVector.
|
OrcBulkWriter<T> |
A BulkWriter implementation that writes data in ORC format.
|
OrcBulkWriterFactory<T> |
|
OrcBytesColumnVector |
This column vector is used to adapt hive's BytesColumnVector to Flink's BytesColumnVector.
|
OrcColumnarRowInputFormat<BatchT,SplitT extends FileSourceSplit> |
|
OrcColumnarRowSplitReader<BATCH> |
|
OrcColumnarRowSplitReader.ColumnBatchGenerator<BATCH> |
|
OrcDecimalColumnVector |
This column vector is used to adapt hive's DecimalColumnVector to Flink's DecimalColumnVector.
|
OrcDoubleColumnVector |
This column vector is used to adapt hive's DoubleColumnVector to Flink's float and double
ColumnVector.
|
OrcFileFormatFactory |
Orc format factory for file system.
|
OrcFileFormatFactory.OrcBulkDecodingFormat |
|
OrcFilters |
Utility class that provides helper methods to work with Orc Filter PushDown.
|
OrcFilters.And |
An AND predicate that can be evaluated by the OrcInputFormat.
|
OrcFilters.Between |
An BETWEEN predicate that can be evaluated by the OrcInputFormat.
|
OrcFilters.Equals |
An EQUALS predicate that can be evaluated by the OrcInputFormat.
|
OrcFilters.In |
An IN predicate that can be evaluated by the OrcInputFormat.
|
OrcFilters.IsNull |
An IS_NULL predicate that can be evaluated by the OrcInputFormat.
|
OrcFilters.LessThan |
A LESS_THAN predicate that can be evaluated by the OrcInputFormat.
|
OrcFilters.LessThanEquals |
A LESS_THAN_EQUALS predicate that can be evaluated by the OrcInputFormat.
|
OrcFilters.Not |
A NOT predicate to negate a predicate that can be evaluated by the OrcInputFormat.
|
OrcFilters.NullSafeEquals |
An EQUALS predicate that can be evaluated with Null safety by the OrcInputFormat.
|
OrcFilters.Or |
An OR predicate that can be evaluated by the OrcInputFormat.
|
OrcFilters.Predicate |
A filter predicate that can be evaluated by the OrcInputFormat.
|
OrcFormatStatisticsReportUtil |
Utils for Orc format statistics report.
|
OrcLegacyTimestampColumnVector |
This class is used to adapt to Hive's legacy (2.0.x) timestamp column vector which is a
LongColumnVector.
|
OrcLongColumnVector |
This column vector is used to adapt hive's LongColumnVector to Flink's boolean, byte, short, int
and long ColumnVector.
|
OrcMapColumnVector |
This column vector is used to adapt hive's MapColumnVector to Flink's MapColumnVector.
|
OrcNoHiveBatchWrapper |
Wrap VectorizedRowBatch orc batch.
|
OrcNoHiveBulkWriterFactory |
|
OrcNoHiveBytesVector |
This column vector is used to adapt hive's BytesColumnVector to Flink's BytesColumnVector.
|
OrcNoHiveColumnarRowInputFormat |
|
OrcNoHiveDecimalVector |
This column vector is used to adapt hive's DecimalColumnVector to Flink's DecimalColumnVector.
|
OrcNoHiveDoubleVector |
This column vector is used to adapt hive's DoubleColumnVector to Flink's float and double
ColumnVector.
|
OrcNoHiveLongVector |
This column vector is used to adapt hive's LongColumnVector to Flink's boolean, byte, short, int
and long ColumnVector.
|
OrcNoHiveShim |
Shim for orc reader without hive dependents.
|
OrcNoHiveSplitReaderUtil |
|
OrcNoHiveTimestampVector |
This column vector is used to adapt hive's TimestampColumnVector to Flink's
TimestampColumnVector.
|
OrcRowColumnVector |
This column vector is used to adapt hive's StructColumnVector to Flink's RowColumnVector.
|
OrcShim<BATCH> |
A shim layer to support orc with different dependents versions of Hive.
|
OrcShimV200 |
Shim orc for Hive version 2.0.0 and upper versions.
|
OrcShimV210 |
Shim orc for Hive version 2.1.0 and upper versions.
|
OrcShimV230 |
Shim orc for Hive version 2.1.0 and upper versions.
|
OrcSplitReader<T,BATCH> |
Orc split reader to read record from orc file.
|
OrcSplitReaderUtil |
|
OrcTimestampColumnVector |
This column vector is used to adapt hive's TimestampColumnVector to Flink's
TimestampColumnVector.
|
OrcVectorizedBatchWrapper<T> |
Interface to unify orc reader in hive and orc reader without hive dependents.
|
Order |
Enumeration representing order.
|
OrderedStreamElementQueue<OUT> |
|
Ordering |
This class represents an ordering on a set of fields.
|
OrInputTypeStrategy |
Strategy for inferring and validating the input using a disjunction of multiple InputTypeStrategy s into one like f(NUMERIC) || f(STRING) .
|
OSSAccessor |
Core implementation of Aliyun OSS Filesystem for Flink.
|
OSSCommitter |
Data object to commit an OSS MultiPartUpload.
|
OSSFileSystemFactory |
Simple factory for the OSS file system.
|
OSSRecoverable |
Data object to recover an OSS MultiPartUpload for a recoverable output stream.
|
OSSRecoverableFsDataOutputStream |
A RecoverableFsDataOutputStream to OSS that is based on a recoverable multipart upload.
|
OSSRecoverableMultipartUpload |
Uploader for OSS multi part upload.
|
OSSRecoverableSerializer |
|
OSSRecoverableWriter |
|
OSSTestCredentials |
Access to credentials to access OSS buckets during integration tests.
|
OutboundChannelHandlerFactory |
Custom netty outbound handler factory in order to make custom changes on netty outbound data.
|
OuterJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> |
|
OuterJoinOperatorBase.OuterJoinType |
|
OuterJoinPaddingUtil |
An utility to generate reusable padding results for outer joins.
|
OuterJoinRecordAsyncStateView |
|
OuterJoinRecordAsyncStateViews |
|
OuterJoinRecordStateView |
|
OuterJoinRecordStateViews |
|
OuterRecord |
An OuterRecord is a composite of record and numOfAssociations .
|
Output<T> |
A StreamOperator is supplied with an object of
this interface that can be used to emit elements and other messages, such as barriers and
watermarks, from an operator.
|
OutputArgumentTypeStrategy |
Strategy for inferring an unknown argument type from the function's output DataType if
available.
|
OutputBase |
Base Output that can be used to emit elements and other messages in MultipleInputStreamOperatorBase .
|
OutputBufferPoolUsageGauge |
Gauge metric measuring the output buffer pool usage gauge for ResultPartition s.
|
OutputBuffersGauge |
Gauge metric measuring the number of queued output buffers for ResultPartition s.
|
OutputBuffersSizeGauge |
Gauge metric measuring the size in bytes of queued output buffers for ResultPartition s.
|
OutputCollector<OUT> |
|
OutputCollector<T> |
The OutputCollector collects records, and emits them to the RecordWriter s.
|
OutputConversionModifyOperation |
|
OutputConversionModifyOperation.UpdateMode |
Should the output type contain the change flag, and what should the flag represent
(retraction or deletion).
|
OutputConversionOperator |
Operator that converts to external data structures and unwraps atomic records if necessary.
|
OutputEmitter<T> |
The output emitter decides to which of the possibly multiple output channels a record is sent.
|
OutputFileConfig |
Part file name configuration.
|
OutputFileConfig.OutputFileConfigBuilder |
A builder to create the part file configuration.
|
OutputFormat<IT> |
The base interface for outputs that consumes records.
|
OutputFormat.InitializationContext |
The context exposes some runtime info for initializing output format.
|
OutputFormatBase<OUT,V> |
OutputFormatBase is the common abstract class for output formats.
|
OutputFormatFactory<T> |
|
OutputFormatOperatorFactory<IN,OUT> |
Interface for operator factories which create the sink operator containing an OutputFormat .
|
OutputFormatProvider |
|
OutputFormatSinkFunction<IN> |
Deprecated.
|
OutputFormatTableSink<T> |
Deprecated.
|
OutputStreamAndPath |
An output stream and a path.
|
OutputStreamBasedCompactingFileWriter |
|
OutputStreamBasedFileCompactor |
Base class for FileCompactor implementations that write the compacting file by a output
stream.
|
OutputStreamBasedPartFileWriter<IN,BucketID> |
|
OutputStreamBasedPartFileWriter.OutputStreamBasedInProgressFileRecoverable |
|
OutputStreamBasedPartFileWriter.OutputStreamBasedInProgressFileRecoverableSerializer |
|
OutputStreamBasedPartFileWriter.OutputStreamBasedPendingFileRecoverable |
|
OutputStreamBasedPartFileWriter.OutputStreamBasedPendingFileRecoverableSerializer |
|
OutputTag<T> |
An OutputTag is a typed and named tag to use for tagging side outputs of an operator.
|
OutputTypeConfigurable<OUT> |
Stream operators can implement this interface if they need access to the output type information
at org.apache.flink.streaming.api.graph.StreamGraph generation.
|
OutputWithChainingCheck<OUT> |
This is a wrapper for outputs to check whether the collected record has been emitted to a
downstream subtask or to a chained operator.
|
Over |
Helper class for creating an over window.
|
OverConvertRule |
|
OverSpec |
OverSpec describes a set of over aggregates.
|
OverSpec.GroupSpec |
OverSpec.GroupSpec describes group of over aggregate calls that have the same window
specification.
|
OverTypeStrategy |
|
OverWindow |
An over window specification.
|
OverWindowedTable |
|
OverWindowFrame |
A window frame calculates the results for those records belong to a window frame.
|
OverWindowPartitioned |
Partially defined over window with partitioning.
|
OverWindowPartitionedOrdered |
Partially defined over window with (optional) partitioning and order.
|
OverWindowPartitionedOrderedPreceding |
Partially defined over window with (optional) partitioning, order, and preceding.
|
OverWindowRange |
|
OverwritableTableSink |
Deprecated.
|
OverwriteSpec |
A sub-class of SinkAbilitySpec that can not only serialize/deserialize the overwrite flag
to/from JSON, but also can overwrite existing data for SupportsOverwrite .
|
OwnedTaskLocalStateStore |
This interface represents the administrative interface to TaskLocalStateStore , that only
the owner of the object should see.
|
PackagedProgram |
This class encapsulates represents a program, packaged in a jar file.
|
PackagedProgram.Builder |
|
PackagedProgramRetriever |
|
PackagedProgramUtils |
|
PackagingTestUtils |
Test utils around jar packaging.
|
PaddingLeftMapFunction |
Function performing left padding.
|
PaddingRightMapFunction |
Function performing right padding.
|
PagedTypeSerializer<T> |
A type serializer which provides paged serialize and deserialize methods.
|
PageRankData |
Test data for PageRank programs.
|
PageSizeUtil |
Utility for accessing the system page size.
|
PanedWindowAssigner<W extends Window> |
A WindowAssigner that window can be split into panes.
|
PanedWindowProcessFunction<K,W extends Window> |
|
ParallelismAndInputInfos |
|
ParallelismProvider |
Parallelism provider for other connector providers.
|
ParallelismQueryParameter |
Query parameter specifying the parallelism of the job.
|
ParallelSourceFunction<OUT> |
Deprecated.
|
Parameter |
The annotation is used to replace Parameterized.Parameter for Junit 5 parameterized
tests.
|
ParameterizedTestExtension |
This extension is used to implement parameterized tests for Junit 5 to replace Parameterized in
Junit4.
|
ParameterProperty<V> |
System-property based parameters for tests and resources.
|
Parameters |
The annotation is used to replace Parameterized.Parameters(Junit4) for Junit 5 parameterized
tests.
|
ParameterTool |
This class provides simple utility methods for reading and parsing program arguments from
different sources.
|
ParentChildTestingVehicle |
This is used for test_streaming_classloader.sh.
|
ParquetBuilder<T> |
A builder to create a ParquetWriter from a Parquet OutputFile .
|
ParquetBulkWriter<T> |
A simple BulkWriter implementation that wraps a ParquetWriter .
|
ParquetColumnarRowInputFormat<SplitT extends FileSourceSplit> |
|
ParquetColumnarRowSplitReader |
|
ParquetColumnarRowSplitReader.ColumnBatchGenerator |
|
ParquetDataColumnReader |
The interface to wrap the underlying Parquet dictionary and non dictionary encoded page reader.
|
ParquetDataColumnReaderFactory |
Parquet file has self-describing schema which may differ from the user required schema (e.g.
|
ParquetDataColumnReaderFactory.DefaultParquetDataColumnReader |
The default data column reader for existing Parquet page reader which works for both
dictionary or non dictionary types, Mirror from dictionary encoding path.
|
ParquetDataColumnReaderFactory.TypesFromInt96PageReader |
The reader who reads from the underlying Timestamp value.
|
ParquetDecimalVector |
Parquet write decimal as int32 and int64 and binary, this class wrap the real vector to provide
DecimalColumnVector interface.
|
ParquetDictionary |
Parquet dictionary.
|
ParquetField |
Field that represent parquet's field type.
|
ParquetFileFormatFactory |
Parquet format factory for file system.
|
ParquetFileFormatFactory.ParquetBulkDecodingFormat |
|
ParquetFormatStatisticsReportUtil |
Utils for Parquet format statistics report.
|
ParquetGroupField |
Field that represent parquet's Group Field.
|
ParquetInputFile |
|
ParquetPrimitiveField |
Field that represent parquet's primitive field.
|
ParquetProtoWriters |
|
ParquetProtoWriters.ParquetProtoWriterBuilder<T extends com.google.protobuf.Message> |
The builder for Protobuf ParquetWriter .
|
ParquetRowDataBuilder |
|
ParquetRowDataBuilder.FlinkParquetBuilder |
|
ParquetRowDataWriter |
Writes a record to the Parquet API with the expected schema in order to be written to a file.
|
ParquetSchemaConverter |
Schema converter converts Parquet schema to and from Flink internal types.
|
ParquetSplitReaderUtil |
|
ParquetVectorizedInputFormat<T,SplitT extends FileSourceSplit> |
|
ParquetVectorizedInputFormat.ParquetReaderBatch<T> |
Reader batch that provides writing and reading capabilities.
|
ParquetWriterFactory<T> |
|
ParseException |
Exception indicating that the parsing of input contents has failed because the data does not
match the configured parser.
|
ParseException |
This exception is thrown when parse errors are encountered.
|
Parser |
Provides methods for parsing SQL objects from a SQL string.
|
ParserFactory |
|
ParserFactory.Context |
Context provided when a parser is created.
|
ParserImpl |
Implementation of Parser that uses Calcite.
|
ParserResource |
Compiler-checked resources for the Flink SQL parser.
|
ParserResultFactory<T> |
|
ParserUtils |
Parsing utils.
|
PartFileInfo<BucketID> |
An interface exposing the information concerning the current (open) part file that is necessary
to the RollingPolicy in order to determine if it should roll the part file or not.
|
PartialCachingAsyncLookupProvider |
|
PartialCachingLookupProvider |
|
PartialDispatcherServices |
|
PartialDispatcherServicesWithJobPersistenceComponents |
|
PartialFinalType |
Enumerations for partial final aggregate types.
|
PartialFinishedInputConsumableDecider |
|
PartialFinishedInputConsumableDecider.Factory |
|
PartialOrderPriorityQueue<T> |
This class implements a priority-queue, which maintains a partial ordering of its elements such
that the least element can always be found in constant time.
|
PartitionableListState<S> |
Implementation of operator list state.
|
PartitionableTableSink |
Deprecated.
|
PartitionableTableSource |
Deprecated.
|
PartitionAggregateOperator<IN,ACC,OUT> |
|
PartitionAlreadyExistsException |
Exception for trying to create a partition that already exists.
|
PartitionCommitInfo |
The message sent by upstream.
|
PartitionCommitPolicy |
Policy for commit a partition.
|
PartitionCommitPolicy.Context |
Context of policy, including table information and partition information.
|
PartitionCommitPolicyFactory |
|
PartitionCommitPredicate |
Partition commit predicate.
|
PartitionCommitPredicate.PredicateContext |
|
PartitionCommitter |
Committer operator for partitions.
|
PartitionCommitTrigger |
Partition commit trigger.
|
PartitionComputer<T> |
Compute partition path from record and project non-partition columns for output writer.
|
PartitionConnectionException |
Exception for failed partition requests due to connection failure with unreachable producer.
|
PartitionCustomKeySelector |
|
PartitionDescriptor |
|
PartitionedContext |
|
PartitionedFile |
PartitionedFile is the persistent file type of sort-merge based blocking shuffle.
|
PartitionedFileWriter |
|
Partitioner<K> |
Function to implement a custom partition assignment for keys.
|
PartitionException |
Exception for covering all the scenarios of consuming partition failure which causes the consumer
task failed, and the job master would decide whether to restart the producer based on this
exception.
|
PartitionFetcher<P> |
Fetcher to fetch the suitable partitions of a filesystem table.
|
PartitionFetcher.Context<P> |
Context for fetch partitions, partition information is stored in hive meta store.
|
PartitionFetcher.Context.ComparablePartitionValue<P,T extends Comparable<T>> |
A comparable partition value that can compare order by using its comparator.
|
PartitionFieldExtractor<T extends FileSourceSplit> |
Interface to extract partition field from split.
|
PartitionFileReader |
|
PartitionFileReader.ReadBufferResult |
A wrapper class of the reading buffer result, including the read buffers, the hint of
continue reading, and the read progress, etc.
|
PartitionFileReader.ReadProgress |
|
PartitionFileWriter |
The PartitionFileWriter interface defines the write logic for different types of shuffle
files.
|
PartitionFileWriter.SegmentBufferContext |
|
PartitionFileWriter.SubpartitionBufferContext |
|
PartitionGroupReleaseStrategy |
|
PartitionGroupReleaseStrategy.Factory |
|
PartitionGroupReleaseStrategyFactoryLoader |
|
PartitionInfo |
Contains information where to find a partition.
|
PartitioningSpec |
|
PartitionLoader |
Loader to temporary files to final output path and meta store.
|
PartitionNotExistException |
Exception for operation on a partition that doesn't exist.
|
PartitionNotFoundException |
Exception for failed partition requests due to non-existing partitions.
|
PartitionOperatorBase<IN> |
|
PartitionOperatorBase.PartitionMethod |
|
PartitionPathUtils |
Utils for file system.
|
PartitionProducerDisposedException |
Exception returned to a TaskManager on JobMaster requesting partition state, if the producer of a
partition has been disposed.
|
PartitionProducerStateChecker |
Intermediate partition state checker to query the JobManager about the state of the producer of a
result partition.
|
PartitionProducerStateProvider |
Request execution state of partition producer, the response accepts state check callbacks.
|
PartitionProducerStateProvider.ResponseHandle |
Result of state query, accepts state check callbacks.
|
PartitionPushDownSpec |
|
PartitionReader<P,OUT> |
Reader that reads record from given partitions.
|
PartitionReduceOperator<IN> |
|
PartitionRequestClient |
|
PartitionRequestListener |
When the netty server receives a downstream task's partition request event and finds its upstream
task doesn't register its partition yet, the netty server will construct a PartitionRequestListener and notify the listener when the task deploys itself and registers its
partition to ResultPartitionManager .
|
PartitionRequestListenerManager |
Manages partition request listener with input channel id.
|
PartitionSpec |
|
PartitionSpecInvalidException |
Exception for invalid PartitionSpec compared with partition key list of a partitioned Table.
|
PartitionTable<K> |
Thread-safe Utility for tracking partitions.
|
PartitionTempFileManager |
Manage temporary files for writing files.
|
PartitionTimeCommitPredicate |
Partition commit predicate by partition time and watermark, if 'watermark' > 'partition-time' +
'delay', the partition is committable.
|
PartitionTimeCommitTrigger |
Partition commit trigger by partition time and watermark.
|
PartitionTimeExtractor |
Time extractor to extract time from partition values.
|
PartitionTracker<K,M> |
Utility for tracking partitions.
|
PartitionTrackerEntry<K,M> |
|
PartitionTrackerFactory |
|
PartitionTrackerFactory.TaskExecutorGatewayLookup |
|
PartitionTransformation<T> |
This transformation represents a change of partitioning of the input elements.
|
PartitionTransformationTranslator<OUT> |
|
PartitionUpdateException |
Exception indicating a problem with the result partitions on the TaskExecutor side.
|
PartitionWindowedStream<T> |
PartitionWindowedStream represents a data stream that collects all records of each
partition separately into a full window.
|
PartitionWithMetrics |
Interface representing the description and metrics of a result partition.
|
PartitionWriter<T> |
Partition writer to write records with partition.
|
PartitionWriter.Context<T> |
Context for partition writer, provide some information and generation utils.
|
PartitionWriter.DefaultPartitionWriterListener |
Default implementation for PartitionWriterListener.
|
PartitionWriter.PartitionWriterListener |
Listener for partition writer.
|
PartitionWriterFactory<T> |
|
PassThroughAllWindowFunction<W extends Window,T> |
|
PassThroughReader<KEY,W extends Window,IN> |
|
PassThroughWindowFunction<K,W extends Window,T> |
|
Path |
|
PathsCopyingFileSystem |
|
PathsCopyingFileSystem.CopyRequest |
A pair of source and destination to duplicate a file.
|
Pattern<T,F extends T> |
Base class for a pattern definition.
|
PatternFlatSelectAdapter<IN,OUT> |
|
PatternFlatSelectFunction<IN,OUT> |
Base interface for a pattern select function which can produce multiple resulting elements.
|
PatternFlatTimeoutFunction<IN,OUT> |
Base interface for a pattern timeout function which can produce multiple resulting elements.
|
PatternProcessFunction<IN,OUT> |
It is called with a map of detected events which are identified by their names.
|
PatternProcessFunction.Context |
Gives access to time related characteristics as well as enables emitting elements to side
outputs.
|
PatternProcessFunctionRunner |
|
PatternSelectAdapter<IN,OUT> |
|
PatternSelectFunction<IN,OUT> |
Base interface for a pattern select function.
|
PatternStream<T> |
Stream abstraction for CEP pattern detection.
|
PatternTimeoutFlatSelectAdapter<IN,OUT,T> |
|
PatternTimeoutFunction<IN,OUT> |
Base interface for a pattern timeout function.
|
PatternTimeoutSelectAdapter<IN,OUT,T> |
|
PausableRelativeClock |
A RelativeClock whose time progress with respect to the wall clock can be paused and
un-paused.
|
PbCodegenAppender |
Helper class which do code fragment concat.
|
PbCodegenArrayDeserializer |
Deserializer to convert proto array type object to flink array type data.
|
PbCodegenArraySerializer |
Serializer to convert flink array type data to proto array type object.
|
PbCodegenDeserializeFactory |
|
PbCodegenDeserializer |
PbCodegenDeserializer is responsible for converting protobuf object to flink internal
object by codegen process.
|
PbCodegenException |
Exception represents codegen error in row and proto conversion which is probably a bug.
|
PbCodegenMapDeserializer |
Deserializer to convert proto map type object to flink map type data.
|
PbCodegenMapSerializer |
Serializer to convert flink map type data to proto map type object.
|
PbCodegenRowDeserializer |
Deserializer to convert proto message type object to flink row type data.
|
PbCodegenRowSerializer |
Serializer to convert flink row type data to proto row type object.
|
PbCodegenSerializeFactory |
|
PbCodegenSerializer |
PbCodegenSerializer is responsible for converting flink internal data object to protobuf
object by codegen process.
|
PbCodegenSimpleDeserializer |
Deserializer to convert proto simple type object to flink simple type data.
|
PbCodegenSimpleSerializer |
Serializer to convert flink simple type data to proto simple type object.
|
PbCodegenUtils |
Codegen utils only used in protobuf format.
|
PbCodegenVarId |
Singleton class for generating variable suffix number globally to avoid conflict in codegen
sections.
|
PbConstant |
Keeps protobuf constants separately.
|
PbDecodingFormat |
|
PbEncodingFormat |
|
PbFileFormatFactory |
|
PbFormatConfig |
Config of protobuf configs.
|
PbFormatConfig.PbFormatConfigBuilder |
Builder of PbFormatConfig.
|
PbFormatContext |
store config and common information.
|
PbFormatFactory |
|
PbFormatOptions |
This class holds configuration constants used by protobuf format.
|
PbFormatUtils |
Protobuf function util.
|
PbRowDataDeserializationSchema |
Deserialization schema from Protobuf to Flink types.
|
PbRowDataSerializationSchema |
Serialization schema from Flink to Protobuf types.
|
PbSchemaValidationUtils |
Validation class to verify protobuf definition and flink schema.
|
PbToRowTypeUtil |
Generate Row type information according to pb descriptors.
|
PekkoRpcService |
|
PekkoRpcServiceConfiguration |
|
PekkoRpcServiceUtils |
These RPC utilities contain helper methods around RPC use, such as starting an RPC service, or
constructing RPC addresses.
|
PekkoRpcServiceUtils.Protocol |
Whether to use TCP or encrypted TCP for Pekko.
|
PekkoRpcSystem |
|
PekkoRpcSystemLoader |
|
PendingCheckpoint |
A pending checkpoint is a checkpoint that has been started, but has not been acknowledged by all
tasks that need to acknowledge it.
|
PendingCheckpoint.TaskAcknowledgeResult |
|
PendingCheckpointStats |
Statistics for a pending checkpoint that is still in progress.
|
PendingSplitsCheckpoint<SplitT extends FileSourceSplit> |
A checkpoint of the current state of the containing the currently pending splits that are not yet
assigned.
|
PendingSplitsCheckpointSerializer<T extends FileSourceSplit> |
|
PendingTaskManager |
|
PendingTaskManagerId |
|
PercentageArgumentTypeStrategy |
|
PercentageArrayArgumentTypeStrategy |
|
PercentileAggFunction<T> |
Built-in PERCENTILE aggregate function.
|
PercentileAggFunction.MultiPercentileAggFunction |
Percentile agg function with multiple percentage parameters.
|
PercentileAggFunction.PercentileAccumulator |
Accumulator for PERCENTILE.
|
PercentileAggFunction.SinglePercentileAggFunction |
Percentile agg function with only one percentage parameter.
|
PercentRankAggFunction |
built-in percent_rank aggregate function.
|
PeriodicCacheReloadTrigger |
|
PeriodicCacheReloadTrigger.ScheduleMode |
Defines the mode how to schedule cache reloads.
|
PeriodicMaterializationManager |
Stateless Materialization Manager.
|
PeriodicMaterializationManager.MaterializationRunnable |
A Runnable representing the materialization and the associated metadata.
|
PeriodicMaterializationManager.MaterializationTarget |
|
PeriodicStreamingJob |
This is a periodic streaming job that runs for CLI testing purposes.
|
PeriodicWatermarkAssigner |
A periodic watermark assigner.
|
PeriodicWatermarkAssignerWrapper |
|
PeriodTimer |
Interface for the measurement of the period of time.
|
PerJobCheckpointRecoveryFactory<T extends CompletedCheckpointStore> |
|
PerJobCheckpointRecoveryFactory.CheckpointStoreRecoveryHelper<StoreType extends CompletedCheckpointStore> |
|
PerJobMiniClusterFactory |
|
PerKeyStateDataViewStore |
|
PermanentBlobCache |
Provides a cache for permanent BLOB files including a per-job ref-counting and a staged cleanup.
|
PermanentBlobKey |
BLOB key referencing permanent BLOB files.
|
PermanentBlobService |
A service to retrieve permanent binary large objects (BLOBs).
|
PersistentMetadataCheckpointStorageLocation |
|
PersistingDownloadCache |
DownloadCache implementation that caches downloaded files in a configured directory.
|
PersistingDownloadCacheFactory |
|
PerWindowStateDataViewStore |
|
PhysicalFile |
An abstraction of physical files in file-merging checkpoints.
|
PhysicalFile.PhysicalFileCreator |
Functional interface to create the physical file.
|
PhysicalFile.PhysicalFileDeleter |
Functional interface to delete the physical file.
|
PhysicalFilePool |
|
PhysicalFilePool.Type |
Types of supported physical file pool.
|
PhysicalSlot |
The context of an AllocatedSlot .
|
PhysicalSlot.Payload |
Payload which can be assigned to an AllocatedSlot .
|
PhysicalSlotProvider |
The provider serves physical slot requests.
|
PhysicalSlotProviderImpl |
The provider serves physical slot requests.
|
PhysicalSlotRequest |
Represents a request for a physical slot.
|
PhysicalSlotRequest.Result |
|
PhysicalSlotRequestBulk |
Represents a bulk of physical slot requests.
|
PhysicalSlotRequestBulkChecker |
This class tracks a fulfillability timeout of a bulk of physical slot requests.
|
PhysicalSlotRequestBulkCheckerImpl |
|
PhysicalStateHandleID |
Unique ID that allows for physical comparison between state handles.
|
PhysicalTransformation<T> |
|
PhysicalWriterImpl |
A slightly customised clone of PhysicalFsWriter .
|
PickledByteArrayTypeInfo |
A PickledByteArrayTypeInfo indicates that the data of this type is a generated primitive byte
array by pickle.
|
Pipeline |
Common interface for Flink pipelines.
|
PipelinedApproximateSubpartition |
A pipelined in-memory only subpartition, which allows to reconnect after failure.
|
PipelinedApproximateSubpartitionView |
View over a pipelined in-memory only subpartition allowing reconnecting.
|
PipelinedRegion<VID extends VertexID,RID extends ResultID,V extends Vertex<VID,RID,V,R>,R extends Result<VID,RID,V,R>> |
A pipelined region is a set of vertices connected via pipelined data exchanges.
|
PipelinedRegionComputeUtil |
Common utils for computing pipelined regions.
|
PipelinedRegionSchedulingStrategy |
|
PipelinedRegionSchedulingStrategy.Factory |
|
PipelinedResultPartition |
A result output of a task, pipelined (streamed) to the receivers.
|
PipelinedSubpartition |
A pipelined in-memory only subpartition, which can be consumed once.
|
PipelinedSubpartitionView |
View over a pipelined in-memory only subpartition.
|
PipelineErrorHandler |
This is the last handler in the pipeline.
|
PipelineErrorHandler |
This is the last handler in the pipeline.
|
PipelineExecutor |
The entity responsible for executing a Pipeline , i.e. a user job.
|
PipelineExecutorFactory |
|
PipelineExecutorServiceLoader |
An interface to be implemented by the entity responsible for finding the correct PipelineExecutor to execute a given Pipeline .
|
PipelineExecutorUtils |
Utility class with method related to job execution.
|
PipelineOptions |
|
PipelineOptions.VertexDescriptionMode |
The mode how we organize description of a vertex.
|
PipelineOptionsInternal |
Pipeline options that are not meant to be used by the user.
|
PlaceholderStreamStateHandle |
A placeholder state handle for shared state that will replaced by an original that was created in
a previous checkpoint.
|
Plan |
This class represents Flink programs, in the form of dataflow plans.
|
PlanAdvice |
|
PlanAdvice.Kind |
|
PlanAdvice.Scope |
|
PlanAnalyzer |
Plan analyzer analyzes the optimized physical plan and provide potential risk warnings and
optimization advice.
|
PlanAnalyzer.AnalyzedResult |
The analyzed PlanAdvice with a list of applicable RelNode ids.
|
PlanCacheManager |
This manages all the plan caches.
|
Planner |
|
PlannerCallProcedureOperation |
Wrapper for valid call procedure operation generated by Planner.
|
PlannerConfig |
The PlannerConfig holds parameters to configure the behavior of queries.
|
PlannerContext |
Utility class to create RelBuilder or FrameworkConfig
used to create a corresponding Planner .
|
PlannerExternalQueryOperation |
Wrapper for valid logical plans and resolved schema generated by Planner.
|
PlannerFactory |
|
PlannerFactory.Context |
Context used when creating a planner.
|
PlannerFactory.DefaultPlannerContext |
|
PlannerFactoryUtil |
|
PlannerQueryOperation |
Wrapper for valid logical plans generated by Planner.
|
PlannerTypeUtils |
|
PlanReference |
Unresolved pointer to a persisted plan.
|
PlanReference.ContentPlanReference |
Plan reference to a string containing the serialized persisted plan in JSON.
|
PlanReference.FilePlanReference |
Plan reference to a file in the local filesystem.
|
PlanReference.ResourcePlanReference |
|
Plugin |
Interface for plugins.
|
PluginConfig |
Stores the configuration for plugins mechanism.
|
PluginDescriptor |
Descriptive meta information for a plugin.
|
PluginFileSystemFactory |
|
PluginFinder |
Implementations of this interface provide mechanisms to locate plugins and create corresponding
PluginDescriptor objects.
|
PluginLoader |
|
PluginManager |
PluginManager is responsible for managing cluster plugins which are loaded using separate class
loaders so that their dependencies don't interfere with Flink's dependencies.
|
PluginUtils |
Utility functions for the plugin mechanism.
|
PodTemplateMountDecorator |
|
PointwiseBlockingResultInfo |
Information of Pointwise result.
|
PojoComparator<T> |
|
PojoField |
Represent a field definition for PojoTypeInfo type of objects.
|
PojoSerializer<T> |
|
PojoSerializerSnapshot<T> |
|
PojoTestUtils |
Test utils around POJOs.
|
PojoTypeInfo<T> |
TypeInformation for "Java Beans"-style types.
|
PojoTypeInfo.NamedFlatFieldDescriptor |
|
Pool<T> |
A pool to cache and recycle heavyweight objects, to reduce object allocation.
|
Pool.Recycler<T> |
A Recycler puts objects into the pool that the recycler is associated with.
|
PortRange |
Represents a port range and provides access to an iterator of the given range.
|
PossibleInconsistentStateException |
PossibleInconsistentStateException represents errors that might have lead to an
inconsistent state within the HA resources.
|
PostVersionedIOReadableWritable |
|
PreCommit |
Marker interface for tests that should be run on every commit.
|
Preconditions |
A collection of static utility methods to validate input.
|
PredefinedOptions |
|
Predicates |
Common predicates for architecture tests.
|
PreferredAllocationRequestSlotMatchingStrategy |
|
PreferredLocationsRetriever |
Component to retrieve the preferred locations of an execution vertex.
|
PreserveWatermarks |
A strategy which indicates the watermarks should be preserved from the underlying datastream.
|
PreviousAllocationSlotSelectionStrategy |
This class implements a SlotSelectionStrategy that is based on previous allocations and
falls back to using location preference hints if there is no previous allocation.
|
PrimitiveArrayComparator<T,C extends BasicTypeComparator> |
|
PrimitiveArrayTypeInfo<T> |
|
PrintConnectorOptions |
Options for the Print sink connector.
|
Printer |
Printer to print the results to the terminal.
|
Printer.ClearCommandPrinter |
Printer to clear the terminal.
|
Printer.HelpCommandPrinter |
Printer to print the HELP results.
|
Printer.InitializationCommandPrinter |
Printer prints the initialization command results.
|
Printer.QuitCommandPrinter |
Printer to print the QUIT messages.
|
Printer.StatementResultPrinter |
Printer prints the statement results.
|
PrintfFunction |
|
PrintSink<IN> |
Sink implementation writing every element to the standard output or standard error stream.
|
PrintSinkFunction<IN> |
Deprecated.
|
PrintSinkOutputWriter<IN> |
Print sink output writer for DataStream and DataSet print API.
|
PrintStyle |
|
PrintTableSinkFactory |
Print table sink factory writing every row to the standard output or standard error stream.
|
PrioritizedDeque<T> |
A deque-like data structure that supports prioritization of elements, such they will be polled
before any non-priority elements.
|
PrioritizedOperatorSubtaskState |
This class is a wrapper over multiple alternative OperatorSubtaskState that are (partial)
substitutes for each other and imposes a priority ordering over all alternatives for the
different states which define an order in which the operator should attempt to restore the state
from them.
|
PrioritizedOperatorSubtaskState.Builder |
A builder for PrioritizedOperatorSubtaskState.
|
PrioritizedOperatorSubtaskStateInputSplit |
|
PriorityComparable<T> |
Interface for objects that can be compared by priority.
|
PriorityComparator<T> |
This interface works similar to Comparable and is used to prioritize between two objects.
|
PriorityQueueSetFactory |
|
PrioritySettingThreadFactory |
Wrapper around a ThreadFactory that configures the thread priority.
|
PriorityThreadsDispatcher |
Pekko dispatcher threads creates threads with configurable priority.
|
ProbeIterator |
Probe iterator from probe or spilled partition.
|
Procedure |
Base interface representing a stored procedure that can be executed by Flink.
|
ProcedureContext |
A context to provide necessary context used by stored procedure.
|
ProcedureDefinition |
Definition of a procedure.
|
ProcedureHint |
A hint that influences the reflection-based extraction of arguments and output for constructing
the TypeInference logic of a Procedure .
|
ProcedureHints |
|
ProcedureNamespace |
Namespace whose contents are defined by the result of a call to a user-defined procedure.
|
ProcedureNotExistException |
Exception for trying to operate on a procedure that doesn't exist.
|
ProcessAllWindowFunction<IN,OUT,W extends Window> |
Base abstract class for functions that are evaluated over non-keyed windows using a context for
retrieving extra information.
|
ProcessConfigurable<T extends ProcessConfigurable<T>> |
This represents the configuration handle of processing.
|
ProcessConfigurableAndGlobalStreamImpl<T> |
|
ProcessConfigurableAndKeyedPartitionStreamImpl<K,T> |
|
ProcessConfigurableAndNonKeyedPartitionStreamImpl<T> |
|
ProcessConfigurableAndTwoKeyedPartitionStreamsImpl<K,OUT1,OUT2> |
|
ProcessConfigurableAndTwoNonKeyedPartitionStreamImpl<OUT1,OUT2> |
|
ProcessConfigureHandle<T,S extends ProcessConfigurable<S>> |
A handle to configure process function related things.
|
ProcessEvictingWindowReader<IN,OUT,KEY,W extends Window> |
A wrapper function for reading an evicting window with no pre-aggregation.
|
ProcessFunction |
Base class for all user defined process functions.
|
ProcessFunction<I,O> |
A function that processes elements of a stream.
|
ProcessingTimeManager |
This is responsibility for managing runtime information related to processing time of process
function.
|
ProcessingTimeoutTrigger<T,W extends Window> |
|
ProcessingTimeService |
|
ProcessingTimeService |
Defines the current processing time and handles all related actions, such as register timers for
tasks to be executed in the future.
|
ProcessingTimeService.ProcessingTimeCallback |
|
ProcessingTimeServiceAware |
|
ProcessingTimeServiceFactory |
A factory for creating processing time services with a given MailboxExecutor .
|
ProcessingTimeServiceUtil |
|
ProcessingTimeSessionWindows |
A WindowAssigner that windows elements into sessions based on the current processing
time.
|
ProcessingTimeTrigger |
A Trigger that fires once the current system time passes the end of the window to which a
pane belongs.
|
ProcessingTimeTriggers |
A Trigger that reacts to processing-time timers.
|
ProcessingTimeTriggers.AfterEndOfWindow<W extends Window> |
A Trigger that fires once the current system time passes the end of the window to
which a pane belongs.
|
ProcessingTimeTriggers.AfterEndOfWindowNoLate<W extends Window> |
A composite Trigger that consist of AfterEndOfWindow and a early trigger.
|
ProcessingTimeTriggers.AfterFirstElementPeriodic<W extends Window> |
Trigger every a given interval, the first trigger time is interval after the first element in
the pane.
|
ProcessJoinFunction<IN1,IN2,OUT> |
A function that processes two joined elements and produces a single output one.
|
ProcessMemoryOptions |
Common Flink's options to describe its JVM process memory configuration for JM or TM.
|
ProcessMemorySpec |
Common interface for Flink JVM process memory components.
|
ProcessMemoryUtils<FM extends FlinkMemory> |
Common utils to parse JVM process memory configuration for JM or TM.
|
ProcessMetricGroup |
AbstractImitatingJobManagerMetricGroup implementation for process related metrics.
|
ProcessOperator<IN,OUT> |
|
ProcessOperator<IN,OUT> |
|
ProcessorArchitecture |
The processor architecture of the this system.
|
ProcessorArchitecture.MemoryAddressSize |
The memory address size of the processor.
|
ProcessorContext |
|
ProcessPythonEnvironment |
|
ProcessPythonEnvironmentManager |
The ProcessPythonEnvironmentManager is used to prepare the working dir of python UDF worker and
create ProcessPythonEnvironment object of Beam Fn API.
|
ProcessWindowFunction<IN,OUT,KEY,W extends Window> |
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context
for retrieving extra information.
|
ProctimeAttribute |
Deprecated.
|
ProcTimeCommitPredicate |
Partition commit trigger by creation time and processing time service, if 'current processing
time' > 'partition creation time' + 'delay', the partition is committable.
|
ProcTimeCommitTrigger |
Partition commit trigger by creation time and processing time service.
|
ProcTimeDeduplicateKeepFirstRowFunction |
This function is used to deduplicate on keys and keeps only first row.
|
ProcTimeDeduplicateKeepLastRowFunction |
This function is used to deduplicate on keys and keeps only last row.
|
ProcTimeIntervalJoin |
The function to execute processing time interval stream inner-join.
|
ProcTimeMiniBatchAssignerOperator |
A stream operator that emits mini-batch marker in a given period.
|
ProcTimeMiniBatchDeduplicateKeepFirstRowFunction |
This function is used to get the first row for every key partition in miniBatch mode.
|
ProcTimeMiniBatchDeduplicateKeepLastRowFunction |
This function is used to get the last row for every key partition in miniBatch mode.
|
ProcTimeRangeBoundedPrecedingFunction<K> |
Process Function used for the aggregate in bounded proc-time OVER window.
|
ProcTimeRowsBoundedPrecedingFunction<K> |
Process Function for ROW clause processing-time bounded OVER window.
|
ProcTimeSortOperator |
Sort on proc-time and additional secondary sort attributes.
|
ProcTimeUnboundedPrecedingFunction<K> |
Process Function for processing-time unbounded OVER window.
|
ProducerDescriptor |
|
ProducerFailedException |
Network-stack level Exception to notify remote receiver about a failed partition producer.
|
ProducerMergedPartitionFile |
The partition file in the producer-merge mode.
|
ProducerMergedPartitionFileIndex |
|
ProducerMergedPartitionFileIndex.FixedSizeRegion |
Represents a series of buffers that are:
From the same subpartition
Logically (i.e. buffer index) consecutive
Physically (i.e. offset in the file) consecutive
|
ProducerMergedPartitionFileReader |
|
ProducerMergedPartitionFileReader.ProducerMergedReadProgress |
|
ProducerMergedPartitionFileWriter |
|
ProductionCodeArchitectureBase |
Central setup of architectural tests for the production code.
|
ProfilingFileMessageParameters |
|
ProfilingFileNamePathParameter |
|
ProfilingInfo |
Contains information of a Profiling Instance.
|
ProfilingInfo.ProfilingMode |
Supported profiling mode in async-profiler.
|
ProfilingInfo.ProfilingStatus |
Profiling Status.
|
ProfilingInfoList |
|
ProfilingRequestBody |
|
ProfilingService |
Create and keep profiling requests with rolling policy.
|
ProgramAbortException |
A special exception used to abort programs when the caller is only interested in the program
plan, rather than in the full execution.
|
ProgramArgQueryParameter |
Query parameter specifying one or more arguments for the program.
|
ProgramDescription |
Implementing this interface allows a Program to have a description of the plan which can be shown
to the user.
|
ProgramInvocationException |
Exception used to indicate that there is an error during the invocation of a Flink program.
|
ProgramMissingJobException |
Exception used to indicate that no job was executed during the invocation of a Flink program.
|
ProgramOptions |
Base class for command line options that refer to a JAR file program.
|
ProgramOptionsUtils |
|
ProgramParametrizationException |
Exception used to indicate that there is an error in the parametrization of a Flink program.
|
ProgressiveTimestampsAndWatermarks<T> |
An implementation of TimestampsAndWatermarks that does periodic watermark emission and
keeps track of watermarks on a per-split basis.
|
ProjectableDecodingFormat<I> |
|
ProjectableTableSource<T> |
Deprecated.
|
ProjectedRowData |
An implementation of RowData which provides a projected view of the underlying RowData .
|
Projection |
Projection represents a list of (possibly nested) indexes that can be used to project
data types.
|
Projection<IN extends RowData,OUT extends RowData> |
Interface for code generated projection, which will map a RowData to another one.
|
ProjectPushDownSpec |
|
ProjectQueryOperation |
Table operation that computes new table using given Expression s from its input relational
operation.
|
ProjectSnapshotTransposeRule |
|
ProjectSnapshotTransposeRule.Config |
|
ProjectWatermarkAssignerTransposeRule |
Transpose between the LogicalWatermarkAssigner and LogicalProject .
|
ProjectWindowTableFunctionTransposeRule |
Planner rule that pushes a LogicalProject into a LogicalTableFunctionScan which
contains a Window table function call by splitting the projection into a projection on top of
child of the TableFunctionScan.
|
PrometheusPushGatewayReporter |
|
PrometheusPushGatewayReporterFactory |
|
PrometheusPushGatewayReporterOptions |
|
PrometheusReporter |
|
PrometheusReporterFactory |
|
PropertiesUtil |
Simple utilities for getting typed values from Properties.
|
ProtobufInternalUtils |
This class is to access internal method in protobuf package.
|
ProtoToRowConverter |
ProtoToRowConverter can convert binary protobuf message data to flink row data by codegen
process.
|
ProtoUtils |
Utilities used to construct protobuf objects or construct objects from protobuf objects.
|
ProviderContext |
|
ProxyMetricGroup<P extends MetricGroup> |
Metric group which forwards all registration calls to its parent metric group.
|
Public |
Annotation for marking classes as public, stable interfaces.
|
PublicEvolving |
Annotation to mark classes and methods for public use, but with evolving interfaces.
|
PublishedVersionUtils |
Utilities for update and read the most-recently published flink version.
|
PullingAsyncDataInput<T> |
Interface defining couple of essential methods for asynchronous and non blocking data polling.
|
PullingAsyncDataInput.EndOfDataStatus |
Status for describing if we have reached the end of data.
|
PunctuatedWatermarkAssigner |
A punctuated watermark assigner.
|
PunctuatedWatermarkStrategyWrapper |
|
PurgingTrigger<T,W extends Window> |
A trigger that can turn any Trigger into a purging Trigger .
|
PushCalcPastChangelogNormalizeRule |
Pushes primary key filters and used fields project through a ChangelogNormalize operator to reduce its state size.
|
PushCalcPastChangelogNormalizeRule.Config |
|
PushFilterInCalcIntoTableSourceScanRule |
Pushes a filter condition from the FlinkLogicalCalc and into a FlinkLogicalTableSourceScan .
|
PushFilterIntoLegacyTableSourceScanRule |
|
PushFilterIntoLegacyTableSourceScanRule.PushFilterIntoLegacyTableSourceScanRuleConfig |
Rule configuration.
|
PushFilterIntoSourceScanRuleBase |
Base class for rules that push down filters into table scan.
|
PushFilterIntoTableSourceScanRule |
Planner rule that tries to push a filter into a LogicalTableScan , which table is a TableSourceTable .
|
PushingAsyncDataInput<T> |
|
PushingAsyncDataInput.DataOutput<T> |
Basic data output interface used in emitting the next element from data input.
|
PushLimitIntoLegacyTableSourceScanRule |
|
PushLimitIntoLegacyTableSourceScanRule.PushLimitIntoLegacyTableSourceScanRuleConfig |
|
PushLimitIntoTableSourceScanRule |
Planner rule that tries to push limit into a FlinkLogicalTableSourceScan , which table is
a TableSourceTable .
|
PushLocalAggIntoScanRuleBase |
Planner rule that tries to push a local aggregator into an BatchPhysicalTableSourceScan
whose table is a TableSourceTable with a source supporting SupportsAggregatePushDown .
|
PushLocalHashAggIntoScanRule |
Planner rule that tries to push a local hash aggregate which without sort into a BatchPhysicalTableSourceScan whose table is a TableSourceTable with a source supporting
SupportsAggregatePushDown .
|
PushLocalHashAggWithCalcIntoScanRule |
Planner rule that tries to push a local hash aggregate which with calc into a BatchPhysicalTableSourceScan whose table is a TableSourceTable with a source supporting
SupportsAggregatePushDown .
|
PushLocalSortAggIntoScanRule |
Planner rule that tries to push a local sort aggregate which without sort into a BatchPhysicalTableSourceScan whose table is a TableSourceTable with a source supporting
SupportsAggregatePushDown .
|
PushLocalSortAggWithCalcIntoScanRule |
Planner rule that tries to push a local sort aggregate which without sort into a BatchPhysicalTableSourceScan whose table is a TableSourceTable with a source supporting
SupportsAggregatePushDown .
|
PushLocalSortAggWithSortAndCalcIntoScanRule |
Planner rule that tries to push a local sort aggregate which with sort and calc into a BatchPhysicalTableSourceScan whose table is a TableSourceTable with a source supporting
SupportsAggregatePushDown .
|
PushLocalSortAggWithSortIntoScanRule |
Planner rule that tries to push a local sort aggregate which with sort into a BatchPhysicalTableSourceScan whose table is a TableSourceTable with a source supporting
SupportsAggregatePushDown .
|
PushPartitionIntoTableSourceScanRule |
Planner rule that tries to push partition evaluated by filter condition into a LogicalTableScan .
|
PushProjectIntoTableSourceScanRule |
|
PushProjectIntoTableSourceScanRule.Config |
|
PushSorter<E> |
|
PushWatermarkIntoTableSourceScanAcrossCalcRule |
Rule to push the FlinkLogicalWatermarkAssigner across the FlinkLogicalCalc to the
FlinkLogicalTableSourceScan .
|
PushWatermarkIntoTableSourceScanRule |
Rule to push the FlinkLogicalWatermarkAssigner into the FlinkLogicalTableSourceScan .
|
PushWatermarkIntoTableSourceScanRuleBase |
|
PythonAggregateFunction |
The wrapper of user defined python aggregate function.
|
PythonAggregateFunctionInfo |
PythonAggregateFunctionInfo contains the execution information of a Python aggregate function,
such as: the actual Python aggregation function, the input arguments, the filter arg, the
distinct flag, etc.
|
PythonBridgeUtils |
Utility class that contains helper methods to create a TableSource from a file which contains
Python objects.
|
PythonBroadcastStateTransformation<IN1,IN2,OUT> |
|
PythonBroadcastStateTransformationTranslator<IN1,IN2,OUT> |
|
PythonConfig |
Configurations for the Python job which are used at run time.
|
PythonConfigUtil |
A Util class to handle the configurations of Python jobs.
|
PythonConnectorUtils |
Utility class for using DataStream connectors in Python.
|
PythonConnectorUtils.FirstColumnTopicSelectorInvocationHandler |
|
PythonConnectorUtils.RowRowMapper |
|
PythonConnectorUtils.SecondColumnSerializationSchema<T> |
|
PythonCorrelateSplitRule |
Rule will split the Python FlinkLogicalTableFunctionScan with Java calls or the Java
FlinkLogicalTableFunctionScan with Python calls into a FlinkLogicalCalc which
will be the left input of the new FlinkLogicalCorrelate and a new FlinkLogicalTableFunctionScan .
|
PythonCsvUtils |
Utilities for using CSV format in PyFlink.
|
PythonDependencyInfo |
PythonDependencyInfo contains the information of third-party dependencies.
|
PythonDependencyUtils |
Utility class for Python dependency management.
|
PythonDriver |
A main class used to launch Python applications.
|
PythonDynamicTableFactory |
Table source factory for PythonDynamicTableSource.
|
PythonDynamicTableOptions |
Options for PythonDynamicTableSource.
|
PythonDynamicTableSource |
|
PythonEnv |
Python execution environments.
|
PythonEnv.ExecType |
The Execution type specifies how to execute the Python function.
|
PythonEnvironment |
The base interface of python environment for executing UDFs.
|
PythonEnvironmentManager |
The base interface of python environment manager which is used to create the PythonEnvironment
object used to execute Python functions.
|
PythonEnvironmentManagerUtils |
Utils used to prepare the python environment.
|
PythonFunction |
The base interface of a wrapper of a Python function.
|
PythonFunctionFactory |
The factory which creates the PythonFunction objects from given module name and object name.
|
PythonFunctionFactory.CacheKey |
The cache key.
|
PythonFunctionFactoryImpl |
Default implementation of PythonFunctionFactory.
|
PythonFunctionInfo |
PythonFunctionInfo contains the execution information of a Python function, such as: the actual
Python function, the input arguments, etc.
|
PythonFunctionKind |
Categorizes the Python functions.
|
PythonFunctionRunner |
The base interface of runner which is responsible for the execution of Python functions.
|
PythonFunctionUtils |
Utilities for creating PythonFunction from the fully qualified name of a Python function.
|
PythonGatewayServer |
The Py4j Gateway Server provides RPC service for user's python process.
|
PythonGatewayServer.Watchdog |
A simple watch dog interface.
|
PythonKeyedBroadcastStateTransformation<OUT> |
|
PythonKeyedBroadcastStateTransformationTranslator<OUT> |
|
PythonMapMergeRule |
Rule will merge Python FlinkLogicalCalc used in Map operation, Flatten FlinkLogicalCalc and Python FlinkLogicalCalc used in Map operation together.
|
PythonMapRenameRule |
Rule which renames the field names of the Flatten FlinkLogicalCalc which is right after a
FlinkLogicalCalc representing a Python Map operation to the output names of the map
function.
|
PythonOperatorChainingOptimizer |
A util class which attempts to chain all available Python functions.
|
PythonOperatorUtils |
Utilities used by Python operators.
|
PythonOptions |
Configuration options for the Python API.
|
PythonProgramOptions |
The class for command line options that refer to a Python program or JAR program with Python
command line options.
|
PythonScalarFunction |
The wrapper of user defined python scalar function.
|
PythonScalarFunctionOperator |
|
PythonSharedResources |
The set of resources that can be shared by all the Python operators in a slot.
|
PythonShellParser |
Command line parser for Python shell.
|
PythonStreamGroupAggregateOperator |
The Python AggregateFunction operator.
|
PythonStreamGroupTableAggregateOperator |
The Python TableAggregateFunction operator.
|
PythonStreamGroupWindowAggregateOperator<K,W extends Window> |
The Python Group Window AggregateFunction operator.
|
PythonTableAggregateFunction |
The wrapper of user defined python table aggregate function.
|
PythonTableFunction |
The wrapper of user defined python table function.
|
PythonTableFunctionOperator |
|
PythonTableUtils |
Python utilities.
|
PythonTypeUtils |
A util class for converting the given TypeInformation to other objects.
|
PythonTypeUtils |
Utilities for converting Flink logical types, such as convert it to the related TypeSerializer or
ProtoType.
|
PythonTypeUtils.ArrayDataConverter<T> |
The element in the Object Array will be converted to the corresponding Data through element
DataConverter.
|
PythonTypeUtils.ArrayDataConverter<T> |
The element in the Object Array will be converted to the corresponding Data through element
DataConverter.
|
PythonTypeUtils.ByteDataConverter |
Python Long will be converted to Long in PemJa, so we need ByteDataConverter to convert Java
Long to internal Byte.
|
PythonTypeUtils.ByteDataConverter |
Python Long will be converted to Long in PemJa, so we need ByteDataConverter to convert Java
Long to internal Byte.
|
PythonTypeUtils.DataConverter<IN,OUT> |
Data Converter that converts the data to the format data which can be used in PemJa.
|
PythonTypeUtils.DataConverter<IN,INTER,OUT> |
Data Converter that converts the data to the java format data which can be used in PemJa.
|
PythonTypeUtils.FloatDataConverter |
Python Float will be converted to Double in PemJa, so we need FloatDataConverter to convert
Java Double to internal Float.
|
PythonTypeUtils.FloatDataConverter |
Python Float will be converted to Double in PemJa, so we need FloatDataConverter to convert
Java Double to internal Float.
|
PythonTypeUtils.IdentityDataConverter<T> |
Identity data converter.
|
PythonTypeUtils.IdentityDataConverter<IN,OUT> |
Identity data converter.
|
PythonTypeUtils.IntDataConverter |
Python Long will be converted to Long in PemJa, so we need IntDataConverter to convert Java
Long to internal Integer.
|
PythonTypeUtils.IntDataConverter |
Python Long will be converted to Long in PemJa, so we need IntDataConverter to convert Java
Long to internal Integer.
|
PythonTypeUtils.ListDataConverter |
The element in the List will be converted to the corresponding Data through element
DataConverter.
|
PythonTypeUtils.LogicalTypeToProtoTypeConverter |
Converter That convert the logicalType to the related Prototype.
|
PythonTypeUtils.MapDataConverter |
The key/value in the Map will be converted to the corresponding Data through key/value
DataConverter.
|
PythonTypeUtils.MapDataConverter |
The key/value in the Map will be converted to the corresponding Data through key/value
DataConverter.
|
PythonTypeUtils.RowDataConverter |
Row Data will be converted to the Object Array [RowKind(as Long Object), Field Values(as
Object Array)].
|
PythonTypeUtils.RowDataConverter |
RowData will be converted to the Object Array [RowKind(as Long Object), Field Values(as
Object Array)].
|
PythonTypeUtils.RowDataDataConverter |
RowData Data will be converted to the Object Array [RowKind(as Long Object), Field Values(as
Object Array)].
|
PythonTypeUtils.ShortDataConverter |
Python Long will be converted to Long in PemJa, so we need ShortDataConverter to convert Java
Long to internal Short.
|
PythonTypeUtils.ShortDataConverter |
Python Long will be converted to Long in PemJa, so we need ShortDataConverter to convert Java
Long to internal Short.
|
PythonTypeUtils.TimeDataConverter |
Python datetime.time will be converted to Time in PemJa, so we need TimeDataConverter to
convert Java Double to internal Integer.
|
PythonTypeUtils.TupleDataConverter |
Tuple Data will be converted to the Object Array.
|
PythonTypeUtils.TypeInfoToDataConverter |
Get DataConverter according to the given typeInformation.
|
PythonTypeUtils.TypeInfoToProtoConverter |
Get coder proto according to the given type information.
|
PythonTypeUtils.TypeInfoToSerializerConverter |
Get serializers according to the given typeInformation.
|
PythonUtil |
Utility for Python.
|
QsConstants |
A class containing the constants used in the end-to-end test.
|
QsStateClient |
A simple implementation of a queryable state client.
|
QsStateProducer |
Streaming application that creates an Email pojo with random ids and increasing
timestamps and passes it to a stateful FlatMapFunction , where it is exposed as queryable state.
|
QuadConsumer<S,T,U,V> |
Operation which is performed on four given arguments.
|
QuadFunction<S,T,U,V,R> |
Function which takes three arguments.
|
Quantifier |
A quantifier describing the Pattern.
|
Quantifier.ConsumingStrategy |
Describes strategy for which events are matched in this Pattern .
|
Quantifier.QuantifierProperty |
|
Quantifier.Times |
Describe the times this Pattern can occur.
|
QuartzSchedulerUtils |
Utility class for quartz scheduler.
|
QueryableAppendingStateOperator<IN> |
Internal operator handling queryable AppendingState instances.
|
QueryableStateClient |
Deprecated.
|
QueryableStateConfiguration |
Simple configuration object for the parameters for the server-side of queryable state.
|
QueryableStateOptions |
Deprecated.
|
QueryableStateStream<K,V> |
Deprecated.
|
QueryableStateUtils |
Utility class to initialize entities used in queryable state.
|
QueryableValueStateOperator<IN> |
Internal operator handling queryable ValueState instances.
|
QueryHintsRelShuttle |
An abstract shuttle for each shuttle used for query hint.
|
QueryHintsResolver |
Resolve and validate the query hints.
|
QueryOperation |
Base class for representing an operation structure behind a user-facing Table API.
|
QueryOperationCatalogView |
|
QueryOperationCatalogViewTable |
|
QueryOperationConverter |
Converter from Flink's specific relational representation: QueryOperation to Calcite's
specific relational representation: RelNode .
|
QueryOperationDefaultVisitor<T> |
|
QueryOperationVisitor<T> |
Class that implements visitor pattern.
|
QueryScopeInfo |
Container for scope related information as required by the MetricQueryService.
|
QueryScopeInfo.JobManagerOperatorQueryScopeInfo |
Container for the job manager operator scope.
|
QueryScopeInfo.JobManagerQueryScopeInfo |
Container for the job manager scope.
|
QueryScopeInfo.JobQueryScopeInfo |
Container for the job scope.
|
QueryScopeInfo.OperatorQueryScopeInfo |
Container for the operator scope.
|
QueryScopeInfo.TaskManagerQueryScopeInfo |
Container for the task manager scope.
|
QueryScopeInfo.TaskQueryScopeInfo |
Container for the task scope.
|
QueueStatus |
Response type for temporary queue resources, i.e., resources that are asynchronously created.
|
QueueStatus.Id |
Defines queue statuses.
|
QueuingCallback<T> |
|
QuickSort |
|
QuickstartExample |
End to end test for quickstarts.
|
QuitOperation |
Operation that represent QUIT command.
|
QuitOperationParseStrategy |
|
RandomAccessInputView |
|
RandomAccessOutputView |
|
RandomGenerator<T> |
Random generator.
|
RandomGeneratorVisitor |
|
RangeBoundaries<T> |
RangeBoundaries is used to split the records into multiple ranges.
|
RangeBoundaryBuilder<T> |
Build RangeBoundaries with input records.
|
RangeFraction |
Range and fraction of a memory component, which is a capped fraction of another component.
|
RangeSlidingOverFrame |
The range sliding window frame calculates frames with the following SQL form: ...
|
RangeUnboundedFollowingOverFrame |
The range unboundedFollowing window frame calculates frames with the following SQL form: ...
|
RangeUnboundedPrecedingOverFrame |
The range UnboundPreceding window frame calculates frames with the following SQL form: ...
|
RankAggFunction |
built-in rank aggregate function.
|
RankLikeAggFunctionBase |
built-in rank like aggregate function, e.g. rank, dense_rank
|
RankOperator |
Rank operator to compute top N.
|
RankProcessStrategy |
Base class of Strategy to choose different rank process function.
|
RankProcessStrategy.AppendFastStrategy |
A strategy which only works when input only contains insertion changes.
|
RankProcessStrategy.RetractStrategy |
A strategy which works when input contains update or deletion changes.
|
RankProcessStrategy.UndefinedStrategy |
A placeholder strategy which will be inferred after FlinkChangelogModeInferenceProgram .
|
RankProcessStrategy.UpdateFastStrategy |
|
RankRange |
RankRange for Rank, including following 3 types : ConstantRankRange, ConstantRankRangeWithoutEnd,
VariableRankRange.
|
RankType |
An enumeration of rank type, usable to show how exactly generate rank number.
|
RateLimitedSourceReader<E,SplitT extends SourceSplit> |
Wraps the actual SourceReader and rate limits its data emission.
|
RateLimiter |
The interface to rate limit execution of methods.
|
RateLimiterStrategy |
A factory for RateLimiters which apply rate-limiting to a source sub-task.
|
RateLimitingStrategy |
RateLimitingStrategy is used to control the rate of requests.
|
RawByteArrayConverter<T> |
Converter for RawType of byte[] external type.
|
RawContentStyle |
Print only the result content as raw form. column delimiter is ",", row delimiter is "\n".
|
RawFormatDeserializationSchema |
Deserialization schema from raw (byte based) value to Flink Table/SQL internal data structure
RowData .
|
RawFormatFactory |
Format factory for raw format which allows to read and write raw (byte based) values as a single
column.
|
RawFormatOptions |
Options for the "raw" format.
|
RawFormatSerializationSchema |
Serialization schema that serializes an RowData object into raw (byte based) value.
|
RawJsonDeserializer |
Json deserializer which deserializes raw json.
|
RawObjectConverter<T> |
Converter for RawType of object external type.
|
RawRelDataType |
The RelDataType representation of a RawType .
|
RawType<T> |
Logical type of an arbitrary serialized type.
|
RawValueData<T> |
An internal data structure representing data of RawType .
|
RawValueDataSerializer<T> |
|
RawValueDataSerializer.RawValueDataSerializerSnapshot<T> |
|
ReadableConfig |
Read access to a configuration object.
|
Reader<T extends IOReadableWritable> |
A record-oriented reader for immutable record types.
|
ReaderBase |
The basic API for every reader.
|
ReaderInfo |
A container class hosting the information of a SourceReader .
|
ReaderIterator<T> |
|
ReaderOutput<T> |
The interface provided by the Flink runtime to the SourceReader to emit records, and
optionally watermarks, to downstream operators for message processing.
|
ReaderRegistrationEvent |
|
ReadingMetadataSpec |
|
ReadOnlyBroadcastState<K,V> |
|
ReadOnlySlicedNetworkBuffer |
Minimal best-effort read-only sliced Buffer implementation wrapping a NetworkBuffer 's sub-region based on io.netty.buffer.SlicedByteBuf and
io.netty.buffer.ReadOnlyByteBuf.
|
RebalancePartitioner<T> |
Partitioner that distributes the data equally by cycling through the output channels.
|
RecipientUnreachableException |
Exception which indicates that the specified recipient is unreachable.
|
Record |
The Record represents a multi-valued data record.
|
RecordAndPosition<E> |
A record, together with the reader position to be stored in the checkpoint.
|
RecordAttributes |
A RecordAttributes describes the attributes of records from the current RecordAttributes until
the next one is received.
|
RecordAttributesBuilder |
|
RecordAttributesCombiner |
RecordAttributesValve combine RecordAttributes from different input channels.
|
RecordComparator |
|
RecordContext<K> |
A context that preserves the necessary variables required by each operation, all operations for
one record will share the same element context.
|
RecordContext.DisposerRunner |
|
RecordCounter |
The RecordCounter is used to count the number of input records under the current key.
|
RecordDeserializer<T extends IOReadableWritable> |
Interface for turning sequences of memory segments into records.
|
RecordDeserializer.DeserializationResult |
Status of the deserialization result.
|
RecordEmitter<E,T,SplitStateT> |
Emit a record to the downstream.
|
RecordEqualiser |
Record equaliser for RowData which can compare two RowData and returns whether they are equal.
|
RecordEvaluator<T> |
An interface that evaluates whether a de-serialized record should trigger certain control-flow
operations (e.g. end of stream).
|
RecordMapperWrapperRecordIterator<I,O> |
|
RecordMapperWrapperRecordIterator.RecordMapper<I,O> |
Record mapper definition.
|
RecordProcessorUtils |
|
RecordReader<T extends IOReadableWritable> |
Record oriented reader for immutable types.
|
RecordsBySplits<E> |
An implementation of RecordsWithSplitIds to host all the records by splits.
|
RecordsBySplits.Builder<E> |
A utility builder to collect records in individual calls, rather than put a finished
collection in the RecordsBySplits(Map, Set) constructor.
|
RecordsCombiner |
|
RecordsCombiner.Factory |
|
RecordsCombiner.LocalFactory |
A factory that creates a RecordsCombiner used for combining at local stage.
|
RecordsWindowBuffer |
|
RecordsWindowBuffer.Factory |
|
RecordsWindowBuffer.LocalFactory |
|
RecordsWithSplitIds<E> |
An interface for the elements passed from the fetchers to the source reader.
|
RecordTimestampAssigner<E> |
|
RecordWiseCompactingFileWriter<IN> |
|
RecordWiseFileCompactor<IN> |
|
RecordWiseFileCompactor.Reader<T> |
The reader that reads record from the compacting files.
|
RecordWiseFileCompactor.Reader.Factory<T> |
|
RecordWiseFileCompactor.Writer<T> |
The writer that writers record into the compacting files.
|
RecordWriter<T extends IOReadableWritable> |
An abstract record-oriented runtime result writer.
|
RecordWriterBuilder<T extends IOReadableWritable> |
Utility class to encapsulate the logic of building a RecordWriter instance.
|
RecordWriterDelegate<T extends IOReadableWritable> |
The record writer delegate provides the availability function for task processor, and it might
represent a single RecordWriter or multiple RecordWriter instances in specific
implementations.
|
RecordWriterOutput<OUT> |
|
RecoverableFsDataOutputStream |
An output stream to a file system that can be recovered at well defined points.
|
RecoverableFsDataOutputStream.Committer |
A committer can publish the file of a stream that was closed.
|
RecoverableStreamTaskInput<T> |
|
RecoverableStreamWrapper |
|
RecoverableWriter |
|
RecoverableWriter.CommitRecoverable |
A handle to an in-progress stream with a defined and persistent amount of data.
|
RecoverableWriter.ResumeRecoverable |
A handle to an in-progress stream with a defined and persistent amount of data.
|
RecoveredInputChannel |
An input channel reads recovered state from previous unaligned checkpoint snapshots.
|
RecoveryClaimMode |
Defines state files ownership when Flink restore from a given savepoint or retained checkpoint.
|
RecoveryMetadata |
|
RecreateOnResetOperatorCoordinator |
|
RecreateOnResetOperatorCoordinator.Provider |
The provider for a private RecreateOnResetOperatorCoordinator.
|
RecyclableIterator<E> |
Utility base class for iterators that accept a recycler.
|
RedirectingSslHandler |
SSL handler which automatically redirects Non-SSL requests to SSL address.
|
ReduceApplyAllWindowFunction<W extends Window,T,R> |
|
ReduceApplyProcessAllWindowFunction<W extends Window,T,R> |
|
ReduceApplyProcessWindowFunction<K,W extends Window,T,R> |
|
ReduceApplyWindowFunction<K,W extends Window,T,R> |
|
ReduceCombineDriver<T> |
Combine operator for Reduce functions, standalone (not chained).
|
ReduceDriver<T> |
Reduce driver which is executed by a Task Manager.
|
ReduceEvictingWindowReaderFunction<IN,OUT,KEY,W extends Window> |
A wrapper function for reading state from an evicting window operator with a reduce function.
|
ReduceFunction<T> |
Base interface for Reduce functions.
|
ReduceOperatorBase<T,FT extends ReduceFunction<T>> |
Base data flow operator for Reduce user-defined functions.
|
ReduceOperatorBase.CombineHint |
An enumeration of hints, optionally usable to tell the system exactly how to execute the
combiner phase of a reduce.
|
ReduceTransformation<IN,K> |
|
ReduceTransformationTranslator<IN,KEY> |
|
ReducingState<T> |
State interface for reducing state.
|
ReducingState<T> |
State interface for reducing state.
|
ReducingStateAdaptor<K,N,V> |
|
ReducingStateDeclaration<T> |
This represents a declaration of the reducing state.
|
ReducingStateDescriptor<T> |
|
ReducingStateDescriptor<T> |
|
RedundantRankNumberColumnRemoveRule |
Planner rule that removes the output column of rank number iff the rank number column is not used
by successor calc.
|
RefCounted |
Interface to simply add reference counting functionality.
|
RefCountedBufferingFileStream |
|
RefCountedFile |
A reference counted file which is deleted as soon as no caller holds a reference to the wrapped
File .
|
RefCountedFileWithStream |
A reference counted file which is deleted as soon as no caller holds a reference to the wrapped
File .
|
RefCountedFSOutputStream |
|
RefCountedTmpFileCreator |
|
Reference<T> |
Wrapper class that allows to express whether the value is borrowed or owned.
|
ReferenceCounted<ReleaseHelper> |
An object that can be reference counted, the internal resource would be released when the
reference count reaches zero.
|
ReflectionUtil |
Utility for reflection operations on classes and generic type parametrization.
|
ReflectionUtil.FullTypeInfo |
Container for the full type information of a type.
|
RefreshHandler |
This interface represents the meta information of current materialized table background refresh
pipeline.
|
RefreshHandlerSerializer<T extends RefreshHandler> |
This interface is used to serialize and deserialize the RefreshHandler .
|
RefreshMaterializedTableHandler |
Handler to execute materialized table refresh operation.
|
RefreshMaterializedTableHeaders |
Message headers for executing a materialized table refresh operation.
|
RefreshMaterializedTableParameters |
|
RefreshMaterializedTableRequestBody |
RequestBody for executing materialized table refresh operation.
|
RefreshMaterializedTableResponseBody |
ResponseBody for executing a materialized table refresh operation.
|
RefreshWorkflow |
RefreshWorkflow is the basic interface that provide the related information to operate
the refresh workflow of CatalogMaterializedTable , the operation of refresh workflow
include create, modify, drop, etc.
|
RegexFileFilter |
A file filter that filters out hidden files, see DefaultFileFilter and the files whose
path doesn't match the given regex pattern.
|
RegexpCountFunction |
|
RegexpExtractAllFunction |
|
RegexpInstrFunction |
|
RegexpSubstrFunction |
|
RegionPartitionGroupReleaseStrategy |
Releases blocking intermediate result partitions that are incident to a SchedulingPipelinedRegion , as soon as the region's execution vertices are finished.
|
RegionPartitionGroupReleaseStrategy.Factory |
|
RegisteredBroadcastStateBackendMetaInfo<K,V> |
|
RegisteredKeyValueStateBackendMetaInfo<N,S> |
Compound meta information for a registered state in a keyed state backend.
|
RegisteredKeyValueStateBackendMetaInfo<N,S> |
Compound meta information for a registered state in a keyed state backend.
|
RegisteredOperatorStateBackendMetaInfo<S> |
Compound meta information for a registered state in an operator state backend.
|
RegisteredPriorityQueueStateBackendMetaInfo<T> |
Meta information about a priority queue state in a backend.
|
RegisteredRpcConnection<F extends Serializable,G extends RpcGateway,S extends RegistrationResponse.Success,R extends RegistrationResponse.Rejection> |
This utility class implements the basis of RPC connecting from one component to another
component, for example the RPC connection from TaskExecutor to ResourceManager.
|
RegisteredStateMetaInfoBase |
Base class for all registered state in state backends.
|
RegisteredStateMetaInfoBase.Key |
|
Registration |
A way to register a table in a TableEnvironment that this descriptor originates from.
|
RegistrationConnectionListener<T extends RegisteredRpcConnection<?,?,S,?>,S extends RegistrationResponse.Success,R extends RegistrationResponse.Rejection> |
Classes which want to be notified about the registration result by the RegisteredRpcConnection have to implement this interface.
|
RegistrationResponse |
|
RegistrationResponse.Failure |
A registration failure.
|
RegistrationResponse.Rejection |
A rejected (declined) registration.
|
RegistrationResponse.Success |
Base class for a successful registration.
|
RegistrationTimeoutException |
Exception which indicates that the TaskExecutor could not register at the master in time.
|
RegistryAvroDeserializationSchema<T> |
Deserialization schema that deserializes from Avro format using SchemaCoder .
|
RegistryAvroFormatFactory |
|
RegistryAvroSerializationSchema<T> |
Serialization schema that serializes to Avro format.
|
RegularOperatorChain<OUT,OP extends StreamOperator<OUT>> |
|
RegularToMutableObjectIterator<T> |
|
ReinterpretCastInputTypeStrategy |
|
RelativeClock |
A clock that gives access to relative time, similar to System#nanoTime(), however the progress of
the relative time doesn't have to reflect the progress of a wall clock.
|
RelativeFileStateHandle |
|
RelBuilder |
Copied from calcite to workaround CALCITE-4668
|
RelBuilder.AggCall |
Information necessary to create a call to an aggregate function.
|
RelBuilder.Config |
Configuration of RelBuilder.
|
RelBuilder.GroupKey |
Information necessary to create the GROUP BY clause of an Aggregate.
|
RelBuilder.OverCall |
Call to a windowed aggregate function.
|
RelDecorrelator |
RelDecorrelator replaces all correlated expressions (corExp) in a relational expression (RelNode)
tree with non-correlated expressions that are produced from joining the RelNode that produces the
corExp with the RelNode that references it.
|
RelDecorrelator.AdjustProjectForCountAggregateRule |
Planner rule that adjusts projects when counts are added.
|
RelDecorrelator.AdjustProjectForCountAggregateRule.AdjustProjectForCountAggregateRuleConfig |
Rule configuration.
|
RelDecorrelator.Config |
Base configuration for rules that are non-static in a RelDecorrelator.
|
RelDecorrelator.CorelMap |
A map of the locations of Correlate in a tree of RelNode s.
|
RelDecorrelator.CorelMapBuilder |
|
RelDecorrelator.RemoveCorrelationForScalarAggregateRule |
Planner rule that removes correlations for scalar aggregates.
|
RelDecorrelator.RemoveCorrelationForScalarAggregateRule.RemoveCorrelationForScalarAggregateRuleConfig |
Rule configuration.
|
RelDecorrelator.RemoveCorrelationForScalarProjectRule |
Planner rule that removes correlations for scalar projects.
|
RelDecorrelator.RemoveCorrelationForScalarProjectRule.RemoveCorrelationForScalarProjectRuleConfig |
Rule configuration.
|
RelDecorrelator.RemoveSingleAggregateRule |
Rule to remove an Aggregate with SINGLE_VALUE.
|
RelDecorrelator.RemoveSingleAggregateRule.RemoveSingleAggregateRuleConfig |
Rule configuration.
|
RelDescriptionWriterImpl |
Converts an RelNode to string with only the information from the RelNode itself without
the information from its inputs.
|
RelMdPredicates |
Utility to infer Predicates that are applicable above a RelNode.
|
ReloadTriggerContext |
|
RelTimeIndicatorConverter |
Traverses a RelNode tree and converts fields with TimeIndicatorRelDataType type.
|
RelWindowProperties |
It describes the information of window properties of a RelNode.
|
RemoteAddressExtension |
ActorSystem Extension used to obtain the Address
on which the given ActorSystem is listening.
|
RemoteAddressExtension.RemoteAddressExtensionImpl |
Actual Extension implementation.
|
RemoteCalcCallFinder |
Finds whether a RexNode contains remote calls or not.
|
RemoteChannelStateChecker |
|
RemoteEnvironmentConfigUtils |
A set of tools used by batch and streaming remote environments when preparing their
configurations.
|
RemoteExecutor |
The PipelineExecutor to be used when executing a job on an already running cluster.
|
RemoteExecutorFactory |
|
RemoteFencedMessage<F extends Serializable,P extends Serializable> |
|
RemoteHandshakeMessage |
Handshake message between rpc endpoints.
|
RemoteInputChannel |
An input channel, which requests a remote partition queue.
|
RemoteRecoveredInputChannel |
An input channel reads recovered state from previous unaligned checkpoint snapshots and then
converts into RemoteInputChannel finally.
|
RemoteRpcInvocation |
Remote rpc invocation message which is used when the actor communication is remote.
|
RemoteStorageScanner |
|
RemoteStreamEnvironment |
|
RemoteTierConsumerAgent |
The data client is used to fetch data from remote tier.
|
RemoteTierFactory |
|
RemoteTierMasterAgent |
|
RemoteTierProducerAgent |
|
RemoteTierShuffleDescriptor |
The shuffle descriptor implementation for remote tier.
|
RemoteTransportException |
|
RemoveJarOperation |
Operation to describe an REMOVE JAR statement.
|
RemoveRangeIndex<T> |
|
RemoveSplitsTask<SplitT extends SourceSplit> |
The task to finish reading some splits.
|
RemoveTimestampMapFunction<T> |
MapFunction which removes the timestamp field from the input element.
|
RemoveUnreachableCoalesceArgumentsRule |
|
RemoveUnreachableCoalesceArgumentsRule.Config |
|
ReOpenableHashPartition<BT,PT> |
|
ReOpenableMutableHashTable<BT,PT> |
|
RepeatingSequenceInputTypeStrategy |
|
ReplaceIntersectWithSemiJoinRule |
Planner rule that replaces distinct Intersect with a distinct Aggregate on a SEMI
Join .
|
ReplaceIntersectWithSemiJoinRule.ReplaceIntersectWithSemiJoinRuleConfig |
Rule configuration.
|
ReplaceMinusWithAntiJoinRule |
Planner rule that replaces distinct Minus (SQL keyword:
EXCEPT) with a distinct Aggregate on an ANTI Join .
|
ReplaceMinusWithAntiJoinRule.ReplaceMinusWithAntiJoinRuleConfig |
Rule configuration.
|
ReplaceScanWithCalcShuttle |
Replace CommonPhysicalTableSourceScan with Calc .
|
ReplaceTableAsOperation |
Operation to describe a [CREATE OR] REPLACE TABLE AS statement.
|
ReplicateRowsFunction |
Replicate the row N times.
|
ReplicatingInputFormat<OT,S extends InputSplit> |
A ReplicatingInputFormat replicates any InputFormat to all parallel instances of a
DataSource, i.e., the full input of the replicated InputFormat is completely processed by each
parallel instance of the DataSource.
|
ReplicatingInputSplitAssigner |
Assigns each InputSplit to each requesting parallel instance.
|
ReportedWatermarkEvent |
|
ReporterScopedSettings |
Encapsulates all settings that are defined per reporter.
|
ReporterSetup |
Encapsulates everything needed for the instantiation and configuration of a MetricReporter .
|
RequestBody |
Marker interface for all requests of the REST API.
|
RequestDoneCallback<T> |
Callback to be executed on completion of an asynchronous I/O request.
|
RequestEntryWrapper<RequestEntryT> |
A wrapper that contains a RequestEntryT ready to be written by the Sink Writer class,
along with the size of that entry as defined by the method getSizeInBytes(RequestEntryT)
of the AsyncSinkWriter .
|
RequestFailure |
A message indicating a protocol-related error.
|
RequestInfo |
Interface for dataclass used to encapsulate information about starting requests.
|
RequestJobDetails |
This message requests an overview of the jobs on the JobManager, including running jobs and/or
finished jobs.
|
RequestJobsOverview |
This message requests an overview of how many jobs are in which status.
|
RequestJobsWithIDsOverview |
This message requests an overview of how many jobs are in which status.
|
RequestQueue<E> |
|
RequestSlotMatchingStrategy |
Strategy to match slot requests to slots.
|
RequestSlotMatchingStrategy.RequestSlotMatch |
Result class representing matches.
|
RequestSplitEvent |
An event to request splits, sent typically from the Source Reader to the Source Enumerator.
|
RequestStatusOverview |
This message requests an overview of the status, such as how many TaskManagers are currently
connected, how many slots are available, how many are free, ...
|
RequireCatalogLock |
Deprecated.
|
RequirementMatcher |
A matcher for resource profiles to requirements.
|
RescaleMappings |
Contains the fine-grain channel mappings that occur when a connected operator has been rescaled.
|
RescalePartitioner<T> |
Partitioner that distributes the data equally by cycling through the output channels.
|
RescalingHandlers |
Rest handler to trigger and poll the rescaling of a running job.
|
RescalingParallelismQueryParameter |
|
RescalingStatusHeaders |
Message headers for polling the status of an ongoing rescaling operation.
|
RescalingStatusMessageParameters |
|
RescalingStreamTaskNetworkInput<T> |
|
RescalingTriggerHeaders |
Message headers for triggering the rescaling of a job.
|
RescalingTriggerMessageParameters |
|
ReservedSlots |
|
ReserveSlotFunction |
A function for reserving slots.
|
ResetOperation |
Operation to represent RESET command.
|
ResetOperationParseStrategy |
|
ResettableDriver<S extends Function,OT> |
This interface marks a Driver as resettable, meaning that will reset part of their
internal state but otherwise reuse existing data structures.
|
ResettableExternalBuffer |
A resettable external buffer for binary row.
|
ResettableIterator<E> |
The resettable iterator is a specialization of the iterator, allowing to reset the iterator and
re-retrieve elements.
|
ResettableMutableObjectIterator<E> |
The resettable iterator is a specialization of the iterator, allowing to reset the iterator and
re-retrieve elements.
|
ResettableRowBuffer |
|
ResettableRowBuffer.ResettableIterator |
Row iterator that can be reset.
|
ResettableValue<T extends Value> |
|
ResolvedCatalogBaseTable<T extends CatalogBaseTable> |
A common parent that describes the resolved metadata of a table or view in a catalog.
|
ResolvedCatalogMaterializedTable |
|
ResolvedCatalogModel |
A validated CatalogModel that is backed by the original metadata coming from the Catalog but resolved by the framework.
|
ResolvedCatalogTable |
A validated CatalogTable that is backed by the original metadata coming from the Catalog but resolved by the framework.
|
ResolvedCatalogView |
A validated CatalogView that is backed by the original metadata coming from the Catalog but resolved by the framework.
|
ResolvedExpression |
Expression that has been fully resolved and validated.
|
ResolvedExpressionDefaultVisitor<T> |
|
ResolvedExpressionVisitor<R> |
|
ResolvedFieldReference |
A reference to a field in an input which has been resolved.
|
ResolvedSchema |
Schema of a table or view consisting of columns, constraints, and watermark specifications.
|
ResolverRule |
Rule that can be applied during resolution of Expression .
|
ResolverRule.ResolutionContext |
Contextual information that can be used during application of the rule.
|
ResolverRules |
|
Resource<T extends Resource<T>> |
Base class for resources one can specify.
|
ResourceAllocationResult |
|
ResourceAllocationResult.Builder |
|
ResourceAllocationStrategy |
Strategy for allocating slots and task managers to fulfill the unfulfilled requirements.
|
ResourceAllocator |
Resource related actions which the SlotManager can perform.
|
ResourceBudgetManager |
|
ResourceCleaner |
ResourceCleaner executes instances on the given JobID .
|
ResourceCleanerFactory |
ResourceCleanerFactory provides methods to create ResourceCleaner for local and
global cleanup.
|
ResourceCounter |
|
ResourceDeclaration |
|
ResourceEventHandler<WorkerType extends ResourceIDRetrievable> |
Callback interfaces for handling resource events from external resource managers.
|
ResourceEventListener |
|
ResourceGuard |
This class is a guard for shared resources with the following invariants.
|
ResourceID |
Class for Resource Ids identifying Flink's distributed components.
|
ResourceIDDeserializer |
|
ResourceIDRetrievable |
An interface to retrieve the ResourceID of an object.
|
ResourceIDSerializer |
|
ResourceManager<WorkerType extends ResourceIDRetrievable> |
ResourceManager implementation.
|
ResourceManager |
A manager for dealing with all user defined resource.
|
ResourceManagerAddress |
Current address and fencing token of the leading ResourceManager.
|
ResourceManagerDriver<WorkerType extends ResourceIDRetrievable> |
A ResourceManagerDriver is responsible for requesting and releasing resources from/to a
particular external resource manager.
|
ResourceManagerException |
|
ResourceManagerFactory<T extends ResourceIDRetrievable> |
|
ResourceManagerGateway |
|
ResourceManagerId |
|
ResourceManagerMetricGroup |
|
ResourceManagerOptions |
The set of configuration options relating to the ResourceManager.
|
ResourceManagerPartitionTracker |
Utility for tracking and releasing partitions on the ResourceManager.
|
ResourceManagerPartitionTrackerFactory |
|
ResourceManagerPartitionTrackerImpl |
|
ResourceManagerProcessContext |
This class contains information and services needed for creating a ResourceManager , which do not change during the
lifetime of the process and can be reused between multiple resource manager instances in the
process.
|
ResourceManagerRuntimeServices |
|
ResourceManagerRuntimeServicesConfiguration |
|
ResourceManagerService |
|
ResourceManagerServiceImpl |
|
ResourceManagerUtils |
Common utils for ResourceManager.
|
ResourceOverview |
Class containing information about the available cluster resources.
|
ResourceProfile |
Describe the immutable resource profile of the slot, either when requiring or offering it.
|
ResourceProfile.Builder |
|
ResourceProfileInfo |
|
ResourceReconcileResult |
|
ResourceReconcileResult.Builder |
|
ResourceRequirement |
Represents the number of required resources for a specific ResourceProfile .
|
ResourceRequirements |
Represents the total resource requirements for a job, and the information required to connect to
the corresponding job master.
|
ResourceSpec |
Describe the different resource factors of the operator with UDF.
|
ResourceSpec.Builder |
|
ResourceTestUtils |
Test utils around module resources.
|
ResourceTracker |
Tracks for each job how many resource are required/acquired.
|
ResourceType |
An enum that represents the type of resource.
|
ResourceUri |
Description of resource information.
|
ResourceVersion<R> |
Resource version for specific state handle on the underlying storage.
|
ResponseBody |
Marker interface for all responses of the REST API.
|
RestAPIDocGenerator |
Generator for the Rest API documentation.
|
RestAPIVersion<T extends RestAPIVersion<T>> |
Interface for all versions of the REST API.
|
RestartAllFailoverStrategy |
A failover strategy that proposes to restart all vertices when a vertex fails.
|
RestartAllFailoverStrategy.Factory |
|
RestartBackoffTimeStrategy |
Strategy to decide whether to restart failed tasks and the delay to do the restarting.
|
RestartBackoffTimeStrategy.Factory |
|
RestartBackoffTimeStrategyFactoryLoader |
|
RestartPipelinedRegionFailoverStrategy |
A failover strategy that proposes to restart involved regions when a vertex fails.
|
RestartPipelinedRegionFailoverStrategy.Factory |
|
RestartStrategyDescriptionUtils |
Utility class for describing restart strategies.
|
RestartStrategyOptions |
Config options for restart strategies.
|
RestartStrategyOptions.RestartStrategyType |
The restart strategy type.
|
RestClient |
|
RestClientConfiguration |
|
RestClientException |
An exception that is thrown if the failure of a REST operation was detected on the client.
|
RestClusterClient<T> |
A ClusterClient implementation that communicates via HTTP REST requests.
|
RestClusterClientConfiguration |
|
RestConstants |
This class contains constants to be used by rest components.
|
RestEndpointFactory<T extends RestfulGateway> |
|
RestfulGateway |
Gateway for restful endpoints.
|
RestHandlerConfiguration |
Configuration object containing values for the rest handler configuration.
|
RestHandlerException |
An exception that is thrown if the failure of a REST operation was detected by a handler.
|
RestHandlerException.LoggingBehavior |
Enum to control logging behavior of RestHandlerExceptions.
|
RestHandlerSpecification |
Rest handler interface which all rest handler implementation have to implement.
|
RestMapperUtils |
This class contains utilities for mapping requests and responses to/from JSON.
|
RestOptions |
Configuration parameters for REST communication.
|
RestoredCheckpointStats |
Statistics for a restored checkpoint.
|
RestoreOperation<R> |
Interface for restore operation.
|
RestServerEndpoint |
An abstract class for netty-based REST server endpoints.
|
RestServerEndpoint.RestHandlerUrlComparator |
Comparator for Rest URLs.
|
RestServerEndpoint.RestHandlerUrlComparator.CaseInsensitiveOrderComparator |
Comparator for Rest URLs.
|
RestServerEndpointConfiguration |
|
RestService |
Rest service interface.
|
Result<VID extends VertexID,RID extends ResultID,V extends Vertex<VID,RID,V,R>,R extends Result<VID,RID,V,R>> |
Represents a data set produced by a Vertex Each result is produced by one Vertex .
|
ResultDescriptor |
Describes a result to be expected from a table program.
|
ResultFetcher |
A fetcher to fetch result from submitted statement.
|
ResultFuture<OUT> |
ResultFuture collects data / error in user codes while processing async i/o.
|
ResultHandler<T> |
|
ResultID |
|
ResultInfo |
Interface for dataclass used to encapsulate results from completed requests.
|
ResultInfo |
A ResultInfo contains information of a ResultSet .
|
ResultInfoDeserializer |
|
ResultInfoSerializer |
|
ResultKind |
ResultKind defines the types of the result.
|
ResultMode |
The mode when display the result of the query in the sql client.
|
ResultPartition |
A result partition for data produced by a single task.
|
ResultPartitionAvailabilityChecker |
This checker helps to query result partition availability.
|
ResultPartitionBytes |
This class represents a snapshot of the result partition bytes metrics.
|
ResultPartitionBytesCounter |
This counter will count the data size of a partition.
|
ResultPartitionDeploymentDescriptor |
Deployment descriptor for a result partition.
|
ResultPartitionFactory |
|
ResultPartitionID |
|
ResultPartitionManager |
The result partition manager keeps track of all currently produced/consumed partitions of a task
manager.
|
ResultPartitionMetrics |
Collects metrics of a result partition.
|
ResultPartitionProvider |
Interface for creating result partitions.
|
ResultPartitionState |
|
ResultPartitionType |
Type of a result partition.
|
ResultPartitionWriter |
A record-oriented runtime result writer API for producing results.
|
ResultProvider |
An internal class which helps the client to get the execute result from a specific sink.
|
ResultRetryStrategy |
A utility class to wrap the data stream api AsyncRetryStrategy to support both sync and
async retry in table module.
|
ResultSet |
A ResultSet represents the collection of the results.
|
ResultSet.ResultType |
Describe the kind of the result.
|
ResultSetImpl |
|
ResultStore |
A result store which stores and buffers results.
|
ResultSubpartition |
|
ResultSubpartition.BufferAndBacklog |
A combination of a Buffer and the backlog length indicating how many non-event
buffers are available in the subpartition.
|
ResultSubpartitionIndexSet |
A collection of subpartition indexes.
|
ResultSubpartitionInfo |
|
ResultSubpartitionStateHandle |
|
ResultSubpartitionView |
|
ResultSubpartitionView.AvailabilityWithBacklog |
|
ResultTypeQueryable<T> |
This interface can be implemented by functions and input formats to tell the framework about
their produced data type.
|
ResumeEmbeddedSchedulerWorkflowHandler |
Handler to resume workflow in embedded scheduler.
|
ResumeEmbeddedSchedulerWorkflowHeaders |
Message headers for resume workflow in embedded scheduler.
|
ResumeEmbeddedSchedulerWorkflowRequestBody |
|
ResumeRefreshWorkflow<T extends RefreshHandler> |
|
RetractableTopNFunction |
A TopN function could handle updating stream.
|
RetractStreamTableSink<T> |
Deprecated.
|
RetrievableStateHandle<T extends Serializable> |
|
RetrievableStateStorageHelper<T extends Serializable> |
State storage helper which is used by StateHandleStore to persist state before the state
handle is written to the underlying system.
|
RetrievableStreamStateHandle<T extends Serializable> |
Wrapper around a StreamStateHandle to make the referenced state object retrievable trough
a simple get call.
|
RetryableAsyncLookupFunctionDelegator |
|
RetryableLookupFunctionDelegator |
|
RetryExtension |
An extension to let failed test retry.
|
RetryingRegistration<F extends Serializable,G extends RpcGateway,S extends RegistrationResponse.Success,R extends RegistrationResponse.Rejection> |
This utility class implements the basis of registering one component at another component, for
example registering the TaskExecutor at the ResourceManager.
|
RetryingRegistrationConfiguration |
Configuration for the cluster components.
|
RetryOnException |
|
RetryOnExceptionStrategy |
A retry strategy that will ignore a specific type of exception and retry a test if it occurs, up
to a fixed number of times.
|
RetryOnFailure |
|
RetryOnFailureStrategy |
Retry strategy that retry fixed times.
|
RetryPolicy |
Retry policy to use by RetryingExecutor .
|
RetryPolicy.FixedRetryPolicy |
RetryPolicy with fixed timeout, delay and max attempts.
|
RetryPredicates |
Utility class to create concrete retry predicates.
|
RetryPredicates |
Contains retry predicates used to determine if a result or error should result in a retry.
|
RetryPredicates.AnyExceptionStrategy |
Returns true for any exception.
|
RetryPredicates.EmptyResponseResultStrategy |
Returns true if the response is null or empty.
|
RetryRule |
A rule to retry failed tests for a fixed number of times.
|
RetryStrategy |
Retry strategy for executing retry tests.
|
RetryStrategy |
Interface that encapsulates retry logic.
|
RetryTestExecutionExtension |
Extension to decide whether a retry test should run.
|
ReturnAndJumpCounter |
Simple parser that counts combined number of 'return', 'continue' and 'break' kay words.
|
ReturnValueRewriter |
Rewrite functions with return values by splitting them into two functions and storing the return
values into member variables.
|
ReusableScanVisitor |
Find reusable sources.
|
ReusingBlockResettableIterator<T> |
Implementation of an iterator that fetches a block of data into main memory and offers resettable
access to the data in that block.
|
ReusingBuildFirstHashJoinIterator<V1,V2,O> |
An implementation of the JoinTaskIterator that
uses a hybrid-hash-join internally to match the records with equal key.
|
ReusingBuildFirstReOpenableHashJoinIterator<V1,V2,O> |
|
ReusingBuildSecondHashJoinIterator<V1,V2,O> |
An implementation of the JoinTaskIterator that
uses a hybrid-hash-join internally to match the records with equal key.
|
ReusingBuildSecondReOpenableHashJoinIterator<V1,V2,O> |
|
ReusingDeserializationDelegate<T> |
|
ReusingKeyGroupedIterator<E> |
The KeyValueIterator returns a key and all values that belong to the key (share the same key).
|
ReusingMergeInnerJoinIterator<T1,T2,O> |
|
ReusingMergeOuterJoinIterator<T1,T2,O> |
|
ReusingMutableToRegularIteratorWrapper<T> |
|
ReusingSortMergeCoGroupIterator<T1,T2> |
|
RewriteMinusAllRule |
Replaces logical Minus operator using a combination of union all, aggregate and table
function.
|
RewriteMinusAllRule.RewriteMinusAllRuleConfig |
Rule configuration.
|
RewriteMultiJoinConditionRule |
Planner rule to apply transitive closure on MultiJoin for equi-join predicates.
|
RewriteMultiJoinConditionRule.RewriteMultiJoinConditionRuleConfig |
Rule configuration.
|
RexFactory |
Planner internal factory for parsing/translating to RexNode .
|
RexFieldAccess |
Access to a field of a row-expression.
|
RexLiteralUtil |
Utilities to work with RexLiteral .
|
RexNodeExpression |
|
RexSetSemanticsTableCall |
A special RexCall that is used to represent a table function with set semantics.
|
RexUtil |
Default implementation of RexUtil , the class was copied over
because of current Calcite way of inferring constants from IS NOT DISTINCT FROM clashes with
filter push down.
|
RexUtil.ExprSimplifier |
Deprecated. |
RexUtil.FieldAccessFinder |
Visitor which builds a bitmap of the inputs used by an expression.
|
RexUtil.FixNullabilityShuttle |
Shuttle that fixes up an expression to match changes in nullability of input fields.
|
RexUtil.RexFinder |
Visitor that tells whether a node matching a particular description exists in a tree.
|
RexUtil.SubQueryFinder |
Visitor that throws Util.FoundOne if applied to an expression
that contains a RexSubQuery .
|
RichAggregateFunction<IN,ACC,OUT> |
|
RichAllWindowFunction<IN,OUT,W extends Window> |
|
RichAndCondition<T> |
A condition which combines two conditions with a logical
AND and returns true if both are true .
|
RichAsyncFunction<IN,OUT> |
|
RichCoFlatMapFunction<IN1,IN2,OUT> |
A RichCoFlatMapFunction represents a FlatMap transformation with two different input types.
|
RichCoGroupFunction<IN1,IN2,OUT> |
|
RichCoMapFunction<IN1,IN2,OUT> |
A RichCoMapFunction represents a Map transformation with two different input types.
|
RichCompositeIterativeCondition<T> |
|
RichCrossFunction<IN1,IN2,OUT> |
|
RichFilterFunction<T> |
|
RichFlatJoinFunction<IN1,IN2,OUT> |
|
RichFlatMapFunction<IN,OUT> |
|
RichFunction |
An base interface for all rich user-defined functions.
|
RichGroupCombineFunction<IN,OUT> |
|
RichGroupReduceFunction<IN,OUT> |
|
RichInputFormat<OT,T extends InputSplit> |
An abstract stub implementation for Rich input formats.
|
RichIterativeCondition<T> |
|
RichJoinFunction<IN1,IN2,OUT> |
|
RichMapFunction<IN,OUT> |
|
RichMapPartitionFunction<I,O> |
|
RichNotCondition<T> |
A condition which negates the condition it wraps and returns
true if the original condition returns false .
|
RichOrCondition<T> |
A condition which combines two conditions with a logical
OR and returns true if at least one is true .
|
RichOutputFormat<IT> |
An abstract stub implementation for Rich output formats.
|
RichParallelSourceFunction<OUT> |
Deprecated.
|
RichPatternFlatSelectFunction<IN,OUT> |
|
RichPatternSelectFunction<IN,OUT> |
|
RichReduceFunction<T> |
|
RichSinkFunction<IN> |
Deprecated.
|
RichSourceFunction<OUT> |
Deprecated.
|
RichSqlInsert |
A SqlInsert that have some extension functions like partition, overwrite
|
RichSqlInsertKeyword |
Defines the keywords that can occur immediately after the "INSERT" keyword.
|
RichTableSourceQueryOperation<T> |
|
RichWindowFunction<IN,OUT,KEY,W extends Window> |
|
RightOuterJoinDriver<IT1,IT2,OT> |
The right outer join driver implements the logic of an outer join operator at runtime.
|
RobustActorSystem |
|
RocksDBCachingPriorityQueueSet<E extends HeapPriorityQueueElement> |
A priority queue with set semantics, implemented on top of RocksDB.
|
RocksDBCachingPriorityQueueSet.OrderedByteArraySetCache |
Cache that is organized as an ordered set for byte-arrays.
|
RocksDBConfigurableOptions |
Deprecated.
|
RocksDBConfigurableOptions |
|
RocksDBFullRestoreOperation<K> |
Encapsulates the process of restoring a RocksDB instance from a full snapshot.
|
RocksDBFullSnapshotResources<K> |
|
RocksDBHeapTimersFullRestoreOperation<K> |
Encapsulates the process of restoring a RocksDB instance from a full snapshot.
|
RocksDBIncrementalCheckpointUtils |
Utils for RocksDB Incremental Checkpoint.
|
RocksDBIncrementalCheckpointUtils.RangeCheckResult |
Helper class that represents the result of a range check of the actual keys in a RocksDB
instance against the proclaimed key-group range of the instance.
|
RocksDBIncrementalRestoreOperation<K> |
Encapsulates the process of restoring a RocksDB instance from an incremental snapshot.
|
RocksDBKeyedStateBackend<K> |
|
RocksDBKeyedStateBackend.RocksDbKvStateInfo |
Rocks DB specific information about the k/v states.
|
RocksDBKeyedStateBackendBuilder<K> |
|
RocksDBManualCompactionConfig |
|
RocksDBManualCompactionConfig.Builder |
|
RocksDBManualCompactionManager |
Manages compactions of small and disjoint RocksDB SST files that otherwise would not be merged to
reduce write amplification.
|
RocksDBManualCompactionOptions |
Configuration options for manual compaction for the RocksDB backend.
|
RocksDBMemoryConfiguration |
The settings regarding RocksDBs memory usage.
|
RocksDBMemoryControllerUtils |
Utils to create Cache and WriteBufferManager which are used to control total
memory usage of RocksDB.
|
RocksDBMemoryControllerUtils.RocksDBMemoryFactory |
Factory for Write Buffer Manager and Bock Cache.
|
RocksDBNativeMetricMonitor |
A monitor which pulls {RocksDB } native metrics and forwards them to Flink's metric group.
|
RocksDBNativeMetricOptions |
Deprecated.
|
RocksDBNativeMetricOptions |
Enable which RocksDB metrics to forward to Flink's metrics reporter.
|
RocksDBNoneRestoreOperation<K> |
Encapsulates the process of initiating a RocksDB instance without restore.
|
RocksDBOperationUtils |
Utils for RocksDB Operations.
|
RocksDBOptions |
Deprecated.
|
RocksDBOptions |
Configuration options for the RocksDB backend.
|
RocksDBOptionsFactory |
Deprecated.
|
RocksDBOptionsFactory |
|
RocksDBPriorityQueueConfig |
The configuration of rocksDB priority queue state implementation.
|
RocksDBPriorityQueueSetFactory |
Encapsulates the logic and resources in connection with creating priority queue state structures,
for RocksDB backend.
|
RocksDBProperty |
RocksDB properties that can be queried by Flink's metrics reporter.
|
RocksDBResourceContainer |
The container for RocksDB resources, including predefined options, option factory and shared
resource among instances.
|
RocksDBRestoreOperation |
Interface for RocksDB restore.
|
RocksDBRestoreResult |
Entity holding result of RocksDB instance restore.
|
RocksDBSnapshotStrategyBase<K,R extends SnapshotResources> |
Abstract base class for SnapshotStrategy implementations for RocksDB state backend.
|
RocksDBSnapshotStrategyBase.NativeRocksDBSnapshotResources |
|
RocksDBSnapshotStrategyBase.PreviousSnapshot |
Previous snapshot with uploaded sst files.
|
RocksDBStateDataTransferHelper |
|
RocksDBStateDownloader |
Help class for downloading RocksDB state files.
|
RocksDBStateMemoryControlTestProgram |
The test program for a job that simply accumulates data in various states.
|
RocksDBStateUploader |
Help class for uploading RocksDB state files.
|
RocksDbTtlCompactFiltersManager |
RocksDB compaction filter utils for state with TTL.
|
RocksDBWriteBatchWrapper |
It's a wrapper class around RocksDB's WriteBatch for writing in bulk.
|
RocksIncrementalSnapshotStrategy<K> |
Snapshot strategy for RocksDBKeyedStateBackend that is
based on RocksDB's native checkpoints and creates incremental snapshots.
|
RocksIteratorWrapper |
This class was originally a wrapper around RocksIterator to check the iterator status for
all the methods mentioned to require this check in the wiki documentation: seek, next,
seekToFirst, seekToLast, seekForPrev, and prev.
|
RocksNativeFullSnapshotStrategy<K> |
Snapshot strategy for RocksDBKeyedStateBackend based on RocksDB's native checkpoints and
creates full snapshots. the difference between savepoint is that sst files will be uploaded
rather than states.
|
RocksQueueIterator |
An iterator over heap timers that produces rocks compatible binary format.
|
RocksSnapshotUtil |
|
RocksStateKeysAndNamespaceIterator<K,N> |
|
RocksStateKeysIterator<K> |
|
RocksStatesPerKeyGroupMergeIterator |
Iterator that merges multiple RocksDB iterators to partition all states into contiguous
key-groups.
|
RocksTransformingIteratorWrapper |
|
RollingPolicy<IN,BucketID> |
The policy based on which a Bucket in the Filesystem Sink rolls its currently
open part file and opens a new one.
|
RootArgumentTypeStrategy |
Strategy for an argument that corresponds to a given LogicalTypeRoot and nullability.
|
RootExceptionHistoryEntry |
RootExceptionHistoryEntry extending ExceptionHistoryEntry by providing a list of
ExceptionHistoryEntry instances to store concurrently caught failures.
|
RoundRobinChannelSelector<T extends IOReadableWritable> |
|
RoundRobinOperatorStateRepartitioner |
|
RoundRobinSubpartitionSelector<T> |
|
RoutedRequest<T> |
Class for handling HttpRequest with associated RouteResult .
|
Router<T> |
This is adopted and simplified code from tv.cntt:netty-router library.
|
RouteResult<T> |
This is adopted and simplified code from tv.cntt:netty-router library.
|
RouterHandler |
Inbound handler that converts HttpRequest to Routed and passes Routed to the matched handler.
|
Row |
A row is a fixed-length, null-aware composite type for storing multiple values in a deterministic
field order.
|
RowColumnVector |
Row column vector.
|
RowComparator |
|
RowCsvInputFormat |
Input format that reads csv into Row .
|
RowCsvInputFormat |
Deprecated.
|
RowCsvInputFormat.Builder |
|
RowData |
Base interface for an internal data structure representing data of RowType and other
(possibly nested) structured types such as StructuredType in the table ecosystem.
|
RowData.FieldGetter |
Accessor for getting the field of a row during runtime.
|
RowDataEventComparator |
|
RowDataGenerator |
Data generator for Flink's internal RowData type.
|
RowDataKeySelector |
RowDataKeySelector takes an RowData and extracts the deterministic key for the RowData.
|
RowDataLocalTimeZoneConverter |
|
RowDataPartitionComputer |
|
RowDataSerializer |
|
RowDataSerializer |
|
RowDataSerializer.RowDataSerializerSnapshot |
|
RowDataSerializer.RowDataSerializerSnapshot |
|
RowDataToAvroConverters |
Tool class used to convert from RowData to Avro GenericRecord .
|
RowDataToAvroConverters.RowDataToAvroConverter |
Runtime converter that converts objects of Flink Table & SQL internal data structures to
corresponding Avro data structures.
|
RowDataToCsvConverters |
Tool class used to convert from RowData to CSV-format JsonNode .
|
RowDataToJsonConverters |
Tool class used to convert from RowData to JsonNode .
|
RowDataToJsonConverters.RowDataToJsonConverter |
Runtime converter that converts objects of Flink Table & SQL internal data structures to
corresponding JsonNode s.
|
RowDataToStringConverter |
Interface to convert RowData to String using the SQL casting rules.
|
RowDataToStringConverterImpl |
|
RowDataUtil |
|
RowDataVectorizer |
|
RowFormat |
|
RowIterator<T extends RowData> |
An internal iterator interface which presents a more restrictive API than Iterator .
|
RowKind |
Lists all kinds of changes that a row can describe in a changelog.
|
RowKindSetter |
An operator that sets the row kind of the incoming records to a specific row kind.
|
RowLevelDeleteSpec |
A sub-class of SinkAbilitySpec that can not only serialize/deserialize the row-level
delete mode & required physical column indices to/from JSON, but also can delete existing data
for SupportsRowLevelDelete .
|
RowLevelModificationContextUtils |
|
RowLevelModificationScanContext |
The context is intended to provide the relevant table scan information needed by the sink to
perform row-level update/delete.
|
RowLevelUpdateSpec |
A sub-class of SinkAbilitySpec that can not only serialize/deserialize the row-level
update mode, columns & required physical column indices to/from JSON, but also can update
existing data for SupportsRowLevelUpdate .
|
RowNumberAggFunction |
built-in row_number aggregate function.
|
RowPartitionComputer |
|
RowPosition |
To represent struct's position in repeated type.
|
RowRowConverter |
|
RowSerializer |
|
RowSerializer.RowSerializerSnapshot |
|
RowSlidingOverFrame |
The row sliding window frame calculates frames with the following SQL form: ...
|
Rowtime |
Deprecated.
|
RowtimeAttribute |
Deprecated.
|
RowtimeAttributeDescriptor |
Deprecated.
|
RowTimeDeduplicateFunction |
This function is used to deduplicate on keys and keeps only first or last row on row time.
|
RowTimeDeduplicateRecordsCombiner |
An implementation of RecordsCombiner that stores the first/last records of incremental
input records into the window state.
|
RowTimeDeduplicateRecordsCombiner.Factory |
|
RowTimeIntervalJoin |
The function to execute row(event) time interval stream inner-join.
|
RowTimeMiniBatchAssginerOperator |
A stream operator that emits watermark in a given event-time interval.
|
RowTimeMiniBatchDeduplicateFunction |
This function is used to get the first or last row for every key partition in miniBatch mode.
|
RowTimeMiniBatchLatestChangeDeduplicateFunction |
This function is used to get the first or last row for every key partition in miniBatch mode.
|
RowTimeRangeBoundedPrecedingFunction<K> |
Process Function for RANGE clause event-time bounded OVER window.
|
RowTimeRangeUnboundedPrecedingFunction<K> |
A ProcessFunction to support unbounded RANGE window.
|
RowTimeRowsBoundedPrecedingFunction<K> |
Process Function for ROWS clause event-time bounded OVER window.
|
RowTimeRowsUnboundedPrecedingFunction<K> |
A ProcessFunction to support unbounded ROWS window.
|
RowTimeSortOperator |
Sort based on event-time and possibly additional secondary sort attributes.
|
RowtimeTypeStrategy |
|
RowtimeValidator |
Deprecated.
|
RowTimeWindowDeduplicateOperatorBuilder |
|
RowTimeWindowDeduplicateProcessor |
A rowtime window deduplicate processor.
|
RowToProtoConverter |
RowToProtoConverter can convert flink row data to binary protobuf message data by codegen
process.
|
RowType |
Logical type of a sequence of fields.
|
RowType.RowField |
|
RowTypeInfo |
|
RowTypeUtils |
Utils for deriving row types of RelNode s.
|
RowUnboundedFollowingOverFrame |
The row unboundedFollowing window frame calculates frames with the following SQL form: ...
|
RowUnboundedPrecedingOverFrame |
The row UnboundPreceding window frame calculates frames with the following SQL form: ...
|
RowUtils |
Utilities to deal with Row instances.
|
RowWiseBucketWriter<IN,BucketID> |
|
RowWisePartWriter<IN,BucketID> |
|
RowWriter<T> |
|
RowWriter.RowWriterForArray |
|
RowWriter.RowWriterForRow |
|
RpcCheckpointResponder |
|
RpcConnectionException |
Exception class which is thrown if a rpc connection failed.
|
RpcEndpoint |
Base class for RPC endpoints.
|
RpcEndpoint.MainThreadExecutor |
Executor which executes runnables in the main thread context.
|
RpcException |
Base class for RPC related exceptions.
|
RpcGateway |
Rpc gateway interface which has to be implemented by Rpc gateways.
|
RpcGatewayRetriever<F extends Serializable,T extends FencedRpcGateway<F>> |
|
RpcGatewayUtils |
|
RpcGlobalAggregateManager |
|
RpcInputSplitProvider |
|
RpcInvalidStateException |
Exception which indicates an invalid state.
|
RpcInvocation |
Interface for rpc invocation messages.
|
RpcKvStateRegistryListener |
|
RpcLoaderException |
Base class for RPC loader exceptions.
|
RpcMetricQueryServiceRetriever |
|
RpcOptions |
RPC configuration options.
|
RpcPartitionStateChecker |
|
RpcRuntimeException |
Base class for RPC related runtime exceptions.
|
RpcServer |
Interface for self gateways.
|
RpcService |
Interface for rpc services.
|
RpcServiceSharing |
Enum which defines whether the mini cluster components use a shared RpcService or whether every
component gets its own dedicated RpcService started.
|
RpcServiceUtils |
These RPC utilities contain helper methods around RPC use.
|
RpcSystem |
This interface serves as a factory interface for RPC services, with some additional utilities
that are reliant on implementation details of the RPC service.
|
RpcSystem.FixedThreadPoolExecutorConfiguration |
Descriptor for creating a thread-pool with a fixed number of threads.
|
RpcSystem.ForkJoinExecutorConfiguration |
Descriptor for creating a fork-join thread-pool.
|
RpcSystem.RpcServiceBuilder |
|
RpcSystemLoader |
|
RpcSystemUtils |
Utils that are dependent on the underlying RPC implementation.
|
RpcTaskManagerGateway |
|
RpcTaskOperatorEventGateway |
|
RpcTimeout |
Annotation for RpcGateway methods to specify an additional timeout parameter for the
returned future to be completed.
|
RpcUtils |
Utility functions for Flink's RPC implementation.
|
RunAsync |
Message for asynchronous runnable invocations.
|
Runnables |
|
RunnableWithException |
Similar to a Runnable , this interface is used to capture a block of code to be executed.
|
RunnerOutputCollector<OUT> |
Output collector for Python UDF runner.
|
RuntimeAggregatorRegistry |
|
RuntimeComparatorFactory<T> |
|
RuntimeContext |
A RuntimeContext contains information about the context in which functions are executed.
|
RuntimeContext |
A RuntimeContext contains information about the context in which process functions are executed.
|
RuntimeContextInitializationContextAdapters |
|
RuntimeConverter |
Base interface for converting data during runtime.
|
RuntimeConverter.Context |
Context for conversions during runtime.
|
RuntimeEnvironment |
|
RuntimeEvent |
Subclasses of this event are recognized as events exchanged by the core runtime.
|
RuntimeExecutionMode |
Runtime execution mode of DataStream programs.
|
RuntimeFilterUtils |
Utilities for runtime filter.
|
RuntimeMessageHeaders<R extends RequestBody,P extends ResponseBody,M extends MessageParameters> |
This class links RequestBody s to ResponseBody s types and contains meta-data
required for their http headers in runtime module.
|
RuntimeOpenApiSpecGenerator |
OpenAPI spec generator for the Runtime Rest API.
|
RuntimePairComparatorFactory<T1,T2> |
|
RuntimeRestAPIDocGenerator |
Generator for the Runtime Rest API documentation.
|
RuntimeRestAPIVersion |
An enum for all versions of the REST API.
|
RuntimeSerializerFactory<T> |
|
RuntimeUDFContext |
A standalone implementation of the RuntimeContext , created by runtime UDF operators.
|
RuntimeUntypedResponseMessageHeaders<R extends RequestBody,M extends MessageParameters> |
Message headers for a web handler request that belongs to runtime module.
|
S3AccessHelper |
An interface that abstracts away the Multi-Part Upload (MPU) functionality offered by S3, from
the specific implementation of the file system.
|
S3AFileSystemFactory |
Simple factory for the S3 file system, registered for the s3a:// scheme.
|
S3Committer |
Data object to commit an S3 MultiPartUpload.
|
S3FileSystemFactory |
Simple factory for the S3 file system.
|
S3FileSystemFactory |
Simple factory for the S3 file system.
|
S3HadoopDelegationTokenProvider |
Delegation token provider for S3 Hadoop filesystems.
|
S3HadoopDelegationTokenReceiver |
Delegation token receiver for S3 Hadoop filesystems.
|
S3PFileSystemFactory |
Simple factory for the S3 file system, registered for the s3p:// scheme.
|
S3PrestoDelegationTokenProvider |
Delegation token provider for S3 Presto filesystems.
|
S3PrestoDelegationTokenReceiver |
Delegation token receiver for S3 Presto filesystems.
|
S3Recoverable |
Data object to recover an S3 MultiPartUpload for a recoverable output stream.
|
S3RecoverableFsDataOutputStream |
A RecoverableFsDataOutputStream to S3 that is based on a recoverable multipart upload.
|
S3RecoverableWriter |
|
S3TestCredentials |
Access to credentials to access S3 buckets during integration tests.
|
SafetyNetCloseableRegistry |
|
SafetyNetWrapperFileSystem |
|
SameTypePairComparator<T> |
|
SavepointDisposalHandlers |
Handlers to trigger the disposal of a savepoint.
|
SavepointDisposalRequest |
Request body for a savepoint disposal call.
|
SavepointDisposalStatusHeaders |
|
SavepointDisposalStatusMessageParameters |
|
SavepointDisposalTriggerHeaders |
|
SavepointEnvironment |
A minimally implemented Environment that provides the functionality required to run the
state-processor-api .
|
SavepointEnvironment.Builder |
|
SavepointFormatType |
Describes the binary format in which a savepoint should be taken.
|
SavepointHandlers |
HTTP handlers for asynchronous triggering of savepoints.
|
SavepointHandlers.SavepointStatusHandler |
HTTP handler to query for the status of the savepoint.
|
SavepointInfo |
Represents information about a finished savepoint.
|
SavepointKeyedStateHandle |
|
SavepointLoader |
|
SavepointMetadataV2 |
Savepoint metadata that can be modified.
|
SavepointOptions |
Command line options for the SAVEPOINT command.
|
SavepointOutputFormat |
|
SavepointPathQueryParameter |
Query parameter that specifies the savepoint to restore from.
|
SavepointReader |
The entry point for reading state from a Flink savepoint.
|
SavepointResources<K> |
|
SavepointRestoreResult |
|
SavepointRestoreSettings |
Savepoint restore settings.
|
SavepointRuntimeContext |
|
SavepointSnapshotStrategy<K> |
|
SavepointStatusHeaders |
These headers define the protocol for triggering a savepoint.
|
SavepointStatusMessageParameters |
The parameters for triggering a savepoint.
|
SavepointTriggerHeaders |
These headers define the protocol for triggering a savepoint.
|
SavepointTriggerMessageParameters |
The parameters for triggering a savepoint.
|
SavepointTriggerRequestBody |
|
SavepointType |
The type of checkpoint to perform.
|
SavepointType.PostCheckpointAction |
What's the intended action after the checkpoint (relevant for stopping with savepoint).
|
SavepointWriter |
A SavepointWriter can create new savepoints from bounded data streams.
|
SavepointWriterOperatorFactory |
Creates a savepoint writing operator from a savepoint path.
|
ScalaCaseClassSerializerSnapshot<T extends scala.Product> |
|
ScalaEitherSerializerSnapshot<L,R> |
Configuration snapshot for serializers of Scala's Either type, containing configuration
snapshots of the Left and Right serializers.
|
ScalaFutureUtils |
Utilities to convert Scala types into Java types.
|
ScalaOptionSerializerSnapshot<E> |
|
ScalaProductFieldAccessorFactory |
Interface to interact with optional Scala field accessors.
|
ScalarFunction |
Base class for a user-defined scalar function.
|
ScalarFunctionDefinition |
Deprecated.
|
ScalaSuffixChecker |
Utility for checking the presence/absence of scala-suffixes.
|
ScalaTrySerializerSnapshot<E> |
|
ScalingStrategy<T> |
ScalingStrategy provides an interface to control scale up / down behaviour.
|
ScanReuser |
Reuse sources.
|
ScanReuserUtils |
|
ScanRuntimeProviderContext |
|
ScanTableSource |
|
ScanTableSource.ScanContext |
|
ScanTableSource.ScanRuntimeProvider |
Provides actual runtime implementation for reading the data.
|
Scheduled |
Interface for reporters that actively send out data periodically.
|
ScheduledDropwizardReporter |
|
ScheduledExecutor |
Extension for the Executor interface which is enriched by method for scheduling tasks in
the future.
|
ScheduledExecutorServiceAdapter |
|
ScheduledFutureAdapter<V> |
|
ScheduledTask<T> |
ScheduledTask represents a task which is executed at a later point in time.
|
SchedulerBase |
|
SchedulerException |
General exception for workflow scheduler related errors.
|
SchedulerExecutionMode |
Enum for controlling whether REACTIVE mode is enabled or not.
|
SchedulerNG |
Interface for scheduling Flink jobs.
|
SchedulerNGFactory |
|
SchedulerOperations |
|
SchedulerUtils |
Utils class for Flink's scheduler implementations.
|
SchedulingExecutionVertex |
|
SchedulingPipelinedRegion |
|
SchedulingPipelinedRegionComputeUtil |
|
SchedulingResultPartition |
|
SchedulingStrategy |
Component which encapsulates the scheduling logic.
|
SchedulingStrategyFactory |
|
SchedulingTopology |
|
SchedulingTopologyListener |
This listener will be notified whenever the scheduling topology is updated.
|
Schema |
Schema of a table or view.
|
Schema |
Deprecated.
|
Schema.Builder |
A builder for constructing an immutable but still unresolved Schema .
|
Schema.UnresolvedColumn |
Super class for all kinds of columns in an unresolved schema.
|
Schema.UnresolvedComputedColumn |
Declaration of a computed column that will be resolved to Column.ComputedColumn during
schema resolution.
|
Schema.UnresolvedConstraint |
Super class for all kinds of constraints in an unresolved schema.
|
Schema.UnresolvedMetadataColumn |
Declaration of a metadata column that will be resolved to Column.MetadataColumn during
schema resolution.
|
Schema.UnresolvedPhysicalColumn |
Declaration of a physical column that will be resolved to Column.PhysicalColumn during
schema resolution.
|
Schema.UnresolvedPrimaryKey |
Declaration of a primary key that will be resolved to UniqueConstraint during schema
resolution.
|
Schema.UnresolvedWatermarkSpec |
Declaration of a watermark strategy that will be resolved to WatermarkSpec during
schema resolution.
|
SchemaBuilderUtil |
|
SchemaCoder |
Schema coder that allows reading schema that is somehow embedded into serialized record.
|
SchemaCoder.SchemaCoderProvider |
|
SchemaResolver |
|
SchemaTestUtils |
Test utilities for schemas.
|
SchemaTranslator |
Utility to derive a physical DataType , Schema , and projections for sinks and
sources.
|
SchemaTranslator.ConsumingResult |
|
SchemaTranslator.ProducingResult |
|
SchemaValidator |
Deprecated.
|
ScopeFormat |
This class represents the format after which the "scope" (or namespace) of the various component
metric groups is built.
|
ScopeFormats |
A container for component scope formats.
|
ScriptTransformIOInfo |
The wrapper class of the input/out schema for script transform.
|
SecondInputOfTwoInput |
|
SecondInputOfTwoInputStreamOperatorOutput |
|
SecureAzureBlobStorageFSFactory |
A factory for the Azure file system over HTTPs.
|
SecureAzureDataLakeStoreGen2FSFactory |
Secure ABFS AzureFS implementation.
|
SecureTestEnvironment |
|
SecurityConfiguration |
The global security configuration.
|
SecurityContext |
A security context with may be required to run a Callable.
|
SecurityContextFactory |
|
SecurityContextInitializeException |
Indicates a problem with installing or uninstalling a security module or context.
|
SecurityFactoryServiceLoader |
The Service provider discovery for searching suitable security factory.
|
SecurityModule |
An installable security module.
|
SecurityModule.SecurityInstallException |
Indicates a problem with installing or uninstalling a security module.
|
SecurityModuleFactory |
|
SecurityOptions |
The set of configuration options relating to security.
|
SecurityUtils |
Security Environment that holds the security context and modules installed.
|
SeekableDataInputView |
|
SeekableDataOutputView |
|
SeekableFileChannelInputView |
|
SegmentFileStateHandle |
|
SegmentPartitionFile |
The partition file with segment file mode.
|
SegmentPartitionFileReader |
|
SegmentPartitionFileWriter |
|
SegmentsUtil |
Util for data format segments calc.
|
SemanticProperties |
Container for the semantic properties associated to an operator.
|
SemanticProperties.EmptySemanticProperties |
|
SemanticProperties.InvalidSemanticAnnotationException |
|
SemanticsCheckMapper |
|
SeparateThreadExecutor |
An Executor that runs every runnable in a separate thread.
|
SequenceFileWriter<K extends org.apache.hadoop.io.Writable,V extends org.apache.hadoop.io.Writable> |
A BulkWriter implementation that wraps a SequenceFile.Writer .
|
SequenceFileWriterFactory<K extends org.apache.hadoop.io.Writable,V extends org.apache.hadoop.io.Writable> |
|
SequenceGenerator<T> |
A stateful, re-scalable DataGenerator that emits each number from a given interval
exactly once, possibly in parallel.
|
SequenceGeneratorSource |
Deprecated.
|
SequenceGeneratorVisitor |
|
SequenceInputTypeStrategy |
Strategy for inferring and validating a function signature like f(STRING, NUMERIC) or
f(s STRING, n NUMERIC) using a sequence of ArgumentTypeStrategy s.
|
SequenceNumber |
A logical timestamp to draw a boundary between the materialized and non-materialized changes.
|
SequenceNumber.GenericSequenceNumber |
|
SequenceNumberRange |
|
SequenceNumberRange.GenericSequenceNumberRange |
|
SequentialChannelStateReader |
Reads channel state saved during checkpoint/savepoint.
|
SequentialChannelStateReaderImpl |
|
SerdeContext |
A context to allow the store user-defined data within ExecNode serialization and deserialization.
|
SerdeUtils |
A util class with some helper method for serde in the sources.
|
SerializableConfiguration |
Wrap Configuration to a serializable class.
|
SerializableConfiguration |
Wrapper of hadoop Configuration to make it serializable.
|
SerializableFunction<T,R> |
|
SerializableHadoopConfigWrapper |
Utility class to make a Hadoop Configuration serializable.
|
SerializableObject |
A simple object that only implements Serializable , so it can be used in
serializable classes.
|
SerializableOptional<T extends Serializable> |
|
SerializableSerializer<T extends com.esotericsoftware.kryo.Serializer<?> & Serializable> |
The wrapper to make serializer serializable.
|
SerializableSupplier<T> |
|
SerializableSupplierWithException<T,E extends Throwable> |
|
SerializableTimestampAssigner<T> |
|
SerializationDelegate<T> |
The serialization delegate exposes an arbitrary element as a IOReadableWritable for
serialization, with the help of a type serializer.
|
SerializationFormatFactory |
|
SerializationSchema<T> |
The serialization schema describes how to turn a data object into a different serialized
representation.
|
SerializationSchema.InitializationContext |
|
SerializationSchemaAdapter |
|
SerializedCheckpointException |
Serialized checkpoint exception which wraps the checkpoint failure reason and its serialized
throwable.
|
SerializedCompositeKeyBuilder<K> |
Responsible for serialization of currentKey, currentGroup and namespace.
|
SerializedInputFormat<T extends IOReadableWritable> |
Reads elements by deserializing them with their regular serialization/deserialization
functionality.
|
SerializedInputSplit |
|
SerializedJobExecutionResult |
|
SerializedListAccumulator<T> |
This accumulator stores a collection of objects in serialized form, so that the stored objects
are not affected by modifications to the original objects.
|
SerializedOutputFormat<T extends IOReadableWritable> |
Stores elements by serializing them with their regular serialization/deserialization
functionality.
|
SerializedThrowable |
Utility class for dealing with user-defined Throwable types that are serialized (for example
during RPC/Actor communication), but cannot be resolved with the default class loader.
|
SerializedThrowableDeserializer |
|
SerializedThrowableSerializer |
|
SerializedUpdateBuffer |
|
SerializedValue<T> |
This class is used to transfer (via serialization) objects whose classes are not available in the
system class loader.
|
SerializedValueDeserializer |
|
SerializedValueSerializer |
|
SerializerConfig |
A config to define the behavior for serializers in Flink job, it manages the registered types and
serializers.
|
SerializerConfigImpl |
|
SerializerFactory |
|
Serializers |
Class containing utilities for the serializers of the Flink Runtime.
|
Serializers.DummyAvroKryoSerializerClass<T> |
This is used in case we don't have Avro on the classpath.
|
Serializers.DummyAvroRegisteredClass |
This is used in case we don't have Avro on the classpath.
|
Serializers.SpecificInstanceCollectionSerializer<T extends Collection> |
Special serializer for Java collections enforcing certain instance types.
|
Serializers.SpecificInstanceCollectionSerializerForArrayList |
Special serializer for Java's ArrayList used for Avro's GenericData.Array.
|
ServerFactory |
A gRPC server factory.
|
ServerFactory.InetSocketAddressServerFactory |
Creates a gRPC Server using the default server factory.
|
ServerFactory.UrlFactory |
Factory that constructs client-accessible URLs from a local server address and port.
|
ServiceConnectionManager<S> |
Base interface for managers of services that are explicitly connected to / disconnected from.
|
ServiceType |
An abstract class represents the service type that flink supported.
|
Session |
Helper class for creating a session window.
|
Session |
Similar to HTTP Session, which could maintain user identity and store user-specific data during
multiple request/response interactions between a client and the gateway server.
|
SessionClusterEntrypoint |
Base class for session cluster entry points.
|
SessionContext |
Context describing a session, it's mainly used for user to open a new session in the backend.
|
SessionContext.SessionState |
session state.
|
SessionDispatcherFactory |
|
SessionDispatcherLeaderProcess |
Process which encapsulates the job recovery logic and life cycle management of a Dispatcher .
|
SessionDispatcherLeaderProcessFactory |
|
SessionDispatcherLeaderProcessFactoryFactory |
|
SessionEnvironment |
Environment to initialize the Session .
|
SessionEnvironment.Builder |
|
SessionEnvironment.CatalogCreator |
An interface used to create Catalog .
|
SessionEnvironment.ModuleCreator |
An interface used to create Module .
|
SessionHandle |
Session Handle that used to identify the Session.
|
SessionHandleIdPathParameter |
|
SessionManager |
Mange the lifecycle of the Session .
|
SessionManagerImpl |
The implementation of the SessionManager that manage the lifecycle of the
Session .
|
SessionMessageParameters |
|
SessionRestEndpointFactory |
|
SessionWindowAssigner |
|
SessionWindowing |
An example of session windowing that keys events by ID and groups and counts them in session with
gaps of 3 milliseconds.
|
SessionWindowingData |
Data for SessionWindowingITCase.
|
SessionWindowSpec |
Logical representation of a session window specification.
|
SessionWindowTimeGapExtractor<T> |
A SessionWindowTimeGapExtractor extracts session time gaps for Dynamic Session Window
Assigners.
|
SessionWithGap |
Session window.
|
SessionWithGapOnTime |
Session window on time.
|
SessionWithGapOnTimeWithAlias |
Session window on time with alias.
|
SetOperation |
Operation to represent SET command.
|
SetOperationParseStrategy |
|
SetOpRewriteUtil |
Util class that rewrite SetOp .
|
SetQueryOperation |
A set operation on two relations.
|
SetQueryOperation.SetQueryOperationType |
Represent kind of this set operation.
|
ShadeOptionalChecker |
Verifies that all dependencies bundled with the shade-plugin are marked as optional in the pom.
|
ShadeParser |
Utils for parsing the shade-plugin output.
|
SharedBuffer<V> |
A shared buffer implementation which stores values under according state.
|
SharedBufferAccessor<V> |
Accessor to SharedBuffer that allows operations on the underlying structures in batches.
|
SharedBufferCacheConfig |
Configuration immutable class.
|
SharedBufferEdge |
Versioned edge in SharedBuffer that allows retrieving predecessors.
|
SharedBufferEdge.SharedBufferEdgeSerializer |
|
SharedBufferEdge.SharedBufferEdgeSerializer.SharedBufferEdgeSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
SharedBufferNode |
An entry in SharedBuffer that allows to store relations between different entries.
|
SharedBufferNodeSerializer |
|
SharedBufferNodeSerializerSnapshotV2 |
Serializer configuration snapshot for compatibility and format evolution.
|
SharedObjects |
This rule allows objects to be used both in the main test case as well as in UDFs by using
serializable SharedReference s.
|
SharedObjectsExtension |
This rule allows objects to be used both in the main test case as well as in UDFs by using
serializable SharedReference s.
|
SharedReference<T> |
|
SharedResourceHolder |
A holder for shared resource singletons.
|
SharedResourceHolder.Resource<T> |
Defines a resource, and the way to create and destroy instances of it.
|
SharedResources |
A map that keeps track of acquired shared resources and handles their allocation disposal.
|
SharedResources.ResourceAndSize<T extends AutoCloseable> |
A resource handle with size.
|
SharedStateRegistry |
This registry manages state that is shared across (incremental) checkpoints, and is responsible
for deleting shared state that is no longer used in any valid checkpoint.
|
SharedStateRegistryFactory |
|
SharedStateRegistryImpl |
|
SharedStateRegistryImpl.EmptyDiscardStateObjectForRegister |
An object with empty discardState for registering.
|
SharedStateRegistryKey |
This class represents a key that uniquely identifies (on a logical level) state handles for
registration in the SharedStateRegistry .
|
SharingPhysicalSlotRequestBulk |
|
ShellScript |
ShellScript for creating shell script on linux and windows.
|
ShellScript.ShellScriptBuilder |
Builder to create shell script.
|
ShipStrategyType |
Enumeration defining the different shipping types of the output, such as local forward,
re-partitioning by hash, or re-partitioning by range.
|
ShortColumnReader |
|
ShortColumnVector |
Short column vector.
|
ShortComparator |
|
ShortcutUtils |
Utilities for quick access of commonly used instances (like FlinkTypeFactory ) without
long chains of getters or casting like (FlinkTypeFactory)
agg.getCluster.getTypeFactory() .
|
ShortHashSet |
Short hash set.
|
ShortParser |
Parses a decimal text field into a Short .
|
ShortPrimitiveArrayComparator |
|
ShortPrimitiveArraySerializer |
A serializer for short arrays.
|
ShortPrimitiveArraySerializer.ShortPrimitiveArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
ShortSerializer |
Type serializer for Byte .
|
ShortSerializer.ShortSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
ShortValue |
Boxed serializable and comparable short integer type, representing the primitive type
short .
|
ShortValueComparator |
Specialized comparator for ShortValue based on CopyableValueComparator.
|
ShortValueParser |
|
ShortValueSerializer |
|
ShortValueSerializer.ShortValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
ShowCatalogsOperation |
Operation to describe a SHOW CATALOGS statement.
|
ShowColumnsOperation |
Operation to describe a SHOW COLUMNS statement.
|
ShowCreateCatalogOperation |
Operation to describe a SHOW CREATE CATALOG statement.
|
ShowCreateTableOperation |
Operation to describe a SHOW CREATE TABLE statement.
|
ShowCreateUtil |
SHOW CREATE statement Util.
|
ShowCreateViewOperation |
Operation to describe a SHOW CREATE VIEW statement.
|
ShowCurrentCatalogOperation |
Operation to describe a SHOW CURRENT CATALOG statement.
|
ShowCurrentDatabaseOperation |
Operation to describe SHOW CURRENT DATABASE operation.
|
ShowDatabasesOperation |
Operation to describe a SHOW DATABASES statement.
|
ShowFunctionsOperation |
Operation to describe a SHOW FUNCTIONS statement.
|
ShowFunctionsOperation.FunctionScope |
Represent scope of function.
|
ShowJarsOperation |
Operation to describe a SHOW JARS statement.
|
ShowJobsOperation |
Operation to describe a SHOW JOBS statement.
|
ShowLikeOperator |
Like operator for SHOW operations.
|
ShowModulesOperation |
Operation to describe a SHOW [FULL] MODULES statement.
|
ShowOperation |
An Operation that show one kind of objects, e.g.
|
ShowPartitionsOperation |
Operation to describe a SHOW PARTITIONS statement.
|
ShowProceduresOperation |
Operation to describe a SHOW PROCEDURES statement.
|
ShowTablesOperation |
Operation to describe a SHOW TABLES statement.
|
ShowViewsOperation |
Operation to describe a SHOW VIEWS statement.
|
ShuffleDescriptor |
Interface for shuffle deployment descriptor of result partition resource.
|
ShuffleEnvironment<P extends ResultPartitionWriter,G extends IndexedInputGate> |
Interface for the implementation of shuffle service local environment.
|
ShuffleEnvironmentContext |
|
ShuffleIOOwnerContext |
Context of shuffle input/output owner used to create partitions or gates belonging to the owner.
|
ShuffleMaster<T extends ShuffleDescriptor> |
Intermediate result partition registry to use in JobMaster .
|
ShuffleMasterContext |
|
ShuffleMasterContextImpl |
|
ShuffleMasterSnapshot |
This class represents a snapshot of shuffle master, which can be used to restore the internal
state of the shuffle master.
|
ShuffleMasterSnapshotContext |
|
ShuffleMetrics |
Interface provides access to the shuffle metrics which includes the meta information of
partition(partition bytes, etc).
|
ShufflePartitioner<T> |
Partitioner that distributes the data equally by selecting one output channel randomly.
|
ShuffleServiceFactory<SD extends ShuffleDescriptor,P extends ResultPartitionWriter,G extends IndexedInputGate> |
Interface for shuffle service factory implementations.
|
ShuffleServiceLoader |
|
ShuffleServiceOptions |
Options to configure shuffle service.
|
ShuffleUtils |
Common utility methods for shuffle service.
|
ShutdownHandler |
REST handler which allows to shut down the cluster.
|
ShutdownHeaders |
|
ShutdownHookUtil |
Utils class for dealing with JVM shutdown hooks.
|
SideOutputDataStream<T> |
|
SideOutputExample |
An example that illustrates the use of side output.
|
SideOutputExample.Tokenizer |
Implements the string tokenizer that splits sentences into words as a user-defined
FlatMapFunction.
|
SideOutputTransformation<T> |
This transformation represents a selection of a side output of an upstream operation with a given
OutputTag .
|
SideOutputTransformationTranslator<OUT> |
|
SignalHandler |
This signal handler / signal logger is based on Apache Hadoop's
org.apache.hadoop.util.SignalLogger.
|
Signature |
Describes the signature of a function.
|
Signature.Argument |
Representation of a single argument in a signature.
|
SimpleAccumulator<T extends Serializable> |
Similar to Accumulator, but the type of items to add and the result value must be the same.
|
SimpleCharStream |
An implementation of interface CharStream, where the stream is assumed to
contain only ASCII characters (without unicode processing).
|
SimpleCloseableInputProvider<E> |
A simple iterator provider that returns a supplied iterator and does nothing when closed.
|
SimpleCollectingOutputView |
The list with the full segments contains at any point all completely full segments, plus the
segment that is currently filled.
|
SimpleCondition<T> |
A user-defined condition that decides if an element should be accepted in the pattern or not.
|
SimpleCounter |
A simple low-overhead Counter that is not thread-safe.
|
SimpleExecutionSlotAllocator |
|
SimpleExecutionSlotAllocator.Factory |
|
SimpleGauge<T> |
A Simple gauge providing method for value updating.
|
SimpleInitializeOnMasterContext |
|
SimpleInputFormatOperatorFactory<OUT> |
Input format source operator factory which just wrap existed StreamSource .
|
SimpleOperatorFactory<OUT> |
|
SimpleOutputFormatOperatorFactory<IN,OUT> |
A simple operator factory which create an operator containing an OutputFormat .
|
SimpleRequestSlotMatchingStrategy |
Simple implementation of the RequestSlotMatchingStrategy that matches the pending
requests in order as long as the resource profile can be fulfilled.
|
SimpleSpan |
Basic implementation of Span .
|
SimpleSplitAssigner |
The SimpleSplitAssigner hands out splits in a random order, without any consideration for
order or locality.
|
SimpleStreamFormat<T> |
A simple version of the StreamFormat , for formats that are not splittable.
|
SimpleStringDecoder |
|
SimpleStringEncoder<IN> |
A simple Encoder that uses toString() on the input elements and writes them to
the output bucket file separated by newline.
|
SimpleStringSchema |
Very simple serialization schema for strings.
|
SimpleTimerService |
|
SimpleTransformationTranslator<OUT,T extends Transformation<OUT>> |
|
SimpleTypeSerializerSnapshot<T> |
A simple base class for TypeSerializerSnapshots, for serializers that have no parameters.
|
SimpleUdfStreamOperatorFactory<OUT> |
|
SimpleUserCodeClassLoader |
Simple UserCodeClassLoader implementation which assumes that the provided class loader
will never be released and, hence, will never execute the release hooks.
|
SimpleVersionedListState<T> |
|
SimpleVersionedSerialization |
|
SimpleVersionedSerializer<E> |
A simple serializer interface for versioned serialization.
|
SimpleVersionedSerializerAdapter<T> |
|
SimpleVersionedSerializerTypeSerializerProxy<T> |
|
SimpleVersionedStringSerializer |
|
SimplifyJoinConditionRule |
Planner rule that apply various simplifying transformations on join condition. e.g. reduce same
expressions: a=b AND b=a -> a=b, simplify boolean expressions: x = 1 AND FALSE -> FALSE, simplify
cast expressions: CAST('123' as integer) -> 123
|
SimplifyJoinConditionRule.SimplifyJoinConditionRuleConfig |
Rule configuration.
|
SingleCheckpointBarrierHandler |
SingleCheckpointBarrierHandler is used for triggering checkpoint while reading the first
barrier and keeping track of the number of received barriers and consumed barriers.
|
SingleDirectoryWriter<T> |
|
SingleElementIterator<E> |
An Iterator that contains only a single element.
|
SingleElementIterator<E> |
|
SingleInputGate |
An input gate consumes one or more partitions of a single produced intermediate result.
|
SingleInputGateFactory |
|
SingleInputGateFactory.ChannelStatistics |
Statistics of input channels.
|
SingleInputOperator<IN,OUT,FT extends Function> |
Abstract superclass for all operators that have one input like "map" or "reduce".
|
SingleInputSemanticProperties |
Container for the semantic properties associated to a single input operator.
|
SingleInputSemanticProperties.AllFieldsForwardedProperties |
|
SingleLogicalSlot |
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator represents a user defined transformation applied on a DataStream with one predefined output type.
|
SingleRecordWriter<T extends IOReadableWritable> |
The specific delegate implementation for the single output case.
|
SingleSessionManager |
|
SingleStateIterator |
An interface for iterating over a single state in a RocksDB state backend.
|
SingleThreadAccessCheckingTypeInfo<T> |
|
SingleThreadAccessCheckingTypeSerializer<T> |
|
SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot<T> |
|
SingleThreadFetcherManager<E,SplitT extends SourceSplit> |
A Fetcher Manager with a single fetching thread (I/O thread) that handles all splits
concurrently.
|
SingleThreadMultiplexSourceReaderBase<E,T,SplitT extends SourceSplit,SplitStateT> |
|
SingletonResultIterator<E> |
|
SingleTransformationTranslator<T> |
|
SingleValueAggFunction |
Base class for built-in single value aggregate function.
|
SingleValueAggFunction.BooleanSingleValueAggFunction |
Built-in boolean single value aggregate function.
|
SingleValueAggFunction.ByteSingleValueAggFunction |
Built-in byte single value aggregate function.
|
SingleValueAggFunction.CharSingleValueAggFunction |
Built-in char single value aggregate function.
|
SingleValueAggFunction.DateSingleValueAggFunction |
Built-in date single value aggregate function.
|
SingleValueAggFunction.DecimalSingleValueAggFunction |
Built-in decimal single value aggregate function.
|
SingleValueAggFunction.DoubleSingleValueAggFunction |
Built-in double single value aggregate function.
|
SingleValueAggFunction.FloatSingleValueAggFunction |
Built-in float single value aggregate function.
|
SingleValueAggFunction.IntSingleValueAggFunction |
Built-in int single value aggregate function.
|
SingleValueAggFunction.LongSingleValueAggFunction |
Built-in long single value aggregate function.
|
SingleValueAggFunction.ShortSingleValueAggFunction |
Built-in short single value aggregate function.
|
SingleValueAggFunction.StringSingleValueAggFunction |
Built-in string single value aggregate function.
|
SingleValueAggFunction.TimeSingleValueAggFunction |
Built-in time single value aggregate function.
|
SingleValueAggFunction.TimestampLtzSingleValueAggFunction |
Built-in timestampLtz single value aggregate function.
|
SingleValueAggFunction.TimestampSingleValueAggFunction |
Built-in timestamp single value aggregate function.
|
Sink<T> |
Sink interface for DataStream api v2.
|
Sink<InputT> |
Base interface for developing a sink.
|
SinkAbilitySpec |
An interface that can not only serialize/deserialize the sink abilities to/from JSON, but also
can apply the abilities to a DynamicTableSink .
|
SinkCommitterMetricGroup |
Pre-defined metrics for sinks.
|
SinkContextUtil |
|
SinkFunction<IN> |
Deprecated.
|
SinkFunction.Context |
Context that SinkFunctions can use for getting additional data about an
input record.
|
SinkFunctionProvider |
Deprecated.
|
SinkModifyOperation |
DML operation that tells to write to a sink.
|
SinkOperator |
|
SinkOptions |
Configuration options for sinks.
|
SinkRuntimeProviderContext |
|
SinkStagingContext |
|
SinkTestSuiteBase<T extends Comparable<T>> |
Base class for sink test suite.
|
SinkTransformation<InputT,OutputT> |
|
SinkTransformationTranslator<Input,Output> |
|
SinkUpsertMaterializer |
An operator that maintains incoming records in state corresponding to the upsert keys and
generates an upsert view for the downstream operator.
|
SinkUtils |
Utility class for sinks.
|
SinkV1CommittableDeserializer |
This class offers the possibility to deserialize committables that have been written with older
Flink releases (i.e. 1.13, 1.14).
|
SinkV2Provider |
|
SinkWriter<InputT> |
The SinkWriter is responsible for writing data.
|
SinkWriter.Context |
|
SinkWriterMetricGroup |
Pre-defined metrics for sinks.
|
SinkWriterOperatorFactory<InputT,CommT> |
|
SizeBasedCacheLimitPolicy |
A fixed capacity cache limit policy, which is not thread-safe, and the thread safe should be
ensured by the invoker.
|
SizeBasedWindowFunction |
Some functions like CUME_DIST/PERCENT_RANK/NTILE need the size of current window for calculation.
|
SkipListUtils |
Utilities for skip list.
|
SkipPastLastStrategy |
Discards every partial match that started before emitted match ended.
|
SkipToFirstStrategy |
Discards every partial match that started before the first event of emitted match mapped to
*PatternName*.
|
SkipToLastStrategy |
Discards every partial match that started before the last event of emitted match mapped to
*PatternName*.
|
SkipToNextStrategy |
Discards every partial match that started with the same event, emitted match was started.
|
Slf4jReporter |
|
Slf4jReporterFactory |
|
Slf4jTraceReporter |
|
Slf4jTraceReporterFactory |
|
SliceAssigner |
|
SliceAssigners |
|
SliceAssigners.CumulativeSliceAssigner |
|
SliceAssigners.HoppingSliceAssigner |
|
SliceAssigners.SlicedSharedSliceAssigner |
The SliceAssigner for elements have been attached slice end timestamp, and the slices
are shared.
|
SliceAssigners.SlicedUnsharedSliceAssigner |
The SliceAssigner for elements have been attached slice end timestamp, but the slices
are not shared, i.e. the assigned slice is equal to the final window.
|
SliceAssigners.TumblingSliceAssigner |
|
SliceAssigners.WindowedSliceAssigner |
The SliceAssigner for elements have been attached window start and end timestamps.
|
SliceAttachedWindowingStrategy |
A windowing strategy that gets windows from input columns as window slice have been assigned and
attached to the physical columns.
|
SliceEnd |
Deprecated.
|
SliceSharedAssigner |
A SliceAssigner which shares slices for windows, which means a window is divided into
multiple slices and need to merge the slices into windows when emitting windows.
|
SliceSharedWindowAggProcessor |
|
SliceUnsharedAssigner |
A SliceAssigner which doesn't share slices for windows, which means a window is divided
into only one slice and doesn't need to merge the slices when emitting windows.
|
SliceUnsharedWindowAggProcessor |
|
SlicingWindowProcessor<W> |
The SlicingWindowProcessor is an optimized processing for aligned windows which can apply
the slicing optimization.
|
SlicingWindowTimerServiceImpl |
|
Slide |
Helper class for creating a sliding window.
|
SlideWithSize |
Partially specified sliding window.
|
SlideWithSizeAndSlide |
Sliding window.
|
SlideWithSizeAndSlideOnTime |
Sliding window on time.
|
SlideWithSizeAndSlideOnTimeWithAlias |
Sliding window on time with alias.
|
SlidingEventTimeWindows |
A WindowAssigner that windows elements into sliding windows based on the timestamp of the
elements.
|
SlidingOverFrame |
The sliding window frame.
|
SlidingProcessingTimeWindows |
A WindowAssigner that windows elements into sliding windows based on the current system
time of the machine the operation is running on.
|
SlidingWindowAssigner |
A GroupWindowAssigner that windows elements into sliding windows based on the timestamp
of the elements.
|
SlidingWindowCheckMapper |
This mapper validates sliding event time window.
|
SlotActions |
|
SlotAllocationException |
Exception indicating that the slot allocation on the task manager failed.
|
SlotAllocationSnapshot |
Model to save local slot allocation info.
|
SlotAllocationSnapshotPersistenceService |
|
SlotAllocator |
Component for calculating the slot requirements and mapping of vertices to slots.
|
SlotAssigner |
Interface for assigning slots to slot sharing groups.
|
SlotContext |
|
SlotID |
Unique identifier for a slot on a TaskManager.
|
SlotInfo |
Interface that provides basic information in the context of a slot.
|
SlotInfo |
|
SlotManager |
The slot manager is responsible for maintaining a view on all registered task manager slots,
their allocation and all pending slot requests.
|
SlotManager.RegistrationResult |
The result of task manager registration.
|
SlotManagerConfiguration |
|
SlotManagerException |
|
SlotManagerMetricGroup |
Metric group which is used by the SlotManager to register metrics.
|
SlotManagerUtils |
|
SlotNotActiveException |
Exception indicating that the given TaskSlot was not in state active.
|
SlotNotFoundException |
Exception indicating that a TaskSlot could not be found.
|
SlotOccupiedException |
Exception which signals that a slot is already occupied by the given AllocationID .
|
SlotOffer |
Describe the slot offering to job manager provided by task manager.
|
SlotOwner |
Interface for components that hold slots and to which slots get released / recycled.
|
SlotPool |
The Interface of a slot pool that manages slots.
|
SlotPoolService |
Service used by the JobMaster to manage a slot pool.
|
SlotPoolServiceFactory |
|
SlotPoolServiceSchedulerFactory |
|
SlotProfile |
A slot profile describes the profile of a slot into which a task wants to be scheduled.
|
SlotReport |
A report about the current status of all slots of the TaskExecutor, describing which slots are
available and allocated, and what jobs (JobManagers) the allocated slots have been allocated to.
|
SlotRequestId |
|
SlotSelectionStrategy |
Interface for slot selection strategies.
|
SlotSelectionStrategy.SlotInfoAndLocality |
|
SlotSelectionStrategyUtils |
|
SlotSharingExecutionSlotAllocatorFactory |
Factory for SlotSharingExecutionSlotAllocator .
|
SlotSharingGroup |
Describe the name and the different resource components of a slot sharing group.
|
SlotSharingGroup |
Describe the name and the different resource components of a slot sharing group.
|
SlotSharingGroup |
A slot sharing units defines which different task (from different job vertices) can be deployed
together within a slot.
|
SlotSharingGroup.Builder |
|
SlotSharingGroup.Builder |
|
SlotSharingGroupId |
|
SlotSharingGroupIDDeserializer |
|
SlotSharingGroupIDSerializer |
|
SlotSharingGroupUtils |
|
SlotSharingSlotAllocator |
|
SlotStatus |
This describes the slot current status which located in TaskManager.
|
SlotStatusSyncer |
Syncer for slot status.
|
SlowTaskDetector |
Component responsible for detecting slow tasks.
|
SlowTaskDetectorListener |
Component responsible for listening on slow tasks.
|
SlowTaskDetectorOptions |
Configuration options to detect slow tasks.
|
SmallIntType |
Logical type of a 2-byte signed integer with values from -32,768 to 32,767.
|
SmallIntWriter<T> |
|
SmallIntWriter.SmallIntWriterForArray |
|
SmallIntWriter.SmallIntWriterForRow |
|
SnappyStreamCompressionDecorator |
This implementation decorates the stream with snappy compression.
|
Snapshotable<S extends StateObject> |
Interface for objects that can snapshot its state (state backends currently).
|
SnapshotDirectory |
This class represents a directory that is the target for a state snapshot.
|
SnapshotExecutionType |
Determines how the write-part of a snapshot should be executed.
|
SnapshotResources |
A set of resources produced in the synchronous part of a snapshot required to finish the
snapshot.
|
SnapshotResult<T extends StateObject> |
This class contains the combined results from the snapshot of a state backend:
A state object representing the state that will be reported to the Job Manager to
acknowledge the checkpoint.
|
SnapshotScope |
Represents the name-resolution context for expressions in an FOR SYSTEM_TIME AS OF TIMESTAMP
clause.
|
SnapshotStrategy<S extends StateObject,SR extends SnapshotResources> |
Interface for different snapshot approaches in state backends.
|
SnapshotStrategy.SnapshotResultSupplier<S extends StateObject> |
A supplier for a SnapshotResult with an access to a CloseableRegistry for io
tasks that need to be closed when cancelling the async part of the checkpoint.
|
SnapshotStrategyRunner<T extends StateObject,SR extends SnapshotResources> |
|
SnapshotType |
The type of checkpoint to perform.
|
SnapshotType.SharingFilesStrategy |
Defines what files can be shared across snapshots.
|
SnapshotUtils |
Takes a final snapshot of the state of an operator subtask.
|
SocketClientSink<IN> |
Deprecated.
|
SocketDynamicTableFactory |
|
SocketDynamicTableSource |
|
SocketSource |
|
SocketSource.DummyCheckpoint |
Placeholder because the SocketSource does not support fault-tolerance and thus does not
require actual checkpointing.
|
SocketSource.DummySplit |
Placeholder because the socket itself implicitly represents the only split and does not
require an actual split object.
|
SocketStreamIterator<T> |
An iterator that returns the data from a socket stream.
|
SocketTextStreamFunction |
Deprecated.
|
SocketWindowWordCount |
Implements a streaming windowed version of the "WordCount" program.
|
SocketWindowWordCount.WordWithCount |
Data type for words with count.
|
SolutionSetBroker |
Used to hand over the hash-join from the iteration head to the solution-set match.
|
SolutionSetFastUpdateOutputCollector<T> |
A Collector to update the solution set of a workset iteration.
|
SolutionSetObjectsUpdateOutputCollector<T> |
A Collector to update the solution set of a workset iteration.
|
SolutionSetUpdateBarrier |
|
SolutionSetUpdateBarrierBroker |
|
SolutionSetUpdateOutputCollector<T> |
A Collector to update the solution set of a workset iteration.
|
SorMergeJoinOperatorUtil |
|
SortBasedDataBuffer |
|
SortBuffer |
A DataBuffer implementation which sorts all appended records only by subpartition index.
|
SortBufferAccumulator |
|
SortedMapSerializer<K,V> |
|
SortedMapSerializerSnapshot<K,V> |
|
SortedMapTypeInfo<K,V> |
The type information for sorted maps.
|
Sorter<E> |
The SortMerger interface representing the public interface to all specific Sort-Merge
implementations.
|
SortingDataInput<T,K> |
A StreamTaskInput which sorts in the incoming records from a chained input.
|
SortLimitOperator |
Operator for batch sort limit.
|
SortMergeFullOuterJoinIterator |
Gets two matched rows for full outer join.
|
SortMergeInnerJoinIterator |
Gets probeRow and match rows for inner join.
|
SortMergeJoinFunction |
This function is used to process the main logic of sort merge join.
|
SortMergeJoinIterator |
Gets probeRow and match rows for inner/left/right join.
|
SortMergeJoinOperator |
An implementation that realizes the joining through a sort-merge join strategy. 1.In most cases,
its performance is weaker than HashJoin. 2.It is more stable than HashJoin, and most of the data
can be sorted stably. 3.SortMergeJoin should be the best choice if sort can be omitted in the
case of multi-level join cascade with the same key.
|
SortMergeOneSideOuterJoinIterator |
Gets probeRow and match rows for left/right join.
|
SortMergeResultPartition |
|
SortOperator |
Operator for batch sort.
|
SortPartitionOperator<INPUT> |
|
SortPartitionOperatorBase<IN> |
|
SortQueryOperation |
Expresses sort operation of rows of the underlying relational operation with given order.
|
SortSpec |
SortSpec describes how the data will be sorted.
|
SortSpec.SortFieldSpec |
Sort info for a Field.
|
SortSpec.SortSpecBuilder |
SortSpec builder.
|
SortUtil |
Util for sort.
|
Source<T> |
Source interface for DataStream api v2.
|
Source<T,SplitT extends SourceSplit,EnumChkT> |
The interface for Source.
|
SourceAbilityContext |
|
SourceAbilitySpec |
An interface that can not only serialize/deserialize the source abilities to/from JSON, but also
can apply the abilities to a DynamicTableSource .
|
SourceAbilitySpecBase |
|
SourceBuilder |
A utility for constructing InputFormat based sources that are marked as BOUNDED.
|
SourceCoordinator<SplitT extends SourceSplit,EnumChkT> |
|
SourceCoordinator.WatermarkElement |
|
SourceCoordinatorContext<SplitT extends SourceSplit> |
|
SourceCoordinatorProvider<SplitT extends SourceSplit> |
|
SourceCoordinatorProvider.CoordinatorExecutorThreadFactory |
A thread factory class that provides some helper methods.
|
SourceCoordinatorSerdeUtils |
|
SourceEvent |
An base class for the events passed between the SourceReaders and Enumerators.
|
SourceEventWrapper |
A wrapper operator event that contains a custom defined operator event.
|
SourceFunction<T> |
Deprecated.
|
SourceFunction.SourceContext<T> |
Interface that source functions use to emit elements, and possibly watermarks.
|
SourceFunctionProvider |
Deprecated.
|
SourceLineageVertex |
Lineage vertex for source which has Boundedness to indicate whether the data for the
source is bounded.
|
SourceOperator<OUT,SplitT extends SourceSplit> |
Base source operator only used for integrating the source reader which is proposed by FLIP-27.
|
SourceOperatorFactory<OUT> |
|
SourceOperatorStreamTask<T> |
|
SourceOperatorStreamTask.AsyncDataOutputToOutput<T> |
|
SourceOutput<T> |
The SourceOutput is the gateway for a SourceReader ) to emit the produced records
and watermarks.
|
SourceOutputWithWatermarks<T> |
Implementation of the SourceOutput.
|
SourcePredicates |
Predicates for a JavaClass 's Source .
|
SourceProvider |
|
SourceQueryOperation |
|
SourceReader<T,SplitT extends SourceSplit> |
The interface for a source reader which is responsible for reading the records from the source
splits assigned by SplitEnumerator .
|
SourceReaderBase<E,T,SplitT extends SourceSplit,SplitStateT> |
An abstract implementation of SourceReader which provides some synchronization between
the mail box main thread and the SourceReader internal threads.
|
SourceReaderContext |
The interface that exposes some context from runtime to the SourceReader .
|
SourceReaderFactory<T,SplitT extends SourceSplit> |
A factory for creating source reader instances.
|
SourceReaderFinishedEvent |
A source event sent from the HybridSourceReader to the enumerator to indicate that the current
reader has finished and splits for the next reader can be sent.
|
SourceReaderMetricGroup |
Pre-defined metrics for SourceReader .
|
SourceReaderOptions |
|
SourceReaderTestBase<SplitT extends SourceSplit> |
An abstract test class for all the unit tests of SourceReader to inherit.
|
SourceSplit |
An interface for all the Split types to extend.
|
SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>> |
Deprecated.
|
SourceTestSuiteBase<T> |
Base class for all test suites.
|
SourceTestSuiteBase.CollectIteratorBuilder<T> |
|
SourceTransformation<OUT,SplitT extends SourceSplit,EnumChkT> |
|
SourceTransformationTranslator<OUT,SplitT extends SourceSplit,EnumChkT> |
|
SourceTransformationWrapper<T> |
This Transformation is a phantom transformation which is used to expose a default parallelism to
downstream.
|
SourceWatermarkFunction |
|
SourceWatermarkSpec |
|
SpaceBasedCacheLimitPolicy |
A space based cache limit policy that leverages the system to check the free space dynamically,
the free space may fluctuate in size due to other components.
|
SpaceUtils |
Utils.
|
Span |
Span represents something that happened in Flink at certain point of time, that will be reported
to a TraceReporter .
|
SpanBuilder |
Builder used to construct Span .
|
SpecializedFunction |
A FunctionDefinition that can provide a runtime implementation (i.e. the function's body)
that is specialized for the given call and session.
|
SpecializedFunction.ExpressionEvaluator |
Serializable factory that can be passed into a UserDefinedFunction for evaluating
previously defined expression during runtime.
|
SpecializedFunction.ExpressionEvaluatorFactory |
|
SpecializedFunction.SpecializedContext |
Provides call and session information for the specialized function.
|
SpecificInputTypeStrategies |
|
SpecificTypeStrategies |
Entry point for specific type strategies not covered in TypeStrategies .
|
SpeculativeExecutionHandler |
Interface for managing speculative execution of tasks and handling slow task detection.
|
SpeculativeExecutionJobVertex |
The ExecutionJobVertex which supports speculative execution.
|
SpeculativeExecutionJobVertex.Factory |
|
SpeculativeExecutionVertex |
The ExecutionVertex which supports speculative execution.
|
SpillChannelManager |
Channel manager to manage the life cycle of spill channels.
|
SpillingAdaptiveSpanningRecordDeserializer<T extends IOReadableWritable> |
|
SpillingBuffer |
An output view that buffers written data in memory pages and spills them when they are full.
|
SpillingResettableIterator<T> |
Implementation of a resettable iterator.
|
SpillingResettableMutableObjectIterator<T> |
Implementation of a resettable iterator.
|
SplitAssignmentTracker<SplitT extends SourceSplit> |
A class that is responsible for tracking the past split assignments made by SplitEnumerator .
|
SplitEnumerator<SplitT extends SourceSplit,CheckpointT> |
The interface for a split enumerator responsible for discovering the source splits, and assigning
them to the SourceReader .
|
SplitEnumeratorContext<SplitT extends SourceSplit> |
|
SplitEnumeratorMetricGroup |
Pre-defined metrics for SplitEnumerator .
|
SplitFetcher<E,SplitT extends SourceSplit> |
The internal fetcher runnable responsible for polling message from the external system.
|
SplitFetcherManager<E,SplitT extends SourceSplit> |
A class responsible for starting the SplitFetcher and manage the life cycles of them.
|
SplitFetcherTask |
An interface similar to Runnable but allows throwing exceptions and wakeup.
|
SplitFunction |
|
SplitPythonConditionFromCorrelateRule |
Rule will split a FlinkLogicalCalc which is the upstream of a FlinkLogicalCorrelate and contains Python Functions in condition into two FlinkLogicalCalc s.
|
SplitPythonConditionFromCorrelateRule.SplitPythonConditionFromCorrelateRuleConfig |
Rule configuration.
|
SplitReader<E,SplitT extends SourceSplit> |
An interface used to read from splits.
|
SplitsAddition<SplitT> |
A change to add splits.
|
SplitsAssignment<SplitT extends SourceSplit> |
A class containing the splits assignment to the source readers.
|
SplitsChange<SplitT> |
An abstract class to host splits change.
|
SplitsRemoval<SplitT> |
A change to remove splits.
|
SplittableIterator<T> |
Abstract base class for iterators that can split themselves into multiple disjoint iterators.
|
SqlAddJar |
Add Jar command to add jar into the classloader.
|
SqlAddPartitions |
ALTER TABLE DDL to add partitions to a table.
|
SqlAddPartitions.AlterTableAddPartitionContext |
Alter table add partition context.
|
SqlAggFunctionVisitor |
|
SqlAlterCatalog |
Abstract class to describe statements like ALTER CATALOG catalog_name.
|
SqlAlterCatalogComment |
ALTER CATALOG catalog_name COMMENT 'comment'.
|
SqlAlterCatalogCommentConverter |
|
SqlAlterCatalogOptions |
ALTER CATALOG catalog_name SET (key1=val1, ...).
|
SqlAlterCatalogOptionsConverter |
|
SqlAlterCatalogReset |
ALTER CATALOG catalog_name RESET (key1, ...).
|
SqlAlterCatalogResetConverter |
|
SqlAlterDatabase |
ALTER Database DDL sql call.
|
SqlAlterFunction |
Alter Function Sql Call.
|
SqlAlterMaterializedTable |
Abstract class to describe statements like ALTER MATERIALIZED TABLE [catalogName.]
|
SqlAlterMaterializedTableFreshness |
SqlNode to describe ALTER MATERIALIZED TABLE [catalogName.]
|
SqlAlterMaterializedTableOptions |
SqlNode to describe ALTER MATERIALIZED TABLE [catalog_name.]
|
SqlAlterMaterializedTableRefresh |
SqlNode to describe ALTER MATERIALIZED TABLE [catalog_name.]
|
SqlAlterMaterializedTableRefreshConverter |
|
SqlAlterMaterializedTableRefreshMode |
SqlNode to describe ALTER MATERIALIZED TABLE [catalog_name.]
|
SqlAlterMaterializedTableReset |
SqlNode to describe ALTER MATERIALIZED TABLE [catalog_name.]
|
SqlAlterMaterializedTableResume |
SqlNode to describe ALTER MATERIALIZED TABLE [catalog_name.]
|
SqlAlterMaterializedTableResumeConverter |
|
SqlAlterMaterializedTableSuspend |
SqlNode to describe ALTER MATERIALIZED TABLE [catalog_name.]
|
SqlAlterMaterializedTableSuspendConverter |
|
SqlAlterModel |
ALTER MODEL [IF EXISTS] [[catalogName.] dataBasesName].modelName SET ( name=value [,
name=value]*).
|
SqlAlterTable |
Abstract class to describe statements like ALTER TABLE [IF EXISTS] [[catalogName.]
|
SqlAlterTable.AlterTableContext |
Alter table context.
|
SqlAlterTableAdd |
SqlNode to describe ALTER TABLE [IF EXISTS] table_name ADD column/constraint/watermark clause.
|
SqlAlterTableAddConstraint |
ALTER TABLE [IF EXISTS] [catalog_name.]
|
SqlAlterTableAddPartitionConverter |
|
SqlAlterTableCompact |
ALTER TABLE [IF EXISTS] [[catalogName.] dataBasesName].tableName [PARTITION partition_spec]
COMPACT.
|
SqlAlterTableDropColumn |
SqlNode to describe ALTER TABLE [IF EXISTS] table_name DROP column clause.
|
SqlAlterTableDropConstraint |
ALTER TABLE [IF EXISTS] [catalog_name.]
|
SqlAlterTableDropDistribution |
SqlNode to describe ALTER TABLE [IF EXISTS] table_name DROP DISTRIBUTION clause.
|
SqlAlterTableDropPartitionConverter |
|
SqlAlterTableDropPrimaryKey |
ALTER TABLE [IF EXISTS] [catalog_name.]
|
SqlAlterTableDropWatermark |
SqlNode to describe ALTER TABLE [IF EXISTS] table_name DROP watermark clause.
|
SqlAlterTableModify |
SqlNode to describe ALTER TABLE [IF EXISTS] table_name MODIFY column/constraint/watermark clause.
|
SqlAlterTableOptions |
ALTER TABLE [IF EXISTS] [[catalogName.] dataBasesName].tableName SET ( name=value [,
name=value]*).
|
SqlAlterTableRename |
ALTER TABLE [IF EXISTS] [[catalogName.] dataBasesName].tableName RENAME TO [[catalogName.]
|
SqlAlterTableRenameColumn |
ALTER TABLE [IF EXISTS] [[catalogName.] dataBasesName].tableName RENAME originColumnName TO
newColumnName.
|
SqlAlterTableReset |
ALTER TABLE [IF EXISTS] [[catalogName.] dataBasesName].tableName RESET ( 'key1' [, 'key2']*).
|
SqlAlterTableSchema |
Abstract class to describe statements which are used to alter table schema.
|
SqlAlterView |
Abstract class to describe ALTER VIEW statements.
|
SqlAlterViewAs |
ALTER DDL to change a view's query.
|
SqlAlterViewAsConverter |
|
SqlAlterViewProperties |
ALTER DDL to change properties of a view.
|
SqlAlterViewPropertiesConverter |
|
SqlAlterViewRename |
ALTER DDL to rename a view.
|
SqlAlterViewRenameConverter |
|
SqlAnalyzeTable |
ANALYZE TABLE to compute the statistics for a given table.
|
SqlArrayConstructor |
SqlOperator for ARRAY , which makes explicit casting if the element type not
equals the derived component type.
|
SqlAuxiliaryGroupAggFunction |
An internal [[SqlAggFunction]] to represents auxiliary group keys which will not be computed as
key and does not also affect the correctness of the final result.
|
SqlBeginStatementSet |
BEGIN STATEMENT SET.
|
SqlCallExpression |
A call to a SQL expression.
|
SqlCallSyntax |
|
SqlCancelException |
Thrown to trigger a canceling of the executing operation.
|
SqlCastFunction |
SqlCastFunction.
|
SqlCatalogViewTable |
A bridge between a Flink's specific CatalogView and a Calcite's RelOptTable .
|
SqlClient |
SQL Client for submitting SQL statements.
|
SqlClientException |
General exception for SQL client related errors.
|
SqlClientOptions |
Options used in sql client.
|
SqlClientParserState |
State of parser used while preparing highlighted output, multiline parsing.
|
SqlClientSyntaxHighlighter |
Sql Client syntax highlighter.
|
SqlColumnPosSpec |
Enumeration of SQL column position specification.
|
SqlCommandParser |
SqlClient command parser.
|
SqlCommandParserImpl |
|
SqlCompileAndExecutePlan |
AST node for COMPILE AND EXECUTE PLAN 'planfile' FOR [DML] .
|
SqlCompilePlan |
AST node for COMPILE PLAN 'planfile' [IF NOT EXISTS] FOR [DML] .
|
SqlCompleter |
SQL code completer.
|
SqlConstraintEnforcement |
Enumeration of SQL constraint enforcement.
|
SqlConstraintValidator |
|
SqlCreateCatalog |
CREATE CATALOG DDL sql call.
|
SqlCreateCatalogConverter |
|
SqlCreateDatabase |
CREATE Database DDL sql call.
|
SqlCreateFunction |
CREATE FUNCTION DDL sql call.
|
SqlCreateMaterializedTable |
CREATE MATERIALIZED TABLE DDL sql call.
|
SqlCreateMaterializedTableConverter |
|
SqlCreateModel |
SqlNode to describe the CREATE MODEL syntax.
|
SqlCreateModelAs |
SqlNode to describe the CREATE MODEL AS syntax.
|
SqlCreateTable |
CREATE TABLE DDL sql call.
|
SqlCreateTable.TableCreationContext |
Table creation context.
|
SqlCreateTableAs |
SqlNode to describe the CREATE TABLE AS syntax.
|
SqlCreateTableLike |
SqlNode to describe the CREATE TABLE LIKE syntax.
|
SqlCreateView |
CREATE VIEW DDL sql call.
|
SqlCreateViewConverter |
|
SqlCumulateTableFunction |
SqlCumulateTableFunction implements an operator for cumulative.
|
SqlDateParser |
Parses a text field into a Date .
|
SqlDateSerializer |
|
SqlDateSerializer.SqlDateSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
SqlDefaultOperator |
Default operator has specified type.
|
SqlDescribeCatalog |
DESCRIBE CATALOG sql call.
|
SqlDescribeCatalogConverter |
|
SqlDescribeDatabase |
DESCRIBE DATABASE [ EXTENDED] [ databaseName.] dataBasesName sql call.
|
SqlDescribeFunctionConverter |
|
SqlDescribeJob |
DESCRIBE | DESC <JOB_ID> sql call.
|
SqlDescribeJobConverter |
|
SqlDescriptorOperator |
DESCRIPTOR appears as an argument in a function.
|
SqlDialect |
Enumeration of valid SQL compatibility modes.
|
SqlDistribution |
Distribution statement in CREATE TABLE DDL, e.g.
|
SqlDropCatalog |
DROP CATALOG DDL sql call.
|
SqlDropDatabase |
DROP DATABASE DDL sql call.
|
SqlDropFunction |
DROP FUNCTION DDL sql call.
|
SqlDropMaterializedTable |
DROP MATERIALIZED TABLE DDL sql call.
|
SqlDropMaterializedTableConverter |
|
SqlDropModel |
SqlNode to describe the DROP MODEL [IF EXISTS] [[catalogName.] dataBasesName].modelName
syntax.
|
SqlDropPartitions |
ALTER TABLE DDL to drop partitions of a table.
|
SqlDropPartitions.AlterTableDropPartitionsContext |
Alter table add partition context.
|
SqlDropTable |
DROP TABLE DDL sql call.
|
SqlDropView |
DROP VIEW DDL sql call.
|
SqlEndStatementSet |
END.
|
SqlExecute |
SqlExecute contains a statement to execute. the statement can be SqlSelect , SqlStatementSet , or RichSqlInsert , such as:
execute select * from Table
execute insert into A select * from B
execute statement set begin insert into A select * from B; insert into C select * from D; end
|
SqlExecutePlan |
AST node for EXECUTE PLAN 'planfile' .
|
SqlExecutionException |
Exception thrown during the execution of SQL statements.
|
SqlExecutionException |
Exception thrown during the execution.
|
SqlExpressionResolver |
|
SqlFirstLastValueAggFunction |
FIRST_VALUE and LAST_VALUE aggregate functions return the first or the
last value in a list of values that are input to the function.
|
SqlFunctionUtils |
Built-in scalar runtime functions.
|
SqlGateway |
Main entry point for the SQL Gateway.
|
SqlGatewayEndpoint |
Endpoint of the SqlGateway to allow users to communicate with.
|
SqlGatewayEndpointFactory |
A factory for creating Endpoint from Configuration.
|
SqlGatewayEndpointFactory.Context |
Provides information describing the endpoint to be accessed.
|
SqlGatewayEndpointFactoryUtils |
|
SqlGatewayEndpointFactoryUtils.DefaultEndpointFactoryContext |
|
SqlGatewayEndpointFactoryUtils.EndpointFactoryHelper |
|
SqlGatewayException |
General exception for SQL gateway related errors.
|
SqlGatewayMessageHeaders<R extends RequestBody,P extends ResponseBody,M extends MessageParameters> |
This class links RequestBody s to ResponseBody s types and contains meta-data
required for their http headers in runtime module.
|
SqlGatewayOpenApiSpecGenerator |
OpenAPI spec generator for the Sql Gateway Rest API.
|
SqlGatewayOptions |
Options to configure the SqlGateway .
|
SqlGatewayOptionsParser |
Parser to parse the command line options.
|
SqlGatewayRestAPIDocGenerator |
Generator for the Sql Gateway Rest API documentation.
|
SqlGatewayRestAPIVersion |
An enum for all versions of the Sql Gateway REST API.
|
SqlGatewayRestEndpoint |
The rest endpoint for sql gateway.
|
SqlGatewayRestEndpointFactory |
The factory for sql gateway.
|
SqlGatewayRestEndpointUtils |
|
SqlGatewayRestOptions |
|
SqlGatewayService |
A service of SQL gateway is responsible for handling requests from the endpoints.
|
SqlGatewayServiceConfigOptions |
|
SqlGatewayServiceImpl |
|
SqlGatewayStreamExecutionEnvironment |
|
SqlGroupedWindowFunction |
SQL function that computes keys by which rows can be partitioned and aggregated.
|
SqlHopTableFunction |
SqlHopTableFunction implements an operator for hopping.
|
SQLJobClientMode |
Use which client to submit job.
|
SQLJobClientMode.EmbeddedSqlClient |
Use the Sql Client embedded mode to submit jobs.
|
SQLJobClientMode.GatewayClientMode |
The base gateway mode to submit jobs.
|
SQLJobClientMode.GatewaySqlClient |
Uses the Sql Client gateway mode to submit jobs.
|
SQLJobClientMode.HiveJDBC |
Uses the Hive JDBC to submit jobs.
|
SQLJobClientMode.RestClient |
Uses a REST Client to submit jobs.
|
SQLJobSubmission |
Programmatic definition of a SQL job-submission.
|
SQLJobSubmission.SQLJobSubmissionBuilder |
|
SqlJoin |
Parse tree node representing a JOIN clause.
|
SqlJoin.SqlJoinOperator |
Describes the syntax of the SQL JOIN operator.
|
SqlJsonQueryFunction |
The JSON_QUERY function.
|
SqlJsonUtils |
Utilities for JSON functions.
|
SqlJsonUtils.JsonQueryReturnType |
|
SqlJsonUtils.PathMode |
Path spec has two different modes: lax mode and strict mode.
|
SqlLikeChainChecker |
String Like util: Matches a chained sequence of checkers.
|
SqlLikeUtils |
Utilities for converting SQL LIKE and SIMILAR operators to regular expressions.
|
SqlListAggFunction |
LISTAGG aggregate function returns the concatenation of a list of values that are
input to the function.
|
SqlLoadModule |
LOAD MODULE sql call.
|
SqlMapConstructor |
SqlOperator for MAP , which makes explicit casting if the element type not
equals the derived component type.
|
SqlMapTypeNameSpec |
Parse SQL MAP type, i.e.
|
SqlMultiLineParser |
Multi-line parser for parsing an arbitrary number of SQL lines until a line ends with ';'.
|
SqlNodeConvertContext |
|
SqlNodeConverter<S extends org.apache.calcite.sql.SqlNode> |
A converter to convert SqlNode instance into Operation .
|
SqlNodeConverter.ConvertContext |
|
SqlNodeConverters |
Registry of SqlNode converters.
|
SqlNodeToOperationConversion |
Mix-in tool class for SqlNode that allows DDL commands to be converted to Operation .
|
SqlParserEOFException |
Exception for incomplete sql statement found while sql parsing.
|
SqlParserException |
Exception for all errors occurring during sql parsing.
|
SqlPartitionSpecProperty |
Properties of PartitionSpec, a key-value pair with key as component identifier and value as
string literal.
|
SqlPartitionUtils |
Utils methods for partition DDLs.
|
SqlProcedureCallConverter |
A converter for call procedure node.
|
SqlProperty |
Properties of a DDL, a key-value pair with key as component identifier and value as string
literal.
|
SqlQueryConverter |
A converter for query SqlNode , e.g., SqlSelect , SqlOrderBy , SqlTableRef .
|
SqlRawTypeNameSpec |
Represents a raw type such as RAW('org.my.Class', 'sW3Djsds...') .
|
SqlRefreshMode |
Enumeration of materialized table refresh mode.
|
SqlRemoveJar |
REMOVE JAR sql call to remove jar from the classloader.
|
SqlReplaceTableAs |
SqlNode to describe the [CREATE OR] REPLACE TABLE AS (RTAS) syntax.
|
SqlReplaceTableAsConverter |
|
SqlReset |
SQL call for "RESET" and "RESET 'key'".
|
SqlResource |
SqlNode to describe resource type and its path information.
|
SqlResourceType |
Enumeration of SQL resource type specification.
|
SqlRichDescribeFunction |
DESCRIBE FUNCTION [EXTENDED] [[catalogName.] dataBasesName].sqlIdentifier sql call.
|
SqlRichDescribeModel |
DESCRIBE MODEL [EXTENDED] [[catalogName.] dataBasesName].sqlIdentifier sql call.
|
SqlRichDescribeTable |
DESCRIBE [ EXTENDED] [[catalogName.] dataBasesName].sqlIdentifier sql call.
|
SqlRichExplain |
EXPLAIN [PLAN FOR | (ESTIMATED_COST | CHANGELOG_MODE | JSON_EXECUTION_PLAN |
ANALYZED_PHYSICAL_PLAN) (,(ESTIMATED_COST | CHANGELOG_MODE | JSON_EXECUTION_PLAN |
PLAN_ADVICE))*] STATEMENT sql call.
|
SqlRowOperator |
Copied to keep null semantics of table api and sql in sync.
|
SqlSessionTableFunction |
SqlSessionTableFunction implements an operator for per-key sessionization.
|
SqlSet |
SQL call for "SET" and "SET 'key' = 'value'".
|
SqlShowCall |
Abstract class for SHOW sql call.
|
SqlShowCatalogs |
SHOW Catalogs sql call.
|
SqlShowCatalogsConverter |
|
SqlShowColumns |
Show [[catalog.] dataBasesName.]sqlIdentifier sql call.
|
SqlShowCreate |
|
SqlShowCreateCatalog |
SHOW CREATE CATALOG sql call.
|
SqlShowCreateCatalogConverter |
|
SqlShowCreateModel |
SHOW CREATE MODEL sql call.
|
SqlShowCreateTable |
SHOW CREATE TABLE sql call.
|
SqlShowCreateView |
SHOW CREATE VIEW sql call.
|
SqlShowCurrentCatalog |
SHOW CURRENT CATALOG sql call.
|
SqlShowCurrentDatabase |
Show current database.
|
SqlShowDatabases |
SHOW Databases sql call.
|
SqlShowDatabasesConverter |
|
SqlShowFunctions |
Show Functions sql call.
|
SqlShowFunctionsConverter |
|
SqlShowJars |
SHOW JARS sql call.
|
SqlShowJobs |
The command to list running flink jobs in a cluster.
|
SqlShowModels |
SqlNode to describe the SHOW MODELS syntax.
|
SqlShowModules |
SHOW [FULL] MODULES sql call.
|
SqlShowPartitions |
SHOW PARTITIONS sql call.
|
SqlShowPartitionsConverter |
|
SqlShowProcedureConverter |
|
SqlShowProcedures |
SHOW PROCEDURES sql call.
|
SqlShowTables |
SHOW TABLES sql call.
|
SqlShowTablesConverter |
|
SqlShowViews |
SHOW VIEWS sql call.
|
SqlShowViewsConverter |
|
SqlStatementSet |
Statement Set contains a group of inserts. eg:
execute statement set begin insert into A select * from B; insert into C select * from D; end
|
SqlStopJob |
The command to stop a flink job.
|
SqlTableColumn |
Table column of a CREATE TABLE DDL.
|
SqlTableColumn.SqlComputedColumn |
A column derived from an expression.
|
SqlTableColumn.SqlMetadataColumn |
A column derived from metadata.
|
SqlTableColumn.SqlRegularColumn |
A regular, physical column.
|
SqlTableColumnPosition |
SqlNode to describe table column and its position.
|
SqlTableConstraint |
Table constraint of a table definition.
|
SqlTableLike |
A LIKE clause in a CREATE TABLE statement.
|
SqlTableLike.FeatureOption |
A feature of a table descriptor that will be merged into the new table.
|
SqlTableLike.MergingStrategy |
A strategy that describes how the features of the parent source table should be merged with
the features of the newly created table.
|
SqlTableLike.SqlTableLikeOption |
|
SqlTableOption |
Table options of a DDL, a key-value pair with both key and value as string literal.
|
SqlThrowExceptionFunction |
Function used to throw an exception, only used internally.
|
SqlTimeParser |
Parses a text field into a Time .
|
SqlTimeSerializer |
|
SqlTimeSerializer.SqlTimeSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
SqlTimestampAddFunction |
The TIMESTAMPADD function, which adds an interval to a datetime (TIMESTAMP, TIME or
DATE).
|
SqlTimestampComparator |
Comparator for comparing Java SQL Timestamps.
|
SqlTimestampLtzTypeNameSpec |
Represents type TIMESTAMP_LTZ(int) which is a synonym of type TIMESTAMP(int) WITH LOCAL TIME
ZONE.
|
SqlTimestampParser |
|
SqlTimestampSerializer |
|
SqlTimestampSerializer.SqlTimestampSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
SqlTimeTypeInfo<T> |
Type information for Java SQL Date/Time/Timestamp.
|
SqlToRelConverter |
Converts a SQL parse tree (consisting of SqlNode objects) into a
relational algebra expression (consisting of RelNode objects).
|
SqlToRelConverter.Config |
Interface to define the configuration for a SqlToRelConverter.
|
SqlToRelConverter.SqlIdentifierFinder |
Visitor that looks for an SqlIdentifier inside a tree of SqlNode objects and return
Boolean.TRUE when it finds one.
|
SqlToRexConverter |
Converts SQL expressions to RexNode .
|
SqlTruncateTable |
SqlNode to describe TRUNCATE TABLE statement.
|
SqlTruncateTableConverter |
|
SqlTryCastFunction |
This class implements the TRY_CAST built-in, essentially delegating all the method
invocations, whenever is possible, to Calcite's SqlCastFunction .
|
SqlTumbleTableFunction |
SqlTumbleTableFunction implements an operator for tumbling.
|
SqlTypeFactoryImpl |
Default implementation SqlTypeFactoryImpl , the class was copied over because of
FLINK-31350.
|
SqlUniqueSpec |
Enumeration of SQL unique specification.
|
SqlUnloadModule |
UNLOAD MODULE sql call.
|
SqlUnparseUtils |
Utils to unparse DDLs.
|
SqlUnresolvedTryCastFunction |
This is the unresolved version of TRY_CAST .
|
SqlUseCatalog |
USE CATALOG sql call.
|
SqlUseDatabase |
USE [catalog.]database sql call.
|
SqlUseModules |
USE MODULES sql call.
|
SqlValidateException |
SQL parse Exception.
|
SqlValidatorImpl |
Default implementation of SqlValidator , the class was copied over because of
CALCITE-4554.
|
SqlValidatorImpl.DmlNamespace |
Common base class for DML statement namespaces.
|
SqlValidatorImpl.FunctionParamInfo |
Utility object used to maintain information about the parameters in a function call.
|
SqlValidatorImpl.IdInfo |
Information about an identifier in a particular scope.
|
SqlValidatorImpl.Status |
Validation status.
|
SqlValidatorUtils |
Utility methods related to SQL validation.
|
SqlValidatorWithSnapshot |
|
SqlWatermark |
Watermark statement in CREATE TABLE DDL, e.g.
|
SqlWindowTableFunction |
Base class for a table-valued function that computes windows.
|
SqlWindowTableFunction.AbstractOperandMetadata |
Partial implementation of operand type checker.
|
SsgNetworkMemoryCalculationUtils |
Util to analyze inputs & outputs of ExecutionJobVertex and calculate network memory
requirement for slot sharing group (SSG).
|
SSLHandlerFactory |
Creates and configures SslHandler instances.
|
SSLUtils |
Common utilities to manage SSL transport settings.
|
StagedSinkModifyOperation |
DML operation that tells to write to a sink which implements SupportsStaging .
|
StagedTable |
The StagedTable is designed to implement Flink's atomic semantic for CTAS(CREATE TABLE AS
SELECT) and RTAS([CREATE OR] REPLACE TABLE AS SELECT) statement using a two-phase commit
protocol.
|
StageRunner |
An interface for different stages of the sorting process.
|
StageRunner.SortStage |
A marker interface for sending messages to different stages.
|
StageRunner.StageMessageDispatcher<E> |
A dispatcher for inter-stage communication.
|
StagingSinkJobStatusHook |
This hook is used to implement atomic semantics for CTAS(CREATE TABLE AS SELECT) or RTAS([CREATE
OR] REPLACE TABLE AS SELECT) statement.
|
StandaloneApplicationClusterConfigurationParserFactory |
Parser factory which generates a StandaloneApplicationClusterConfiguration from a given
list of command line arguments.
|
StandaloneApplicationClusterEntryPoint |
|
StandaloneCheckpointIDCounter |
|
StandaloneCheckpointRecoveryFactory |
|
StandaloneClientFactory |
|
StandaloneClientHAServices |
|
StandaloneClusterDescriptor |
A deployment descriptor for an existing cluster.
|
StandaloneClusterId |
Identifier for standalone clusters.
|
StandaloneCompletedCheckpointStore |
|
StandaloneDispatcher |
Dispatcher implementation which spawns a JobMaster for each submitted JobGraph
within in the same process.
|
StandaloneExecutionPlanStore |
|
StandaloneHaServices |
|
StandaloneLeaderElection |
|
StandaloneLeaderRetrievalService |
|
StandaloneResourceManager |
A standalone implementation of the resource manager.
|
StandaloneResourceManagerFactory |
|
StandaloneSessionClusterEntrypoint |
Entry point for the standalone session cluster.
|
StandaloneThreadedGenerator |
Base for standalone generators that use the state machine to create event sequences and push them
for example into Kafka.
|
StandardConvertletTable |
Standard implementation of SqlRexConvertletTable .
|
StandardDeCompressors |
A collection of common compression formats and de-compressors.
|
StandardSinkTopologies |
This utility class provides building blocks for custom topologies.
|
StartStoppable |
Interface to start and stop the processing of rpc calls in the rpc server.
|
StartsWithFunction |
|
State |
Interface that different types of partitioned state must implement.
|
State |
Interface that different types of partitioned state must implement.
|
State<T> |
Represents a state of the NFA .
|
State |
The State captures the main functionality of the state machine.
|
State.StateType |
Set of valid state types.
|
StateAdaptor<K,N,S extends InternalKvState<K,N,?>> |
An base implementation of state adaptor from v1 to v2.
|
StateAssignmentOperation |
This class encapsulates the operation of assigning restored state when restoring from a
checkpoint.
|
StateBackend |
A State Backend defines how the state of a streaming application is stored locally within
the cluster.
|
StateBackend.CustomInitializationMetrics |
|
StateBackend.KeyedStateBackendParameters<K> |
|
StateBackend.OperatorStateBackendParameters |
|
StateBackendBuilder<T,E extends Throwable> |
A mutable builder to build a state backend instance.
|
StateBackendFactory<T extends StateBackend> |
A factory to create a specific state backend.
|
StateBackendLoader |
This class contains utility methods to load state backends from configurations.
|
StateBackendOptions |
A collection of all configuration options that relate to state backend.
|
StateBootstrapFunction<IN> |
Interface for writing elements to operator state.
|
StateBootstrapFunction.Context |
|
StateBootstrapOperator<IN> |
|
StateBootstrapTransformation<T> |
A StateBootstrapTransformation represents a procedure of writing new operator state into
a Savepoint .
|
StateBootstrapTransformationWithID<T> |
A simple container class that represents a newly bootstrapped operator state within savepoints.
|
StateBootstrapWrapperOperator<IN,OUT,OP extends AbstractStreamOperator<OUT> & OneInputStreamOperator<IN,OUT>> |
Wraps an existing operator so it can be bootstrapped.
|
StateBootstrapWrapperOperatorFactory<IN,OUT,OP extends AbstractStreamOperator<OUT> & OneInputStreamOperator<IN,OUT>,OPF extends OneInputStreamOperatorFactory<IN,OUT>> |
|
StateChange |
Change of state of a keyed operator.
|
StateChangeApplier |
Applies state data change to some state.
|
StateChangeFormat |
Serialization format for state changes.
|
StateChangeFsUploader |
|
StateChangeLogger<Value,Namespace> |
|
StateChangelogHandleReader<Handle extends ChangelogStateHandle> |
|
StateChangelogHandleStreamHandleReader |
|
StateChangelogHandleStreamHandleReader.StateChangeIterator |
Reads a stream of state changes starting from a specified offset.
|
StateChangelogOptions |
A collection of all configuration options that relate to changelog.
|
StateChangelogStorage<Handle extends ChangelogStateHandle> |
A storage for changelog.
|
StateChangelogStorageFactory |
|
StateChangelogStorageLoader |
|
StateChangelogStorageView<Handle extends ChangelogStateHandle> |
A storage view for changelog.
|
StateChangelogWriter<Handle extends ChangelogStateHandle> |
Allows to write data to the log.
|
StateChangeOperation |
|
StateChangeSet |
A set of changes made to some state(s) by a single state backend during a single checkpoint.
|
StateChangeUploader |
The purpose of this interface is to abstract the different implementations of uploading state
changelog parts.
|
StateChangeUploader.UploadTasksResult |
|
StateChangeUploadScheduler |
|
StateChangeUploadScheduler.UploadTask |
|
StateConfigUtil |
|
StateDataView<N> |
A DataView which is implemented using state backend.
|
StateDataViewStore |
This interface contains methods for registering StateDataView with a managed store.
|
StateDeclaration |
|
StateDeclaration.RedistributionMode |
|
StateDeclarations |
This is a helper class for declaring various states.
|
StateDeclarations.AggregatingStateDeclarationBuilder<IN,OUT,ACC> |
|
StateDeclarations.ListStateDeclarationBuilder<T> |
|
StateDeclarations.MapStateDeclarationBuilder<K,V> |
|
StateDeclarations.ReducingStateDeclarationBuilder<T> |
|
StateDeclarations.ValueStateDeclarationBuilder<T> |
|
StateDescriptor<S extends State,T> |
Base class for state descriptors.
|
StateDescriptor<T> |
Base class for state descriptors.
|
StateDescriptor.Type |
An enumeration of the types of supported states.
|
StateDescriptor.Type |
An enumeration of the types of supported states.
|
StateDescriptorUtils |
|
StateEntry<K,N,S> |
Interface of entries in a state backend.
|
StateEntry.SimpleStateEntry<K,N,S> |
|
StateExecutor |
|
StateFactory<T extends org.apache.flink.runtime.scheduler.adaptive.State> |
Factory for creating adaptive scheduler state instances.
|
StatefulComplexPayloadSerializer |
A custom stateful serializer to test that serializers are not used concurrently.
|
StatefulComplexPayloadSerializer.Snapshot |
|
StatefulSequenceSource |
Deprecated.
|
StatefulSinkWriter<InputT,WriterStateT> |
A SinkWriter whose state needs to be checkpointed.
|
StatefulStreamingJob |
A simple stateful job that will be used to test avro state evolution and general state migration.
|
StatefulStreamingJob.MySource |
Stub source that emits one record per second.
|
StatefulStreamingJob.MyStatefulFunction |
|
StatefulStreamJobUpgradeTestProgram |
Test upgrade of generic stateful job for Flink's DataStream API operators and primitives.
|
StateFuture<T> |
StateFuture is a future that act as a return value for async state interfaces.
|
StateFutureFactory<K> |
An internal factory for InternalStateFuture that build future with necessary context
switch and wired with mailbox executor.
|
StateFutureImpl<T> |
|
StateFutureImpl.AsyncFrameworkExceptionHandler |
Handle exceptions thrown by async state callback framework.
|
StateFutureImpl.CallbackRunner |
The entry for a state future to submit task to mailbox.
|
StateFutureUtils |
A collection of utilities that expand the usage of StateFuture .
|
StateHandleDownloadSpec |
|
StateHandleID |
Unique ID that allows for logical comparison between state handles.
|
StateHandleStore<T extends Serializable,R extends ResourceVersion<R>> |
Class which stores state via the provided RetrievableStateStorageHelper and writes the
returned state handle to distributed coordination system(e.g.
|
StateHandleStore.AlreadyExistException |
The key already exists in ConfigMap or the Zookeeper node already exists.
|
StateHandleStore.NotExistException |
The key does not exist in ConfigMap or the Zookeeper node does not exists.
|
StateHandleStoreUtils |
StateHandleStoreUtils collects utility methods that might be usefule for any StateHandleStore implementation.
|
StateHandleTransferSpec |
|
StateInitializationContext |
This interface provides a context in which operators can initialize by registering to managed
state (i.e. state that is managed by state backends) or iterating over streams of state
partitions written as raw state in a previous snapshot.
|
StateInitializationContextImpl |
|
StateIterator<T> |
Asynchronous iterators allow to iterate over data that comes asynchronously, on-demand.
|
StateKeyContext |
Context to switch current key in state backend.
|
StateLatencyTrackOptions |
A collection of all configuration options that relate to the latency tracking for state access.
|
StateListView<N,EE> |
|
StateListView.KeyedStateListView<N,T> |
|
StateListView.NamespacedStateListView<N,T> |
|
StateLocalitySlotAssigner |
A SlotAssigner that assigns slots based on the number of local key groups.
|
StateLocationRetriever |
Component to retrieve the state location of an execution vertex.
|
StateMachineExample |
Main class of the state machine example.
|
StateManager |
This is responsibility for managing runtime information related to state of process function.
|
StateMap<K,N,S> |
Base class for state maps.
|
StateMapSnapshot<K,N,S,T extends StateMap<K,N,S>> |
|
StateMapView<N,EK,EV> |
MapView which is implemented using state backends.
|
StateMapView.KeyedStateMapViewWithKeysNotNull<N,EK,EV> |
A state MapView which does not support nullable keys and namespace.
|
StateMapView.KeyedStateMapViewWithKeysNullable<N,EK,EV> |
A state MapView which supports nullable keys but does not support namespace.
|
StateMapView.NamespacedStateMapViewWithKeysNotNull<N,EK,EV> |
A state MapView which supports namespace but does not support nullable keys.
|
StateMapView.NamespacedStateMapViewWithKeysNullable<N,EK,EV> |
A state MapView which supports nullable keys and namespace.
|
StatementResult |
|
StatementResultIterator |
Closeable result iterator for statement result.
|
StatementSet |
|
StatementSetImpl<E extends TableEnvironmentInternal> |
|
StatementSetOperation |
A Operation that describes the statement set, e.g.
|
StateMetadata |
It is used to describe the state metadata of a stateful operator, which is
serialized/deserialized into/from those StreamExecNode s that can generate stateful
operators.
|
StateMetaInfoReader |
|
StateMetaInfoSnapshot |
Generalized snapshot for meta information about one state in a state backend (e.g.
|
StateMetaInfoSnapshot.BackendStateType |
Enum that defines the different types of state that live in Flink backends.
|
StateMetaInfoSnapshot.CommonOptionsKeys |
Predefined keys for the most common options in the meta info.
|
StateMetaInfoSnapshot.CommonSerializerKeys |
Predefined keys for the most common serializer types in the meta info.
|
StateMetaInfoSnapshotReadersWriters |
|
StateMetaInfoWriter |
|
StateMigrationException |
Base class for state migration related exceptions.
|
StateObject |
Base of all handles that represent checkpointed state in some form.
|
StateObject.StateObjectLocation |
Enum for state locations.
|
StateObject.StateObjectSizeStatsCollector |
|
StateObjectCollection<T extends StateObject> |
This class represents a generic collection for StateObject s.
|
StatePartitionStreamProvider |
This class provides access to input streams that contain data of one state partition of a
partitionable state.
|
StatePathExtractor |
Extracts all file paths that are part of the provided OperatorState .
|
StateReaderOperator<F extends Function,KEY,N,OUT> |
Base class for executing functions that read keyed state.
|
StateRecoveryOptions |
|
StateRequest<K,N,IN,OUT> |
A request encapsulates the necessary data to perform a state request.
|
StateRequestBuffer<K> |
A buffer to hold state requests to execute state requests in batch, which can only be manipulated
within task thread.
|
StateRequestContainer |
|
StateRequestHandler |
|
StateRequestType |
The type of processing request for State from **users' perspective**.
|
StateSerializerProvider<T> |
A StateSerializerProvider wraps logic on how to obtain serializers for registered state,
either with the previous schema of state in checkpoints or the current schema of state.
|
StateSizeEstimates |
Managed Keyed State size estimates used to make scheduling decisions.
|
StateSnapshot |
General interface for state snapshots that should be written partitioned by key-groups.
|
StateSnapshot.StateKeyGroupWriter |
Interface for writing a snapshot that is partitioned into key-groups.
|
StateSnapshotContext |
This interface provides a context in which operators that use managed (i.e. state that is managed
by state backends) or raw (i.e. the operator can write it's state streams) state can perform a
snapshot.
|
StateSnapshotContextSynchronousImpl |
This class is a default implementation for StateSnapshotContext.
|
StateSnapshotKeyGroupReader |
Interface for state de-serialization into StateTable s by key-group.
|
StateSnapshotRestore |
Interface to deal with state snapshot and restore of state.
|
StateSnapshotTransformer<T> |
Transformer of state values which are included or skipped in the snapshot.
|
StateSnapshotTransformer.CollectionStateSnapshotTransformer<T> |
Collection state specific transformer which says how to transform entries of the collection.
|
StateSnapshotTransformer.CollectionStateSnapshotTransformer.TransformStrategy |
|
StateSnapshotTransformer.StateSnapshotTransformFactory<T> |
This factory creates state transformers depending on the form of values to transform.
|
StateSnapshotTransformers |
Collection of common state snapshot transformers and their factories.
|
StateSnapshotTransformers.ListStateSnapshotTransformer<T> |
General implementation of list state transformer.
|
StateSnapshotTransformers.ListStateSnapshotTransformFactory<T> |
|
StateSnapshotTransformers.MapStateSnapshotTransformer<K,V> |
General implementation of map state transformer.
|
StateSnapshotTransformers.MapStateSnapshotTransformFactory<K,V> |
|
StateSnapshotTransformers.StateSnapshotTransformFactoryWrapAdaptor<S,T> |
|
StateTable<K,N,S> |
Base class for state tables.
|
StateTableByKeyGroupReaders |
This class provides a static factory method to create different implementations of StateSnapshotKeyGroupReader depending on the provided serialization format version.
|
StateTimeMetric |
Utility to define metrics that capture the time that some component spends in a state.
|
StateTransformationFunction<S,T> |
Interface for a binary function that is used for push-down of state transformation into state
backends.
|
StateTransition<T> |
Represents a transition from one State to another.
|
StateTransitionAction |
Set of actions when doing a state transition from a State to another.
|
StateTransitionManager |
The StateTransitionManager decides on whether AdaptiveScheduler state transition
should happen or not.
|
StateTransitionManager.Context |
The interface that can be used by the StateTransitionManager to communicate with the
underlying system.
|
StateTransitions |
An interface covering all possible State transitions.
|
StateTransitions.ToCancelling |
Interface covering transition to the Canceling state.
|
StateTransitions.ToCreatingExecutionGraph |
|
StateTransitions.ToExecuting |
Interface covering transition to the Executing state.
|
StateTransitions.ToFailing |
Interface covering transition to the Failing state.
|
StateTransitions.ToFinished |
Interface covering transition to the Finished state.
|
StateTransitions.ToRestarting |
Interface covering transition to the Restarting state.
|
StateTransitions.ToStopWithSavepoint |
Interface covering transition to the StopWithSavepoint state.
|
StateTransitions.ToWaitingForResources |
Interface covering transition to the WaitingForResources state.
|
StateTtlConfig |
Configuration of state TTL logic.
|
StateTtlConfig.Builder |
|
StateTtlConfig.CleanupStrategies |
TTL cleanup strategies.
|
StateTtlConfig.IncrementalCleanupStrategy |
Configuration of cleanup strategy while taking the full snapshot.
|
StateTtlConfig.RocksdbCompactFilterCleanupStrategy |
Configuration of cleanup strategy using custom compaction filter in RocksDB.
|
StateTtlConfig.StateVisibility |
This option configures whether expired user value can be returned or not.
|
StateTtlConfig.TtlTimeCharacteristic |
This option configures time scale to use for ttl.
|
StateTtlConfig.UpdateType |
This option value configures when to update last access timestamp which prolongs state TTL.
|
StateTtlHint |
|
StateTypeStrategy |
Strategy for inferring a function call's intermediate result data type (i.e. state entry).
|
StateTypeStrategyWrapper |
|
StateUtil |
|
StaticArgument |
Describes an argument in a static signature that is not overloaded and does not support varargs.
|
StaticArgumentTrait |
|
StaticDMetric |
A DMetric that returns a fixed value.
|
StaticExternalResourceInfoProvider |
|
StaticFileServerHandler<T extends RestfulGateway> |
Simple file server handler that serves requests to web frontend's static files, such as HTML,
CSS, or JS files.
|
StaticFileSplitEnumerator |
A SplitEnumerator implementation for bounded / batch FileSource input.
|
StaticResultProvider |
Create result provider from a static set of data using external types.
|
Statistics |
Represents one or more statistics samples.
|
StatsDReporter |
Largely based on the StatsDReporter class by ReadyTalk.
|
StatsDReporterFactory |
|
StatsSummary |
Aggregated values of some measurement such as min/max/average state size.
|
StatsSummaryDto |
|
StatsSummarySnapshot |
|
StatusDurationUtils |
Utilities to calculate status duration.
|
StatusWatermarkValve |
A StatusWatermarkValve embodies the logic of how Watermark and WatermarkStatus are propagated to downstream outputs, given a set of one or multiple
subpartitions that continuously receive them.
|
StatusWatermarkValve.SubpartitionStatus |
An SubpartitionStatus keeps track of a subpartition's last watermark, stream status,
and whether or not the subpartition's current watermark is aligned with the overall watermark
output from the valve.
|
StickyAllocationAndLocalRecoveryTestJob |
Automatic end-to-end test for local recovery (including sticky allocation).
|
StickyAllocationAndLocalRecoveryTestJob.MapperSchedulingAndFailureInfo |
Records the information required to check sticky scheduling after a restart.
|
StopJobOperation |
Operation to stop a running job.
|
StopMode |
Tells if the job is stopping because of consuming all data.
|
StoppedDispatcherLeaderProcess |
DispatcherLeaderProcess implementation which is stopped.
|
StopWithSavepointRequestBody |
|
StopWithSavepointStoppingException |
Exception thrown when a savepoint has been created successfully when stopping with savepoint, but
the job has not finished.
|
StopWithSavepointTerminationHandler |
StopWithSavepointTerminationHandler handles the steps necessary for the
stop-with-savepoint operation to finish.
|
StopWithSavepointTerminationHandlerImpl |
|
StopWithSavepointTerminationManager |
|
StopWithSavepointTriggerHeaders |
These headers define the protocol for triggering a "stop" action.
|
StreamArrowPythonGroupWindowAggregateFunctionOperator<K,W extends Window> |
|
StreamArrowPythonProcTimeBoundedRangeOperator<K> |
The Stream Arrow Python AggregateFunction Operator for ROWS clause proc-time bounded OVER
window.
|
StreamArrowPythonProcTimeBoundedRowsOperator<K> |
The Stream Arrow Python AggregateFunction Operator for ROWS clause proc-time bounded OVER
window.
|
StreamArrowPythonRowTimeBoundedRangeOperator<K> |
The Stream Arrow Python AggregateFunction Operator for RANGE clause event-time bounded
OVER window.
|
StreamArrowPythonRowTimeBoundedRowsOperator<K> |
The Stream Arrow Python AggregateFunction Operator for RANGE clause event-time bounded
OVER window.
|
StreamCompressionDecorator |
Implementations of this interface decorate streams with a compression scheme.
|
StreamConfig |
|
StreamConfig.InputConfig |
Interface representing chained inputs.
|
StreamConfig.InputRequirement |
Requirements of the different inputs of an operator.
|
StreamConfig.NetworkInputConfig |
|
StreamConfig.SourceInputConfig |
A serialized representation of an input.
|
StreamContextEnvironment |
|
StreamEdge |
An edge in the streaming topology.
|
StreamElement |
An element in a data stream.
|
StreamElementQueue<OUT> |
|
StreamElementSerializer<T> |
|
StreamElementSerializer.StreamElementSerializerSnapshot<T> |
|
StreamExchangeMode |
The data exchange mode between operators during StreamGraph generation.
|
StreamExchangeModeUtils |
Utility class to load job-wide exchange mode.
|
StreamExecAggregateBase |
|
StreamExecAsyncCalc |
|
StreamExecCalc |
|
StreamExecChangelogNormalize |
Stream ExecNode which normalizes a changelog stream which maybe an upsert stream or a
changelog stream containing duplicate events.
|
StreamExecCorrelate |
Stream ExecNode which matches along with join a Java/Scala user defined table function.
|
StreamExecDataStreamScan |
|
StreamExecDeduplicate |
Stream ExecNode which deduplicate on keys and keeps only first row or last row.
|
StreamExecDropUpdateBefore |
Stream ExecNode which will drop the UPDATE_BEFORE messages.
|
StreamExecExchange |
This ExecNode represents a change of partitioning of the input elements for stream.
|
StreamExecExpand |
Stream ExecNode that can expand one row to multiple rows based on given projects.
|
StreamExecGlobalGroupAggregate |
Stream ExecNode for unbounded global group aggregate.
|
StreamExecGlobalWindowAggregate |
Stream ExecNode for window table-valued based global aggregate.
|
StreamExecGroupAggregate |
Stream ExecNode for unbounded group aggregate.
|
StreamExecGroupTableAggregate |
Stream ExecNode for unbounded java/scala group table aggregate.
|
StreamExecGroupWindowAggregate |
Stream ExecNode for either group window aggregate or group window table aggregate.
|
StreamExecIncrementalGroupAggregate |
Stream ExecNode for unbounded incremental group aggregate.
|
StreamExecIntervalJoin |
|
StreamExecJoin |
|
StreamExecLegacySink<T> |
|
StreamExecLegacyTableSourceScan |
|
StreamExecLimit |
|
StreamExecLocalGroupAggregate |
Stream ExecNode for unbounded local group aggregate.
|
StreamExecLocalWindowAggregate |
Stream ExecNode for window table-valued based local aggregate.
|
StreamExecLookupJoin |
|
StreamExecMatch |
Stream ExecNode which matches along with MATCH_RECOGNIZE.
|
StreamExecMiniBatchAssigner |
Stream ExecNode which injects a mini-batch event in the streaming data.
|
StreamExecMultipleInput |
|
StreamExecNode<T> |
|
StreamExecOverAggregate |
Stream ExecNode for time-based over operator.
|
StreamExecPythonCalc |
Stream ExecNode for Python ScalarFunctions.
|
StreamExecPythonCorrelate |
Stream exec node which matches along with join a Python user defined table function.
|
StreamExecPythonGroupAggregate |
Stream ExecNode for Python unbounded group aggregate.
|
StreamExecPythonGroupTableAggregate |
Stream ExecNode for unbounded python group table aggregate.
|
StreamExecPythonGroupWindowAggregate |
Stream ExecNode for group widow aggregate (Python user defined aggregate function).
|
StreamExecPythonOverAggregate |
Stream ExecNode for python time-based over operator.
|
StreamExecRank |
|
StreamExecSink |
|
StreamExecSort |
|
StreamExecSortLimit |
|
StreamExecTableSourceScan |
|
StreamExecTemporalJoin |
StreamExecNode for temporal table join (FOR SYSTEM_TIME AS OF) and temporal TableFunction
join (LATERAL TemporalTableFunction(o.proctime)).
|
StreamExecTemporalSort |
|
StreamExecUnion |
Stream ExecNode that is not a physical node and just union the inputs' records into one
node.
|
StreamExecutionEnvironment |
The StreamExecutionEnvironment is the context in which a streaming program is executed.
|
StreamExecutionEnvironmentFactory |
Factory class for stream execution environments.
|
StreamExecutorFactory |
|
StreamExecValues |
Stream ExecNode that read records from given values.
|
StreamExecWatermarkAssigner |
Stream ExecNode which generates watermark based on the input elements.
|
StreamExecWindowAggregate |
Stream ExecNode for window table-valued based aggregate.
|
StreamExecWindowAggregateBase |
The base class for window aggregate ExecNode .
|
StreamExecWindowDeduplicate |
|
StreamExecWindowJoin |
|
StreamExecWindowRank |
|
StreamExecWindowTableFunction |
Stream ExecNode which acts as a table-valued function to assign a window for each row of
the input relation.
|
StreamFilter<IN> |
|
StreamFlatMap<IN,OUT> |
|
StreamFormat<T> |
A reader format that reads individual records from a stream.
|
StreamFormat.Reader<T> |
The actual reader that reads the records.
|
StreamFormatAdapter<T> |
|
StreamFormatAdapter.Reader<T> |
|
StreamGraph |
Class representing the streaming topology.
|
StreamGraphGenerator |
|
StreamGraphHasher |
Interface for different implementations of generating hashes over a stream graph.
|
StreamGraphHasherV2 |
StreamGraphHasher from Flink 1.2.
|
StreamGraphTranslator |
|
StreamGraphUserHashHasher |
StreamGraphHasher that works with user provided hashes.
|
StreamGraphUtils |
Utility class that contains helper methods to generating StreamGraph .
|
StreamGroupedReduceOperator<IN> |
|
StreamingFileSink<IN> |
Deprecated.
|
StreamingFileSink.BucketsBuilder<IN,BucketID,T extends StreamingFileSink.BucketsBuilder<IN,BucketID,T>> |
|
StreamingFileSink.BulkFormatBuilder<IN,BucketID,T extends StreamingFileSink.BulkFormatBuilder<IN,BucketID,T>> |
A builder for configuring the sink for bulk-encoding formats, e.g.
|
StreamingFileSink.DefaultBulkFormatBuilder<IN> |
|
StreamingFileSink.DefaultRowFormatBuilder<IN> |
|
StreamingFileSink.RowFormatBuilder<IN,BucketID,T extends StreamingFileSink.RowFormatBuilder<IN,BucketID,T>> |
A builder for configuring the sink for row-wise encoding formats.
|
StreamingFileSinkHelper<IN> |
|
StreamingFileWriter<IN> |
|
StreamingFunctionUtils |
Utility class that contains helper methods to work with Flink Streaming Functions .
|
StreamingJobGraphGenerator |
|
StreamingJoinOperator |
Streaming unbounded Join operator which supports INNER/LEFT/RIGHT/FULL JOIN.
|
StreamingRuntimeContext |
|
StreamingSemiAntiJoinOperator |
Streaming unbounded Join operator which supports SEMI/ANTI JOIN.
|
StreamingSink |
Helper for creating streaming file sink.
|
StreamInputProcessor |
|
StreamIterationHead<OUT> |
A special StreamTask that is used for executing feedback edges.
|
StreamIterationTail<IN> |
A special StreamTask that is used for executing feedback edges.
|
StreamMap<IN,OUT> |
|
StreamMultipleInputProcessor |
|
StreamMultipleInputProcessorFactory |
|
StreamNode |
Class representing the operators in the streaming programs, with all their properties.
|
StreamNonDeterministicPhysicalPlanResolver |
|
StreamNonDeterministicUpdatePlanVisitor |
An inner visitor to validate if there's any NDU problems which may cause wrong result and try to
rewrite lookup join node with materialization (to eliminate the non-deterministic result
generated by lookup join node only).
|
StreamOneInputProcessor<IN> |
|
StreamOperator<OUT> |
Basic interface for stream operators.
|
StreamOperatorFactory<OUT> |
|
StreamOperatorFactoryUtil |
A utility to instantiate new operators with a given factory.
|
StreamOperatorParameters<OUT> |
|
StreamOperatorStateContext |
This interface represents a context from which a stream operator can initialize everything
connected to state such as e.g. backends, raw state, and timer service manager.
|
StreamOperatorStateHandler |
Class encapsulating various state backend handling logic for StreamOperator
implementations.
|
StreamOperatorStateHandler.CheckpointedStreamOperator |
|
StreamOperatorUtils |
|
StreamOperatorWrapper<OUT,OP extends StreamOperator<OUT>> |
This class handles the finish, endInput and other related logic of a StreamOperator .
|
StreamPartitioner<T> |
|
StreamPhysicalAsyncCalc |
|
StreamPhysicalAsyncCalcRule |
A physical rule for identifying logical async Calcs and converting it to a physical RelNode.
|
StreamPhysicalCalcRemoveRule |
Rule to remove trivial StreamPhysicalCalc .
|
StreamPhysicalConstantTableFunctionScanRule |
Converts FlinkLogicalTableFunctionScan with constant RexCall.
|
StreamPhysicalConstantTableFunctionScanRule.StreamPhysicalConstantTableFunctionScanRuleConfig |
|
StreamPhysicalPythonCorrelateRule |
The physical rule is responsible for convert FlinkLogicalCorrelate to StreamPhysicalPythonCorrelate .
|
StreamPhysicalPythonGroupAggregateRule |
Rule to convert a FlinkLogicalAggregate into a StreamPhysicalPythonGroupAggregate .
|
StreamPhysicalPythonGroupTableAggregateRule |
|
StreamPhysicalPythonGroupWindowAggregateRule |
The physical rule is responsible for converting FlinkLogicalWindowAggregate to StreamPhysicalPythonGroupWindowAggregate .
|
StreamPhysicalPythonOverAggregateRule |
The physical rule is responsible for converting FlinkLogicalOverAggregate to StreamPhysicalPythonOverAggregate .
|
StreamPlanEnvironment |
A special StreamExecutionEnvironment that is used in the web frontend when generating a
user-inspectable graph of a streaming job.
|
StreamProject<IN,OUT extends Tuple> |
|
StreamProjection<IN> |
|
StreamPythonUdfSqlJob |
A simple job used to test submitting the Python UDF job in stream mode.
|
StreamRecord<T> |
One value in a data stream.
|
StreamRecordCollector<T> |
|
StreamRecordComparator<IN> |
|
StreamRecordRowDataWrappingCollector |
|
StreamRecordTimestamp |
Deprecated.
|
StreamRecordTimestampInserter |
Operator which sets the timestamp on the StreamRecord from the corresponding column of each row.
|
StreamSink<IN> |
|
StreamSortOperator |
Operator for stream sort.
|
StreamSource<OUT,SRC extends SourceFunction<OUT>> |
Deprecated.
|
StreamSourceContexts |
Deprecated.
|
StreamSQLExample |
Simple example for demonstrating the use of SQL on a table backed by a DataStream in Java
DataStream API.
|
StreamSQLExample.Order |
Simple POJO.
|
StreamSQLTestProgram |
End-to-end test for Stream SQL queries.
|
StreamSQLTestProgram.Generator |
Data-generating source function.
|
StreamSQLTestProgram.GeneratorTableSource |
TableSource for generated data.
|
StreamSQLTestProgram.KeyBucketAssigner |
Use first field for buckets.
|
StreamSQLTestProgram.KillMapper |
Kills the first execution attempt of an application when it receives the second record.
|
StreamStateHandle |
A StateObject that represents state that was written to a stream.
|
StreamStatementSet |
|
StreamStatementSetImpl |
|
StreamTableEnvironment |
This table environment is the entry point and central context for creating Table and SQL API
programs that integrate with the Java-specific DataStream API.
|
StreamTableEnvironmentImpl |
|
StreamTableSink<T> |
Deprecated.
|
StreamTableSinkFactory<T> |
Deprecated.
|
StreamTableSource<T> |
Deprecated.
|
StreamTableSourceFactory<T> |
Deprecated.
|
StreamTask<OUT,OP extends StreamOperator<OUT>> |
Base class for all streaming tasks.
|
StreamTask.CanEmitBatchOfRecordsChecker |
Check whether records can be emitted in batch.
|
StreamTaskActionExecutor |
|
StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor |
Deprecated.
|
StreamTaskCancellationContext |
Context on the StreamTask for figuring out whether it has been cancelled.
|
StreamTaskException |
An exception that is thrown by the stream vertices when encountering an illegal condition.
|
StreamTaskExternallyInducedSourceInput<T> |
|
StreamTaskFinishedOnRestoreSourceInput<T> |
A special source input implementation that immediately emit END_OF_INPUT.
|
StreamTaskInput<T> |
Basic interface for inputs of stream operators.
|
StreamTaskNetworkInput<T> |
|
StreamTaskNetworkInputFactory |
|
StreamTaskSourceInput<T> |
|
StreamTaskStateInitializer |
|
StreamTaskStateInitializerImpl |
|
StreamTaskStateInitializerImpl.KeyedStateBackendCreator<K,R extends Disposable & Closeable> |
Functional interface to create the keyed state backend.
|
StreamTwoInputProcessorFactory |
|
StreamUtils |
This class encapsulates the common logic for all type of streams.
|
StreamWindowSQLExample |
Simple example for demonstrating the use of SQL in Java.
|
StringArraySerializer |
A serializer for String arrays.
|
StringArraySerializer.StringArraySerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
StringBasedID |
Base class for typed IDs that are internally represented by a string.
|
StringByteArrayConverter |
|
StringComparator |
|
StringData |
|
StringDataSerializer |
|
StringDataSerializer.StringDataSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
StringDataTypeInfo |
|
StringifiedAccumulatorResult |
Container class that transports the result of an accumulator as set of strings.
|
StringParser |
Converts a variable length field of a byte array into a String .
|
StringQueryParameter |
Abstract super class for String query parameters.
|
StringRegexReplaceFunction |
Scalar function for replacing all occurrences of a regular expression with a replacement string.
|
StringResourceVersion |
|
StringSerializer |
Type serializer for String .
|
StringSerializer |
We create the StringSerializer instead of using the StringSerializer of flink-core module because
the StringSerializer of flink-core module serialize every Char of String in serialize method and
deserialize the Char to build the String.
|
StringSerializer.StringSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
StringSerializer.StringSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
StringStringConverter |
|
StringUtf8Utils |
String utf-8 utils.
|
StringUtils |
Utility class to convert objects into strings in vice-versa.
|
StringValue |
Mutable string data type that implements the Key interface.
|
StringValueComparator |
Specialized comparator for StringValue based on CopyableValueComparator.
|
StringValueParser |
Converts a variable length field of a byte array into a StringValue .
|
StringValueSerializer |
|
StringValueSerializer.StringValueSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
StringValueUtils |
|
StringValueUtils.WhitespaceTokenizer |
A tokenizer for string values that uses whitespace characters as token delimiters.
|
StronglyConnectedComponentsComputeUtils |
Utility for computing strongly connected components.
|
StructuredObjectConverter<T> |
|
StructuredRelDataType |
|
StructuredType |
Logical type of a user-defined object structured type.
|
StructuredType.Builder |
|
StructuredType.StructuredAttribute |
|
StructuredType.StructuredComparison |
Defines equality properties for scalar evaluation.
|
SubmoduleClassLoader |
Loads all classes from the submodule jar, except for explicitly white-listed packages.
|
SubpartitionSelector<T> |
SubpartitionSelector helps to choose from multiple available subpartitions when their
output buffers should union into one stream.
|
SubQueryDecorrelator |
SubQueryDecorrelator finds all correlated expressions in a SubQuery, and gets an equivalent
non-correlated relational expression tree and correlation conditions.
|
SubQueryDecorrelator.Result |
Result describing the relational expression after decorrelation and where to find the
equivalent non-correlated expressions and correlated conditions.
|
SubQueryDecorrelator.SubQueryRelDecorrelator |
Pull out all correlation conditions from a given subquery to top level, and rebuild the
subquery rel tree without correlation conditions.
|
SubQueryInputTypeStrategy |
|
SubsequenceInputTypeStrategy |
An InputTypeStrategy that lets you apply other strategies for subsequences of the actual
arguments.
|
SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder |
|
SubtaskAttemptMessageParameters |
The type Subtask attempt message parameters.
|
SubtaskAttemptNumberStore |
Contains the attempt number per subtask.
|
SubtaskAttemptPathParameter |
Path parameter identifying subtask attempt.
|
SubtaskCheckpointCoordinator |
Coordinates checkpointing-related work for a subtask (i.e.
|
SubtaskCheckpointStatistics |
Checkpoint statistics for a subtask.
|
SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics |
Checkpoint statistics for a completed subtask checkpoint.
|
SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment |
Alignment statistics of the checkpoint.
|
SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration |
Duration of the checkpoint.
|
SubtaskCheckpointStatistics.PendingSubtaskCheckpointStatistics |
Checkpoint statistics for a pending subtask checkpoint.
|
SubtaskConnectionDescriptor |
An event that is used to (de)multiplex old channels over the same new channel.
|
SubtaskCurrentAttemptDetailsHandler |
Request handler providing details about a single task execution attempt.
|
SubtaskCurrentAttemptDetailsHeaders |
|
SubtaskExecutionAttemptAccumulatorsHandler |
Request handler for the subtask execution attempt accumulators.
|
SubtaskExecutionAttemptAccumulatorsHeaders |
|
SubtaskExecutionAttemptAccumulatorsInfo |
|
SubtaskExecutionAttemptDetailsHandler |
Handler of specific sub task execution attempt.
|
SubtaskExecutionAttemptDetailsHeaders |
|
SubtaskExecutionAttemptDetailsInfo |
The sub task execution attempt response.
|
SubtaskFileMergingManagerRestoreOperation |
|
SubtaskIndexPathParameter |
Path parameter specifying the index of a subtask.
|
SubtaskIndexQueryParameter |
Query parameter specifying the index of a subtask.
|
SubTaskInitializationMetrics |
A collection of simple metrics, around the triggering of a checkpoint.
|
SubTaskInitializationMetricsBuilder |
|
SubtaskMessageParameters |
Message parameters for subtask REST handlers.
|
SubtaskMetricsHandler |
Handler that returns subtask metrics.
|
SubtaskMetricsHeaders |
|
SubtaskMetricsMessageParameters |
|
SubtasksAllAccumulatorsHandler |
Request handler for the subtasks all accumulators.
|
SubtasksAllAccumulatorsHeaders |
|
SubtasksAllAccumulatorsInfo |
|
SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo |
Detailed information about subtask accumulators.
|
SubtasksFilterQueryParameter |
|
SubtaskState |
Deprecated.
|
SubtaskStateMapper |
The SubtaskStateMapper narrows down the subtasks that need to be read during rescaling to
recover from a particular subtask when in-flight data has been stored in the checkpoint.
|
SubtaskStateStats |
Statistics for a single subtask that is part of a checkpoint.
|
SubtasksTimesHandler |
Request handler for the subtasks times info.
|
SubtasksTimesHeaders |
|
SubtasksTimesInfo |
|
SubtasksTimesInfo.SubtaskTimeInfo |
Nested class to encapsulate the sub task times info.
|
SubtypeCondition<T> |
A condition which filters elements of the given type.
|
SuccessException |
Exception that is thrown to terminate a program and indicate success.
|
SuccessFileCommitPolicy |
Partition commit policy to add success file to directory.
|
Sum0AggFunction |
built-in sum0 aggregate function.
|
Sum0AggFunction.ByteSum0AggFunction |
Built-in Byte Sum0 aggregate function.
|
Sum0AggFunction.DecimalSum0AggFunction |
Built-in Decimal Sum0 aggregate function.
|
Sum0AggFunction.DoubleSum0AggFunction |
Built-in Double Sum0 aggregate function.
|
Sum0AggFunction.FloatSum0AggFunction |
Built-in Float Sum0 aggregate function.
|
Sum0AggFunction.IntSum0AggFunction |
Built-in Int Sum0 aggregate function.
|
Sum0AggFunction.LongSum0AggFunction |
Built-in Long Sum0 aggregate function.
|
Sum0AggFunction.ShortSum0AggFunction |
Built-in Short Sum0 aggregate function.
|
SumAggFunction |
built-in sum aggregate function.
|
SumAggFunction.ByteSumAggFunction |
Built-in Byte Sum aggregate function.
|
SumAggFunction.DecimalSumAggFunction |
Built-in Decimal Sum aggregate function.
|
SumAggFunction.DoubleSumAggFunction |
Built-in Double Sum aggregate function.
|
SumAggFunction.FloatSumAggFunction |
Built-in Float Sum aggregate function.
|
SumAggFunction.IntSumAggFunction |
Built-in Int Sum aggregate function.
|
SumAggFunction.LongSumAggFunction |
Built-in Long Sum aggregate function.
|
SumAggFunction.ShortSumAggFunction |
Built-in Short Sum aggregate function.
|
SumAggregator<T> |
|
SumFunction |
Internal function for summing up contents of fields.
|
SumWithRetractAggFunction |
built-in sum aggregate function with retraction.
|
SumWithRetractAggFunction.ByteSumWithRetractAggFunction |
Built-in Byte Sum with retract aggregate function.
|
SumWithRetractAggFunction.DecimalSumWithRetractAggFunction |
Built-in Decimal Sum with retract aggregate function.
|
SumWithRetractAggFunction.DoubleSumWithRetractAggFunction |
Built-in Double Sum with retract aggregate function.
|
SumWithRetractAggFunction.FloatSumWithRetractAggFunction |
Built-in Float Sum with retract aggregate function.
|
SumWithRetractAggFunction.IntSumWithRetractAggFunction |
Built-in Int Sum with retract aggregate function.
|
SumWithRetractAggFunction.LongSumWithRetractAggFunction |
Built-in Long Sum with retract aggregate function.
|
SumWithRetractAggFunction.ShortSumWithRetractAggFunction |
Built-in Short Sum with retract aggregate function.
|
SuperstepBarrier |
A resettable one-shot latch.
|
SuperstepKickoffLatch |
Latch used to wait for the previous superstep to complete.
|
SuperstepKickoffLatchBroker |
|
SupplierWithException<R,E extends Throwable> |
A functional interface for a Supplier that may throw exceptions.
|
SupportsAggregatePushDown |
|
SupportsBatchSnapshot |
|
SupportsBucketing |
|
SupportsCommitter<CommittableT> |
A mixin interface for a Sink which supports exactly-once semantics using a two-phase
commit protocol.
|
SupportsConcurrentExecutionAttempts |
The interface indicates that it supports multiple attempts executing at the same time.
|
SupportsDeletePushDown |
Enables to push down filters decomposed from the WHERE clause in delete statement to
DynamicTableSink .
|
SupportsDynamicFiltering |
Pushes dynamic filter into ScanTableSource , the table source can filter the partitions
even the input data in runtime to reduce scan I/O.
|
SupportsFilterPushDown |
|
SupportsFilterPushDown.Result |
Result of a filter push down.
|
SupportsHandleExecutionAttemptSourceEvent |
|
SupportsIntermediateNoMoreSplits |
|
SupportsLimitPushDown |
Enables to push down a limit (the expected maximum number of produced records) into a ScanTableSource .
|
SupportsOverwrite |
|
SupportsPartitioning |
|
SupportsPartitionPushDown |
Enables to pass available partitions to the planner and push down partitions into a ScanTableSource .
|
SupportsPostCommitTopology<CommittableT> |
Allows expert users to implement a custom topology after Committer .
|
SupportsPreCommitTopology<WriterResultT,CommittableT> |
|
SupportsPreWriteTopology<InputT> |
Allows expert users to implement a custom topology before SinkWriter .
|
SupportsProjectionPushDown |
Enables to push down a (possibly nested) projection into a ScanTableSource .
|
SupportsReadingMetadata |
|
SupportsRowLevelDelete |
Interface for DynamicTableSink s that support delete existing data according to row-level
changes.
|
SupportsRowLevelDelete.RowLevelDeleteInfo |
The information that guides the planner on how to rewrite the delete statement.
|
SupportsRowLevelDelete.RowLevelDeleteMode |
Type of delete modes that the sink expects for delete purpose.
|
SupportsRowLevelModificationScan |
|
SupportsRowLevelModificationScan.RowLevelModificationType |
Type of the row-level modification for table.
|
SupportsRowLevelUpdate |
Interface for DynamicTableSink s that support update existing data according to row-level
changes.
|
SupportsRowLevelUpdate.RowLevelUpdateInfo |
The information that guides the planner on how to rewrite the update statement.
|
SupportsRowLevelUpdate.RowLevelUpdateMode |
Type of update modes that the sink expects for update purpose.
|
SupportsSourceWatermark |
Enables to fully rely on the watermark strategy provided by the ScanTableSource itself.
|
SupportsStaging |
Interface for DynamicTableSink s that support atomic semantic for CTAS(CREATE TABLE AS
SELECT) or RTAS([CREATE OR] REPLACE TABLE AS SELECT) statement using a two-phase commit protocol.
|
SupportsStaging.StagingContext |
The context is intended to tell DynamicTableSink the type of this operation.
|
SupportsStaging.StagingPurpose |
The type of operation the staging sink is for.
|
SupportsStatisticReport |
|
SupportsTruncate |
Enables to delete all existing data in a DynamicTableSink table using TRUNCATE
TABLE statement.
|
SupportsWatermarkPushDown |
|
SupportsWriterState<InputT,WriterStateT> |
|
SupportsWriterState.WithCompatibleState |
A mix-in for SupportsWriterState that allows users to migrate from a sink with a
compatible state to this sink.
|
SupportsWritingMetadata |
|
SuppressRestartsException |
Exception thrown in order to suppress job restarts.
|
SuspendEmbeddedSchedulerWorkflowHandler |
Handler to suspend workflow in embedded scheduler.
|
SuspendEmbeddedSchedulerWorkflowHeaders |
Message headers for suspend workflow in embedded scheduler.
|
SuspendRefreshWorkflow<T extends RefreshHandler> |
|
SwitchSourceEvent |
|
SymbolArgumentTypeStrategy<T extends Enum<? extends TableSymbol>> |
Strategy for a symbol argument of a specific TableSymbol enum.
|
SymbolType<T extends TableSymbol> |
Logical type for representing symbol values.
|
SymbolUtil |
Utilities to map between symbols from both Calcite and Flink.
|
SymbolUtil.SerializableSymbol |
Serializable representation of a symbol that can be used for persistence.
|
SyncEventHandler |
Listener for WorkerDoneEvent which also aggregates all aggregators from iteration tasks
and signals the end of the superstep.
|
SynchronousBufferFileReader |
|
SynchronousChainedCombineDriver<IN,OUT> |
The chained variant of the combine driver which is also implemented in GroupReduceCombineDriver.
|
SynchronousFileIOChannel |
A base class for synchronous readers and writers.
|
SyncIteratorWrapper<T> |
|
SyncPreferredLocationsRetriever |
Component to retrieve the preferred locations of an execution vertex.
|
SyntaxHighlightStyle |
|
SyntaxHighlightStyle.BuiltInStyle |
Pre-defined highlight styles.
|
SystemClock |
A clock that returns the time of the system / process.
|
SystemOutRedirectionUtils |
|
SystemProcessingTimeService |
|
SystemResourcesCounter |
Daemon thread probing system resources.
|
SystemResourcesMetricsInitializer |
Utility class to initialize system resource metrics.
|
Table |
The Table object is the core abstraction of the Table API.
|
TableAggregateFunction<T,ACC> |
Base class for a user-defined table aggregate function.
|
TableAggregateFunction.RetractableCollector<T> |
Collects a record and forwards it.
|
TableAggregateFunctionDefinition |
Deprecated.
|
TableAggregateWindowOperator<K,W extends Window> |
|
TableAggsHandleFunction |
The base class for handling table aggregate functions.
|
TableAlreadyExistException |
Exception for trying to create a table (or view) that already exists.
|
TableApiRules |
Rules for Table API.
|
TableauStyle |
Print the result and content as tableau form.
|
TableChange |
|
TableChange.AddColumn |
A table change to add a column.
|
TableChange.AddDistribution |
A table change to add a distribution.
|
TableChange.AddUniqueConstraint |
A table change to add a unique constraint.
|
TableChange.AddWatermark |
A table change to add a watermark.
|
TableChange.After |
Column position AFTER means the specified column should be put after the given `column`.
|
TableChange.ColumnPosition |
The position of the modified or added column.
|
TableChange.DropColumn |
A table change to drop the column.
|
TableChange.DropConstraint |
A table change to drop the constraints.
|
TableChange.DropDistribution |
A table change to drop a table's distribution.
|
TableChange.DropWatermark |
A table change to drop the watermark.
|
TableChange.First |
Column position FIRST means the specified column should be the first column.
|
TableChange.MaterializedTableChange |
|
TableChange.ModifyColumn |
A base schema change to modify a column.
|
TableChange.ModifyColumnComment |
A table change to modify the column comment.
|
TableChange.ModifyColumnName |
A table change to modify the column name.
|
TableChange.ModifyColumnPosition |
A table change to modify the column position.
|
TableChange.ModifyDistribution |
A table change to modify a distribution.
|
TableChange.ModifyPhysicalColumnType |
A table change that modify the physical column data type.
|
TableChange.ModifyRefreshHandler |
A table change to modify materialized table refresh handler.
|
TableChange.ModifyRefreshStatus |
A table change to modify materialized table refresh status.
|
TableChange.ModifyUniqueConstraint |
A table change to modify a unique constraint.
|
TableChange.ModifyWatermark |
A table change to modify the watermark.
|
TableChange.ResetOption |
A table change to reset the table option.
|
TableChange.SetOption |
A table change to set the table option.
|
TableColumn |
Deprecated.
|
TableColumn.ComputedColumn |
Representation of a computed column.
|
TableColumn.MetadataColumn |
Representation of a metadata column.
|
TableColumn.PhysicalColumn |
Representation of a physical column.
|
TableConfig |
Configuration for the current TableEnvironment session to adjust Table & SQL API
programs.
|
TableConfigOptions |
|
TableConfigOptions.CatalogPlanCompilation |
Strategy to compile Catalog objects into a plan.
|
TableConfigOptions.CatalogPlanRestore |
Strategy to restore Catalog objects using the plan and lookups if necessary.
|
TableConfigOptions.ColumnExpansionStrategy |
Strategy to expand columns in SELECT * queries.
|
TableConfigUtils |
Utility class for TableConfig related helper functions.
|
TableConfigValidation |
|
TableConnectorUtils |
Utilities for table sources and sinks.
|
TableDescriptor |
|
TableDescriptor.Builder |
|
TableDistribution |
Defines whether the given table is distributed across buckets using a specified algorithm and
given columns.
|
TableDistribution.Kind |
Distribution kind.
|
TableEnvironment |
A table environment is the base class, entry point, and central context for creating Table and
SQL API programs.
|
TableEnvironmentImpl |
Implementation of TableEnvironment that works exclusively with Table API interfaces.
|
TableEnvironmentInternal |
|
TableException |
General Exception for all errors during table handling.
|
TableFactory |
Deprecated.
|
TableFactoryService |
Deprecated. |
TableFactoryUtil |
|
TableFunction<T> |
Base class for a user-defined table function.
|
TableFunctionCollector<T> |
|
TableFunctionDefinition |
Deprecated.
|
TableFunctionProvider<T> |
Deprecated.
|
TableFunctionResultFuture<T> |
The basic implementation of collector for ResultFuture in table joining.
|
TableImpl |
Implementation for Table .
|
TableInfo |
Information of the table or view.
|
TableLineageDataset |
Basic table lineage dataset which has catalog context and table in it.
|
TableLineageDatasetImpl |
Implementation for TableLineageDataSet.
|
TableLineageUtils |
Util class for building table lineage graph.
|
TableMetaStoreFactory |
|
TableMetaStoreFactory.TableMetaStore |
Meta store to manage the location paths of this table and its partitions.
|
TableModificationEvent |
Base table event, provides column list, primary keys, partition keys, watermarks and properties
in CatalogBaseTable.
|
TableNotExistException |
Exception for an operation on a nonexistent table.
|
TableNotExistException |
Exception for trying to operate on a table (or view) that doesn't exist.
|
TableNotPartitionedException |
Exception for trying to operate partition on a non-partitioned table.
|
TableOperatorWrapper<OP extends StreamOperator<RowData>> |
This class handles the close, endInput and other related logic of a StreamOperator .
|
TableOperatorWrapper.Edge |
|
TableOperatorWrapperGenerator |
|
TableOptionsUtils |
Interface for handling specific set of table options.
|
TablePartitionedException |
Exception for trying to operate non-partitioned on a partitioned table.
|
TablePipeline |
Describes a complete pipeline from one or more source tables to a sink table.
|
TableReferenceExpression |
Expression that references another table.
|
TableReferenceLookup |
Provides a way to look up table reference by the name of the table.
|
TableResult |
A TableResult is the representation of the statement execution result.
|
TableResultImpl |
|
TableResultImpl.Builder |
|
TableResultInternal |
Internal interface with internal methods for TableResult .
|
TableResultUtils |
|
TableRuntimeException |
Exception for errors occurring in the runtime.
|
TableSchema |
Deprecated.
|
TableSchema.Builder |
|
TableSchemaUtils |
|
TableSink<T> |
Deprecated.
|
TableSinkBase<T> |
Deprecated.
|
TableSinkExternalContext |
External context for table sinks.
|
TableSinkFactory<T> |
Deprecated.
|
TableSinkFactory.Context |
Context of table sink creation.
|
TableSinkFactoryContextImpl |
Deprecated. |
TableSinkLineageVertex |
Sink lineage vertex for table.
|
TableSinkLineageVertexImpl |
Implementation of TableSinkLineageVertex.
|
TableSource<T> |
Deprecated.
|
TableSourceExternalContext |
External context for table sources.
|
TableSourceFactory<T> |
Deprecated.
|
TableSourceFactory.Context |
Context of table source creation.
|
TableSourceFactoryContextImpl |
Deprecated. |
TableSourceLineageVertex |
Source lineage vertex for table.
|
TableSourceLineageVertexImpl |
Implementation of TableSourceLineageVertex.
|
TableSourceQueryOperation<T> |
|
TableSourceValidation |
|
TableStats |
Table statistics.
|
TableStreamOperator<OUT> |
Table operator to invoke close always.
|
TableSymbol |
The base interface for all table symbols.
|
TaggedOperatorSubtaskState |
|
Task |
The Task represents one execution of a parallel subtask on a TaskManager.
|
Task.NotifyCheckpointOperation |
Various operation of notify checkpoint.
|
TaskActions |
Actions which can be performed on a Task .
|
TaskBackPressureResponse |
Response to the task back pressure request rpc call.
|
TaskChangelogRegistry |
TM-side registry of StateObjects , each
representing one or more changelog segments.
|
TaskCheckpointMessageParameters |
Message parameters for subtask related checkpoint message.
|
TaskCheckpointStatisticDetailsHandler |
REST handler which serves checkpoint statistics for subtasks.
|
TaskCheckpointStatistics |
Checkpoint statistics for a single task.
|
TaskCheckpointStatisticsHeaders |
|
TaskCheckpointStatisticsWithSubtaskDetails |
Task checkpoint statistics which also includes information about the sub task checkpoint
statistics.
|
TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment |
Alignment information for a specific checkpoint at a given task.
|
TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration |
Duration of a checkpoint split up into its synchronous and asynchronous part.
|
TaskCheckpointStatisticsWithSubtaskDetails.Summary |
Summary of the checkpoint statistics for a given task.
|
TaskConfig |
Configuration class which stores all relevant parameters required to set up the Pact tasks.
|
TaskContext<S,OT> |
The task context gives a driver (e.g., MapDriver , or JoinDriver ) access to the
runtime components and configuration that they can use to fulfil their task.
|
TaskDeploymentDescriptor |
A task deployment descriptor contains all the information necessary to deploy a task on a task
manager.
|
TaskDeploymentDescriptor.MaybeOffloaded<T> |
Wrapper class for serialized values which may be offloaded to the BlobServer or not.
|
TaskDeploymentDescriptor.NonOffloaded<T> |
A serialized value that is not offloaded to the BlobServer .
|
TaskDeploymentDescriptor.Offloaded<T> |
Reference to a serialized value that was offloaded to the BlobServer .
|
TaskDeploymentDescriptorFactory |
|
TaskDeploymentDescriptorFactory.PartitionLocationConstraint |
Defines whether the partition's location must be known at deployment time or can be unknown
and, therefore, updated later.
|
TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex |
|
TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup |
A set of shuffle descriptors that will be serialized together.
|
TaskEvent |
Subclasses of this event are recognized as custom events that are not part of the core flink
runtime.
|
TaskEventDispatcher |
The task event dispatcher dispatches events flowing backwards from a consuming task to the task
producing the consumed result.
|
TaskEventHandler |
The event handler manages EventListener instances and allows to publish events to them.
|
TaskEventPublisher |
The task event publisher is used for publishing the event to the registered EventListener
instances.
|
TaskException |
Exception indicating a task related problem on the TaskExecutor .
|
TaskExecutionState |
This class represents an update about a task's execution state.
|
TaskExecutionStateTransition |
|
TaskExecutor |
TaskExecutor implementation.
|
TaskExecutorBlobService |
|
TaskExecutorChannelStateExecutorFactoryManager |
|
TaskExecutorClusterPartitionReleaser |
Interface for releasing cluster partitions on a task executor.
|
TaskExecutorConnection |
This class is responsible for grouping the TaskExecutorGateway and the InstanceID of a registered
task executor.
|
TaskExecutorFileMergingManager |
|
TaskExecutorFlinkMemory |
Flink internal memory components of Task Executor.
|
TaskExecutorFlinkMemoryUtils |
|
TaskExecutorGateway |
|
TaskExecutorGatewayDecoratorBase |
|
TaskExecutorHeartbeatPayload |
Payload for heartbeats sent from the TaskExecutor to the ResourceManager.
|
TaskExecutorLocalStateStoresManager |
|
TaskExecutorMemoryConfiguration |
TaskExecutorConfiguration collects the configuration of a TaskExecutor instance.
|
TaskExecutorOperatorEventGateway |
The gateway through which the OperatorCoordinator can send an event to an Operator on the
Task Manager side.
|
TaskExecutorPartitionInfo |
Encapsulates meta-information the TaskExecutor requires to be kept for each partition.
|
TaskExecutorPartitionTracker |
Utility for tracking partitions.
|
TaskExecutorPartitionTrackerImpl |
Utility for tracking partitions and issuing release calls to task executors and shuffle masters.
|
TaskExecutorProcessSpec |
Describe the specifics of different resource dimensions of the TaskExecutor process.
|
TaskExecutorProcessSpecBuilder |
|
TaskExecutorProcessSpecContainerResourcePriorityAdapter |
|
TaskExecutorProcessUtils |
Utility class for TaskExecutor memory configurations.
|
TaskExecutorRegistration |
Information provided by the TaskExecutor when it registers to the ResourceManager.
|
TaskExecutorRegistrationRejection |
|
TaskExecutorRegistrationSuccess |
Base class for responses from the ResourceManager to a registration attempt by a TaskExecutor.
|
TaskExecutorResourceSpec |
|
TaskExecutorResourceUtils |
|
TaskExecutorStateChangelogStoragesManager |
|
TaskExecutorThreadInfoGateway |
|
TaskExecutorToJobManagerHeartbeatPayload |
Payload for heartbeats sent from the TaskExecutor to the JobManager.
|
TaskExecutorToResourceManagerConnection |
The connection between a TaskExecutor and the ResourceManager.
|
TaskExecutorToServiceAdapter |
|
TaskInfo |
The TaskInfo represents the meta information of current task.
|
TaskInfo |
TaskInfo contains all the meta information of the task.
|
TaskInfoImpl |
|
TaskInformation |
Container class for operator/task specific information which are stored at the ExecutionJobVertex .
|
TaskInputsOutputsDescriptor |
Describes inputs and outputs information of a task.
|
TaskInvokable |
An invokable part of the task.
|
TaskIOMetricGroup |
Metric group that contains shareable pre-defined IO-related metrics.
|
TaskIOMetricGroup.SizeSupplier<R> |
Supplier for sizes.
|
TaskKvStateRegistry |
A helper for KvState registrations of a single task.
|
TaskLocalStateStore |
Classes that implement this interface serve as a task-manager-level local storage for local
checkpointed state.
|
TaskLocalStateStoreImpl |
|
TaskMailbox |
A task mailbox provides read and write access to a mailbox and has a lifecycle of open ->
(quiesced) -> closed.
|
TaskMailbox.MailboxClosedException |
|
TaskMailbox.State |
This enum represents the states of the mailbox lifecycle.
|
TaskMailboxImpl |
Implementation of TaskMailbox in a BlockingQueue fashion and
tailored towards our use case with multiple writers and single reader.
|
TaskManagerActions |
|
TaskManagerConfiguration |
|
TaskManagerCustomLogHandler |
Rest handler which serves the custom file of the TaskExecutor .
|
TaskManagerCustomLogHeaders |
|
TaskManagerDetailsHandler |
Handler which serves detailed TaskManager information.
|
TaskManagerDetailsHeaders |
|
TaskManagerDetailsInfo |
Message containing base information about a TaskExecutor and more detailed metrics.
|
TaskManagerException |
|
TaskManagerExceptionUtils |
Exception utils to handle and enrich exceptions occurring in TaskManager.
|
TaskManagerFileMessageParameters |
|
TaskManagerGateway |
Task manager gateway interface to communicate with the task manager.
|
TaskManagerIdPathParameter |
TaskManager id path parameter used by TaskManager related handlers.
|
TaskManagerInfo |
|
TaskManagerInfo |
|
TaskManagerInfoWithSlots |
Contains the base information about a TaskExecutor and its allocated slots.
|
TaskManagerJobMetricGroup |
Special MetricGroup representing everything belonging to a
specific job, running on the TaskManager.
|
TaskManagerJobScopeFormat |
|
TaskManagerLocation |
This class encapsulates the connection information of a TaskManager.
|
TaskManagerLocation.DefaultHostNameSupplier |
This Supplier class could retrieve the FQDN host name of the given InetAddress on demand,
extract the pure host name and cache the results for later use.
|
TaskManagerLocation.HostNameSupplier |
|
TaskManagerLocation.IpOnlyHostNameSupplier |
This Supplier class returns the IP address of the given InetAddress directly, therefore no
reverse DNS lookup is required.
|
TaskManagerLocation.ResolutionMode |
The DNS resolution mode for TaskManager's IP address.
|
TaskManagerLogFileHandler |
|
TaskManagerLogFileHeaders |
|
TaskManagerLogListHandler |
Handler which serves detailed TaskManager log list information.
|
TaskManagerLogsHeaders |
|
TaskManagerLogUrlHeaders |
Headers for the log url retriever of TaskManager.
|
TaskManagerMessageParameters |
Message parameter for a TaskManager specific handler.
|
TaskManagerMetricGroup |
|
TaskManagerMetricsHandler |
Handler that returns TaskManager metrics.
|
TaskManagerMetricsHeaders |
|
TaskManagerMetricsInfo |
Contains information about the TaskManager metrics.
|
TaskManagerMetricsInfo.GarbageCollectorInfo |
Information about the garbage collector metrics.
|
TaskManagerMetricsMessageParameters |
|
TaskManagerOptions |
The set of configuration options relating to TaskManager and Task settings.
|
TaskManagerOptions.SystemOutMode |
|
TaskManagerOptions.TaskManagerLoadBalanceMode |
|
TaskManagerOptionsInternal |
TaskManager options that are not meant to be used by the user.
|
TaskManagerProfilingFileHandler |
Rest handler which serves the profiling result file of the TaskExecutor .
|
TaskManagerProfilingFileHeaders |
|
TaskManagerProfilingFileMessageParameters |
|
TaskManagerProfilingHandler |
Rest handler which serves the profiling service from a TaskExecutor .
|
TaskManagerProfilingHeaders |
|
TaskManagerProfilingListHandler |
Handler which serves detailed TaskManager profiling list information.
|
TaskManagerProfilingListHeaders |
|
TaskManagerRegistrationInformation |
DTO for TaskManager registration information.
|
TaskManagerRunner |
This class is the executable entry point for the task manager in yarn or standalone mode.
|
TaskManagerRunner.Result |
|
TaskManagerRunner.TaskExecutorService |
|
TaskManagerRunner.TaskExecutorServiceFactory |
|
TaskManagerRuntimeInfo |
|
TaskManagerScopeFormat |
|
TaskManagerServices |
|
TaskManagerServicesConfiguration |
Configuration for the task manager services such as the memory manager, the io manager and the
metric registry.
|
TaskManagersFilterQueryParameter |
|
TaskManagersHandler |
Returns an overview over all registered TaskManagers of the cluster.
|
TaskManagersHeaders |
|
TaskManagersInfo |
|
TaskManagerSlotInformation |
Basic information about a TaskManager slot.
|
TaskManagerStdoutFileHandler |
Rest handler which serves the stdout file of the TaskExecutor .
|
TaskManagerStdoutFileHeaders |
|
TaskManagerThreadDumpHandler |
Rest handler which serves the thread dump info from a TaskExecutor .
|
TaskManagerThreadDumpHeaders |
|
TaskMetricGroup |
|
TaskNotRunningException |
An exception indicating that a target task is not running.
|
TaskOperatorEventGateway |
|
TaskScopeFormat |
|
TaskSlot<T extends TaskSlotPayload> |
Container for multiple tasks belonging to the same slot.
|
TaskSlotPayload |
|
TaskSlotTable<T extends TaskSlotPayload> |
Container for multiple TaskSlot instances.
|
TaskSlotTableImpl<T extends TaskSlotPayload> |
|
TaskState |
Deprecated.
|
TaskStateManager |
This interface provides methods to report and retrieve state for a task.
|
TaskStateManagerImpl |
|
TaskStateSnapshot |
This class encapsulates state handles to the snapshots of all operator instances executed within
one task.
|
TaskStateStats |
Statistics for a single task/operator that gathers all statistics of its subtasks and provides
summary statistics about all subtasks.
|
TaskStateStats.TaskStateStatsSummary |
Summary of the subtask stats of a single task/operator.
|
TaskStatsRequestCoordinator<T,V> |
Encapsulates the common functionality for requesting statistics from tasks and combining their
responses.
|
TaskStatsRequestCoordinator.PendingStatsRequest<T,V> |
A pending task stats request, which collects samples from individual tasks and completes the
response future upon gathering all of of them.
|
TaskSubmissionException |
|
TaskThreadInfoResponse |
Response to the request to collect thread details samples.
|
TaskTracker |
Track the upstream tasks to determine whether all the upstream data of a checkpoint has been
received.
|
TempBarrier<T> |
This class facilitates JVM-local exchange between stages of a batch job.
|
TempDirUtils |
The utils contains some methods same as org.junit.rules.TemporaryFolder in Junit4.
|
TemporalJoinRewriteWithUniqueKeyRule |
Planner rule that rewrites temporal join with extracted primary key, Event-time temporal table
join requires primary key and row time attribute of versioned table.
|
TemporalJoinRewriteWithUniqueKeyRule.TemporalJoinRewriteWithUniqueKeyRuleConfig |
Rule configuration.
|
TemporalJoinSQLExample |
Example for demonstrating the use of temporal join between a table backed by a DataStream
and a table backed by a change log stream.
|
TemporalJoinSQLExample.EnrichedTransaction |
Enriched transaction by joining with the currency rate table.
|
TemporalJoinSQLExample.Transaction |
A simple class to represent a transaction.
|
TemporalProcessTimeJoinOperator |
The operator to temporal join a stream on processing time.
|
TemporalRowTimeJoinOperator |
The operator for temporal join (FOR SYSTEM_TIME AS OF o.rowtime) on row time, it has no
limitation about message types of the left input and right input, this means the operator deals
changelog well.
|
TemporalTableFunction |
Class representing temporal table function over some history table.
|
TemporalTableFunctionImpl |
Class representing temporal table function over some history table.
|
TemporalTableJoinUtil |
Utility for temporal table join which will gradually replace the scala class TemporalJoinUtil .
|
TemporalTableSourceSpec |
TemporalTableSpec describes how the right tale of lookupJoin ser/des.
|
TemporaryClassLoaderContext |
Sets a context class loader in a "try-with-resources" pattern.
|
TemporaryOperationListener |
This interface is for a Catalog to listen on temporary object operations.
|
Terminable |
Models the functionality that the termination of an iterative task can be requested from outside.
|
TerminalUtils |
Utilities for terminal handling.
|
TerminalUtils.MockOutputStream |
|
TerminationEvent |
Signals that the iteration is completely executed, participating tasks must terminate now.
|
TerminationModeQueryParameter |
Termination mode query parameter.
|
TerminationModeQueryParameter.TerminationMode |
Termination mode.
|
TernaryBoolean |
A ternary boolean, which can have the values 'true', 'false', or 'undefined'.
|
TestableKeyedStateBackend<K> |
A keyed state backend interface for internal testing purpose.
|
TestBaseUtils |
Utility class containing various methods for testing purposes.
|
TestBaseUtils.TupleComparator<T extends Tuple> |
Comparator for comparable Tuples.
|
TestCaseInvocationContextProvider |
A helper class for injecting test resources into test case as parameters.
|
TestCodeArchitectureTestBase |
Central setup of architectural tests for the test code.
|
TestContainerExtension<T extends org.testcontainers.containers.GenericContainer<T>> |
TestContainerExtension provides common functionality for TestContainer
implementations.
|
TestcontainersSettings |
The configuration holder for Testcontainers.
|
TestcontainersSettings.Builder |
The TestContainersSettings builder.
|
TestContext |
|
TestEnv |
|
TestEnvironment |
Test environment for running Flink jobs.
|
TestEnvironment.Endpoint |
Endpoint with address and port of the test environment.
|
TestEnvironmentSettings |
|
TestEnvironmentSettings.Builder |
|
TestExecutorExtension<T extends ExecutorService> |
|
TestExecutorResource<T extends ExecutorService> |
|
TestExternalSystem |
Marks the field in test class defining external system.
|
TestFileSystemCatalog |
|
TestFileSystemCatalog.FileSystemTableInfo |
The pojo class represents serializable catalog base table info.
|
TestFileSystemCatalogFactory |
|
TestFileSystemTableFactory |
|
TestingDeserializationContext |
|
TestingJobInfo |
|
TestingJobInfo.Builder |
|
TestingReaderContext |
|
TestingReaderOutput<E> |
A ReaderOutput for testing that collects the emitted records.
|
TestingSecurityContext |
Test security context to support handling both client and server principals in MiniKDC.
|
TestingSinkSettings |
Settings for configuring the sink under testing.
|
TestingSinkSettings.Builder |
|
TestingSourceSettings |
Settings for configuring the source under testing.
|
TestingSourceSettings.Builder |
|
TestingSplitEnumeratorContext<SplitT extends SourceSplit> |
A test implementation of the SplitEnumeratorContext , with manual, non-concurrent
interaction and intercepting of state.
|
TestingSplitEnumeratorContext.SplitAssignmentState<SplitT extends SourceSplit> |
The state of the split assignment for a subtask.
|
TestingTaskInfo |
|
TestingTaskInfo.Builder |
|
TestListResultSink<T> |
Thread-safe sink for collecting elements into an on-heap list.
|
TestListWrapper |
|
TestLogger |
Adds automatic test name logging.
|
TestLoggerExtension |
A JUnit-5-style test logger.
|
TestLoggerResource |
Utility for auditing logged messages.
|
TestLoggerResource.SingleTestResource |
SingleTestResource re-uses the code in TestLoggerResource for try-with-resources
statement.
|
TestNameProvider |
A rule that provides the current test name per thread.
|
TestOperatorEnum |
|
TestProcessBuilder |
Utility class wrapping ProcessBuilder and pre-configuring it with common options.
|
TestProcessBuilder.TestProcess |
|
TestResource |
|
TestScanTableSourceWithWatermarkPushDown |
|
TestScanTableSourceWithWatermarkPushDownFactory |
|
TestSemantics |
|
TestSignalHandler |
This signal handler / signal logger is based on Apache Hadoop's
org.apache.hadoop.util.SignalLogger.
|
TestSourceFunction |
A source function used to test.
|
TestStreamEnvironment |
|
TestUserClassLoaderAdditionalArtifact |
This class is used to test classloading from additional user artifacts.
|
TestUserClassLoaderJob |
This class can used to test situation that the jar is not in the system classpath.
|
TestUtils |
Test utilities.
|
TestUtils |
General test utilities.
|
TextElement |
|
TextElement.TextStyle |
Styles that can be applied to TextElement e.g. code, bold etc.
|
TextInputFormat |
Deprecated.
|
TextLineInputFormat |
A reader format that text lines from a file.
|
TextLineInputFormat.Reader |
The actual reader for the TextLineInputFormat .
|
TextOutputFormat<T> |
Deprecated.
|
TextOutputFormat.TextFormatter<IN> |
Formatter that transforms values into their String representations.
|
ThreadDumpInfo |
Class containing thread dump information.
|
ThreadDumpInfo.ThreadInfo |
Class containing information about a thread.
|
ThreadInfoRequestCoordinator |
A coordinator for triggering and collecting thread info stats of running job vertex subtasks.
|
ThreadInfoSample |
A serializable wrapper container for transferring parts of the ThreadInfo .
|
ThreadInfoSamplesRequest |
A wrapper for parameters of a thread info sampling request.
|
ThreadLocalCache<K,V> |
Provides a thread local cache with a maximum cache size per thread.
|
ThreadLocalClassLoaderConfiguration |
Workaround for https://issues.apache.org/jira/browse/ORC-653.
|
ThreadSafeSimpleCounter |
A simple low-overhead Counter that is thread-safe.
|
ThreadUtils |
Utils for thread pool executor.
|
ThreadUtils |
ThreadUtils collects helper methods in the context of threading.
|
ThresholdMeter |
A timestamp queue based threshold meter.
|
ThresholdMeter.ThresholdExceedException |
Exception thrown when a threshold exceeds.
|
ThrottledIterator<T> |
A variant of the collection source (emits a sequence of elements as a stream) that supports
throttling the emission rate.
|
ThroughputCalculator |
Class for measuring the throughput based on incoming data size and measurement period.
|
ThrowableAnnotation |
Annotation to classify subclasses of Throwable into categories w.r.t. recovery.
|
ThrowableCatchingRunnable |
This class catches all the Throwables from the wrapped runnable.
|
ThrowableClassifier |
Helper class, given a exception do the classification.
|
ThrowableType |
Enum for the classification of Throwable objects into failure/recovery classes.
|
ThrowingConsumer<T,E extends Throwable> |
This interface is basically Java's Consumer interface enhanced with
the ability to throw an exception.
|
ThrowingExecutionPlanWriter |
|
ThrowingIterator<E> |
|
ThrowingRunnable<E extends Throwable> |
Similar to a Runnable , this interface is used to capture a block of code to be executed.
|
TierConsumerAgent |
The TierConsumerAgent is the consumer agent of each tier in tiered store, which could
read data from responding tier.
|
TieredInternalShuffleMaster |
A wrapper internal shuffle master class for tiered storage.
|
TieredResultPartition |
TieredResultPartition appends records and events to the tiered storage, which supports
the upstream dynamically switches storage tier for writing shuffle data, and the downstream will
read data from the relevant tier.
|
TieredResultPartitionFactory |
|
TieredStorageBytesBasedDataIdentifier |
The bytes based unique identification for the Tiered Storage.
|
TieredStorageConfiguration |
Configurations for the Tiered Storage.
|
TieredStorageConsumerClient |
|
TieredStorageConsumerSpec |
|
TieredStorageDataIdentifier |
Identifier interface in the Tiered Storage.
|
TieredStorageIdMappingUtils |
Utils to convert the Ids to Tiered Storage Ids, or vice versa.
|
TieredStorageInputChannelId |
Identifier of an InputChannel.
|
TieredStorageMasterClient |
Client of the Tiered Storage used by the master.
|
TieredStorageMemoryManager |
|
TieredStorageMemoryManagerImpl |
|
TieredStorageMemorySpec |
The memory specs for a memory owner, including the owner itself, the number of guaranteed buffers
of the memory owner, etc.
|
TieredStorageNettyService |
|
TieredStorageNettyServiceImpl |
|
TieredStoragePartitionId |
Identifier of a partition.
|
TieredStorageProducerClient |
Client of the Tiered Storage used by the producer.
|
TieredStorageProducerMetricUpdate |
The metric statistics for the tiered storage producer.
|
TieredStorageResource |
The resource (e.g., local files, remote storage files, etc.) for the Tiered Storage.
|
TieredStorageResourceRegistry |
A registry that maintains local or remote resources that correspond to a certain set of data in
the Tiered Storage.
|
TieredStorageResultSubpartitionView |
|
TieredStorageSortBuffer |
|
TieredStorageSubpartitionId |
Identifier of a subpartition.
|
TieredStorageTopicId |
Identifier of a topic.
|
TieredStorageUtils |
Utils for reading from or writing to tiered storage.
|
TierFactory |
A factory that creates all the components of a tier.
|
TierFactoryInitializer |
|
TierMasterAgent |
The master-side agent of a Tier.
|
TierProducerAgent |
The producer-side agent of a Tier.
|
TierShuffleDescriptor |
|
TierShuffleHandler |
A handler to process the call back result from each tier, the callbacks can be some events, some
errors, some exceptions, etc.
|
TimeAttributeWindowingStrategy |
A windowing strategy that gets windows by calculating on time attribute column.
|
TimeContext |
Enables access to time related characteristics such as current processing time or timestamp of
currently processed element.
|
TimedCacheReloadTrigger |
A trigger that reloads at a specific time and repeats for the given interval in days.
|
TimeDomain |
TimeDomain specifies whether a firing timer is based on event time or processing time.
|
TimedOutPartialMatchHandler<IN> |
Enables handling timed out partial matches.
|
TimeEvictor<W extends Window> |
An Evictor that keeps elements for a certain amount of time.
|
TimeFormats |
Time formats and timestamp formats respecting the RFC3339 specification, ISO-8601 specification
and SQL specification.
|
TimeIndicatorTypeInfo |
Deprecated.
|
TimeIntervalTypeInfo<T> |
Deprecated.
|
TimeIntervalUnit |
Units for working with time intervals.
|
TimeLocalTimeConverter |
|
TimeLongConverter |
|
TimeoutListener<K> |
|
TimePointUnit |
Units for working with points in time.
|
TimerException |
RuntimeException for wrapping exceptions that are thrown in the timer callback of the
timer service in StreamTask .
|
TimerGauge |
|
TimerGauge.StartStopListener |
|
TimerHandler |
Utilities to handle triggered timer.
|
TimerHeapInternalTimer<K,N> |
|
TimerRegistration |
Handles the interaction with the Python worker for registering and deleting timers.
|
TimerSerializer<K,N> |
A serializer for TimerHeapInternalTimer objects that produces a serialization format that
is lexicographically aligned the priority of the timers.
|
TimerSerializerSnapshot<K,N> |
|
TimerService |
|
TimerService<K> |
Service to register timeouts for a given key.
|
TimerService |
Interface for working with time and timers.
|
TimerService |
A common timer service interface with life cycle methods.
|
TimerUtils |
Utilities for timer.
|
TimeSerializer |
Uses int instead of long as the serialized value.
|
TimeSerializer.TimeSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
TimestampAssigner<T> |
A TimestampAssigner assigns event time timestamps to elements.
|
TimestampAssignerSupplier<T> |
|
TimestampAssignerSupplier.Context |
|
TimestampAssignerSupplier.SupplierFromSerializableTimestampAssigner<T> |
We need an actual class.
|
TimestampCollector<OUT> |
The base Collector which take care of records timestamp.
|
TimestampColumnReader |
|
TimestampColumnVector |
Timestamp column vector.
|
TimestampData |
|
TimestampDataSerializer |
|
TimestampDataSerializer.TimestampDataSerializerSnapshot |
|
TimestampDataTypeInfo |
|
TimestampedCollector<T> |
Wrapper around an Output for user functions that expect a Output .
|
TimestampedFileInputSplit |
|
TimestampedInputSplit |
An extended InputSplit that also includes information about:
The modification time of the file this split belongs to.
|
TimestampedValue<T> |
Stores the value and the timestamp of the record.
|
Timestamper<T> |
Assigns an event time timestamp to the given record.
|
TimestampExtractor |
Deprecated.
|
TimestampExtractorUtils |
|
TimestampFormat |
Timestamp format Enums.
|
TimestampKind |
Internal timestamp kind for attaching time attribute metadata to timestamps with or without a
time zone.
|
TimestampLocalDateTimeConverter |
|
TimestampsAndWatermarks<T> |
Basic interface for the timestamp extraction and watermark generation logic for the SourceReader .
|
TimestampsAndWatermarks.TimestampsAndWatermarksContextProvider |
|
TimestampsAndWatermarks.WatermarkUpdateListener |
Lets the owner/creator of the output know about latest emitted watermark.
|
TimestampsAndWatermarksContext |
|
TimestampsAndWatermarksOperator<T> |
A stream operator that may do one or both of the following: extract timestamps from events and
generate watermarks.
|
TimestampsAndWatermarksOperator.WatermarkEmitter |
Implementation of the WatermarkEmitter , based on the components that are available
inside a stream operator.
|
TimestampsAndWatermarksOperatorFactory<T> |
|
TimestampsAndWatermarksTransformation<IN> |
|
TimestampsAndWatermarksTransformationTranslator<IN> |
|
TimestampSchemaVersion |
The implementation of SchemaVersion to specify the snapshot at the specific time.
|
TimestampSerializer |
Uses similar serialization/deserialization of SqlTimestampSerializer to serialize Timestamp.
|
TimestampSerializer.TimestampSerializerSnapshot |
|
TimestampStringUtils |
Utility functions for calcite's TimestampString .
|
TimestampTimestampConverter |
|
TimestampType |
Logical type of a timestamp WITHOUT time zone consisting of year-month-day
hour:minute:second[.fractional] with up to nanosecond precision and values ranging from
0000-01-01 00:00:00.000000000 to 9999-12-31 23:59:59.999999999 .
|
TimestampUtil |
Util class to handle timestamp vectors.
|
TimestampWriter<T> |
|
TimestampWriter.TimestampWriterForArray |
|
TimestampWriter.TimestampWriterForRow |
|
TimeTimeConverter |
|
TimeToConsumeGauge |
Gauge metric measuring the maximal time to consume all buffers of all input gates.
|
TimeType |
Logical type of a time WITHOUT time zone consisting of hour:minute:second[.fractional]
with up to nanosecond precision and values ranging from 00:00:00.000000000 to
23:59:59.999999999 .
|
TimeUtils |
Collection of utilities about time intervals.
|
TimeWindow |
A Window that represents a time interval from start (inclusive) to end
(exclusive).
|
TimeWindow |
A Window that represents a time interval from start (inclusive) to end
(exclusive).
|
TimeWindow.Serializer |
The serializer used to write the TimeWindow type.
|
TimeWindow.Serializer |
The serializer used to write the TimeWindow type.
|
TimeWindow.Serializer.TimeWindowSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
TimeWindow.Serializer.TimeWindowSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
TimeWindowUtil |
Time util to deals window start and end in different timezone.
|
TimeWriter<T> |
|
TimeWriter.TimeWriterForArray |
|
TimeWriter.TimeWriterForRow |
|
TinyIntType |
Logical type of a 1-byte signed integer with values from -128 to 127.
|
TinyIntWriter<T> |
|
TinyIntWriter.TinyIntWriterForArray |
|
TinyIntWriter.TinyIntWriterForRow |
|
Token |
Describes the input token stream.
|
TokenMgrError |
|
TopNBuffer |
TopNBuffer stores mapping from sort key to records list, sortKey is RowData type, each record is
RowData type.
|
TopNBufferCacheRemovalListener<V> |
A common cache removal listener for rank node.
|
TopNRecordsCombiner |
An implementation of RecordsCombiner that save topN records of incremental input records
into the window state.
|
TopNRecordsCombiner.Factory |
|
Topology<VID extends VertexID,RID extends ResultID,V extends Vertex<VID,RID,V,R>,R extends Result<VID,RID,V,R>,PR extends PipelinedRegion<VID,RID,V,R>> |
|
TopSpeedWindowing |
An example of grouped stream windowing where different eviction and trigger policies can be used.
|
TopSpeedWindowingExampleData |
Data for TopSpeedWindowingExampleITCase.
|
ToTimestampLtzTypeStrategy |
Type strategy of TO_TIMESTAMP_LTZ .
|
TpcdsResultComparator |
Result comparator for TPC-DS test according to the TPC-DS standard specification v2.11.0.
|
TpcdsSchema |
Class to define table schema of TPS-DS table.
|
TpcdsSchemaProvider |
Class to provide all TPC-DS tables' schema information.
|
TpcdsStatsProvider |
Table statistics information for TPC-DS qualification test, TPC-DS tool version is v2.11.0.
|
TpcdsTestProgram |
End-to-end test for TPC-DS.
|
TpchDataGenerator |
TPC-H test data generator.
|
TpchResultComparator |
Result comparator for TPC-H test, according to the TPC-H standard specification v2.18.0.
|
TraceOptions |
Configuration options for traces and trace reporters.
|
TraceReporter |
Trace reporters are used to export Spans to an external backend.
|
TraceReporterFactory |
|
TraceReporterSetup |
Encapsulates everything needed for the instantiation and configuration of a TraceReporter .
|
Transaction |
A simple transaction.
|
TransactionRowInputFormat |
An bounded input of transactions.
|
TransactionSource |
Deprecated.
|
Transformation<T> |
A Transformation represents the operation that creates a DataStream.
|
TransformationMetadata |
This POJO is meant to hold some metadata information about operators, which usually needs to be
passed to "factory" methods for Transformation .
|
TransformationScanProvider |
|
TransformationSinkProvider |
|
TransformationSinkProvider.Context |
|
TransformationTranslator<OUT,T extends Transformation<OUT>> |
A TransformationTranslator is responsible for translating a given Transformation
to its runtime implementation depending on the execution mode.
|
TransformationTranslator.Context |
A context giving the necessary information for the translation of a given transformation.
|
TransformationWithLineage<T> |
|
TransientBlobCache |
Provides access to transient BLOB files stored at the BlobServer .
|
TransientBlobKey |
BLOB key referencing transient BLOB files.
|
TransientBlobService |
A service to retrieve transient binary large objects (BLOBs) which are deleted on the BlobServer when they are retrieved.
|
Transition |
A possible transition on a given event into a target state.
|
TransitiveClosureData |
Test data for TransitiveClosure programs.
|
TranslateFunction |
|
TransportException |
|
TraversableOnceException |
An exception, indicating that an Iterable can only be traversed once, but has
been attempted to traverse an additional time.
|
TraversableSerializerSnapshot<T extends scala.collection.TraversableOnce<E>,E> |
|
TravisDownloadCache |
Travis-specific DownloadCache implementation that caches downloaded files in a configured
directory.
|
TravisDownloadCacheFactory |
|
TreeOrderedSetCache |
Implementation of a lexicographically ordered set of byte-arrays, based on a TreeSet .
|
TreeOrderedSetCache |
Implementation of a lexicographically ordered set of byte-arrays, based on a TreeSet .
|
TriConsumer<S,T,U> |
Operation which is performed on three given arguments.
|
TriConsumerWithException<S,T,U,E extends Throwable> |
|
TriFunction<S,T,U,R> |
Function which takes three arguments.
|
TriFunctionWithException<S,T,U,R,E extends Throwable> |
Function which takes three arguments.
|
Trigger<T,W extends Window> |
A Trigger determines when a pane of a window should be evaluated to emit the results for
that part of the window.
|
Trigger<W extends Window> |
A Trigger determines when a pane of a window should be evaluated to emit the results for
that part of the window.
|
Trigger.OnMergeContext |
|
Trigger.OnMergeContext |
|
Trigger.TriggerContext |
A context object that is given to Trigger methods to allow them to register timer
callbacks and deal with state.
|
Trigger.TriggerContext |
A context object that is given to Trigger methods to allow them to register timer
callbacks and deal with state.
|
Triggerable<K,N> |
|
TriggerCheckpointFunction |
Wrapper interface for functions triggering checkpoints.
|
TriggerId |
Identifies a savepoint trigger request.
|
TriggerId.TriggerIdDeserializer |
|
TriggerId.TriggerIdSerializer |
|
TriggerIdPathParameter |
|
TriggerResponse |
Response to the triggering of an asynchronous operation.
|
TriggerResult |
Result type for trigger methods.
|
TriggerSavepointFunction |
Wrapper interface for functions triggering savepoints.
|
TriggerSavepointMode |
Describes the context of taking a savepoint: Whether it is a savepoint for a running job or
whether the job is cancelled, suspended or terminated with a savepoint.
|
TriggerSessionHeartbeatHandler |
Handler to touch the session.
|
TriggerSessionHeartbeatHeaders |
Message headers for touching the session.
|
TruncateTableOperation |
Operation to describe an TRUNCATE TABLE statement.
|
TtlAggregateFunction<IN,ACC,OUT> |
This class wraps aggregating function with TTL logic.
|
TtlAwareSerializer<T> |
|
TtlAwareSerializerSnapshot<T> |
|
TtlAwareSerializerSnapshotWrapper<T> |
|
TtlReduceFunction<T> |
This class wraps reducing function with TTL logic.
|
TtlStateContext<T,SV> |
|
TtlStateFactory<K,N,SV,TTLSV,S extends State,IS extends S> |
This state factory wraps state objects, produced by backends, with TTL logic.
|
TtlStateFactory<K,N,SV,TTLSV,S extends State,IS> |
|
TtlStateFactory.TtlSerializer<T> |
Serializer for user state value with TTL.
|
TtlStateFactory.TtlSerializer<T> |
Serializer for user state value with TTL.
|
TtlStateFactory.TtlSerializerSnapshot<T> |
|
TtlStateFactory.TtlSerializerSnapshot<T> |
|
TtlStateFactory.TtlTypeInformation<T> |
|
TtlStateVerifier<UV,GV> |
TTL state verifier interface.
|
TtlTimeProvider |
Provides time to TTL logic to judge about state expiration.
|
TtlUpdateContext<UV,GV> |
Contains context relevant for state update with TTL.
|
TtlUtils |
Common functions related to State TTL.
|
TtlValue<T> |
This class wraps user value of state with TTL.
|
TtlVerificationContext<UV,GV> |
Data to verify state update with TTL.
|
Tumble |
Helper class for creating a tumbling window.
|
TumbleWithSize |
Tumbling window.
|
TumbleWithSizeOnTime |
Tumbling window on time.
|
TumbleWithSizeOnTimeWithAlias |
Tumbling window on time with alias.
|
TumblingEventTimeWindows |
A WindowAssigner that windows elements into windows based on the timestamp of the
elements.
|
TumblingProcessingTimeWindows |
A WindowAssigner that windows elements into windows based on the current system time of
the machine the operation is running on.
|
TumblingWindowAssigner |
A GroupWindowAssigner that windows elements into fixed-size windows based on the
timestamp of the elements.
|
TumblingWindowSpec |
Logical representation of a tumbling window specification.
|
Tuple |
The base class of all tuples.
|
Tuple0 |
A tuple with 0 fields.
|
Tuple0Builder |
|
Tuple0Serializer |
|
Tuple0SerializerSnapshot |
|
Tuple1<T0> |
A tuple with 1 fields.
|
Tuple10<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9> |
A tuple with 10 fields.
|
Tuple10Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9> |
|
Tuple11<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> |
A tuple with 11 fields.
|
Tuple11Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> |
|
Tuple12<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> |
A tuple with 12 fields.
|
Tuple12Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> |
|
Tuple13<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> |
A tuple with 13 fields.
|
Tuple13Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> |
|
Tuple14<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> |
A tuple with 14 fields.
|
Tuple14Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> |
|
Tuple15<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> |
A tuple with 15 fields.
|
Tuple15Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> |
|
Tuple16<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> |
A tuple with 16 fields.
|
Tuple16Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> |
|
Tuple17<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> |
A tuple with 17 fields.
|
Tuple17Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> |
|
Tuple18<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> |
A tuple with 18 fields.
|
Tuple18Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> |
|
Tuple19<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> |
A tuple with 19 fields.
|
Tuple19Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> |
|
Tuple1Builder<T0> |
|
Tuple2<T0,T1> |
A tuple with 2 fields.
|
Tuple20<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> |
A tuple with 20 fields.
|
Tuple20Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> |
|
Tuple21<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> |
A tuple with 21 fields.
|
Tuple21Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> |
|
Tuple22<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> |
A tuple with 22 fields.
|
Tuple22Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> |
|
Tuple23<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> |
A tuple with 23 fields.
|
Tuple23Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> |
|
Tuple24<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23> |
A tuple with 24 fields.
|
Tuple24Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23> |
|
Tuple25<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24> |
A tuple with 25 fields.
|
Tuple25Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24> |
|
Tuple2Builder<T0,T1> |
|
Tuple2CaseClassSerializerSnapshot<T1,T2> |
|
Tuple3<T0,T1,T2> |
A tuple with 3 fields.
|
Tuple3Builder<T0,T1,T2> |
|
Tuple4<T0,T1,T2,T3> |
A tuple with 4 fields.
|
Tuple4Builder<T0,T1,T2,T3> |
|
Tuple5<T0,T1,T2,T3,T4> |
A tuple with 5 fields.
|
Tuple5Builder<T0,T1,T2,T3,T4> |
|
Tuple6<T0,T1,T2,T3,T4,T5> |
A tuple with 6 fields.
|
Tuple6Builder<T0,T1,T2,T3,T4,T5> |
|
Tuple7<T0,T1,T2,T3,T4,T5,T6> |
A tuple with 7 fields.
|
Tuple7Builder<T0,T1,T2,T3,T4,T5,T6> |
|
Tuple8<T0,T1,T2,T3,T4,T5,T6,T7> |
A tuple with 8 fields.
|
Tuple8Builder<T0,T1,T2,T3,T4,T5,T6,T7> |
|
Tuple9<T0,T1,T2,T3,T4,T5,T6,T7,T8> |
A tuple with 9 fields.
|
Tuple9Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8> |
|
TupleComparator<T extends Tuple> |
|
TupleComparatorBase<T> |
|
TupleSerializer<T extends Tuple> |
|
TupleSerializerBase<T> |
|
TupleSerializerSnapshot<T extends Tuple> |
Snapshot of a tuple serializer's configuration.
|
TupleTypeInfo<T extends Tuple> |
|
TupleTypeInfoBase<T> |
|
TupleUnwrappingIterator<T,K> |
An iterator that reads 2-tuples (key value pairs) and returns only the values (second field).
|
TwoInputBroadcastProcessOperator<IN1,IN2,OUT> |
|
TwoInputBroadcastStreamProcessFunction<IN1,IN2,OUT> |
This contains all logical related to process records from a broadcast stream and a non-broadcast
stream.
|
TwoInputNonBroadcastProcessOperator<IN1,IN2,OUT> |
|
TwoInputNonBroadcastStreamProcessFunction<IN1,IN2,OUT> |
This contains all logical related to process records from two non-broadcast input.
|
TwoInputStreamOperator<IN1,IN2,OUT> |
Interface for stream operators with two inputs.
|
TwoInputStreamOperatorFactory<IN1,IN2,OUT> |
|
TwoInputStreamTask<IN1,IN2,OUT> |
|
TwoInputTransformation<IN1,IN2,OUT> |
|
TwoInputTransformationTranslator<IN1,IN2,OUT> |
|
TwoOutputApplyPartitionFunction<OUT1,OUT2> |
A function to be applied to all partitions with two outputs.
|
TwoOutputNonPartitionedContext<OUT1,OUT2> |
This interface represents the context associated with all operations must be applied to all
partitions with two outputs.
|
TwoOutputProcessOperator<IN,OUT_MAIN,OUT_SIDE> |
|
TwoOutputStreamProcessFunction<IN,OUT1,OUT2> |
This contains all logical related to process and emit records to two output streams.
|
TwoPhaseCommitSinkFunction<IN,TXN,CONTEXT> |
Deprecated.
|
TwoPhaseCommitSinkFunction.State<TXN,CONTEXT> |
State POJO class coupling pendingTransaction, context and pendingCommitTransactions.
|
TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT> |
|
TwoPhaseCommitSinkFunction.StateSerializerSnapshot<TXN,CONTEXT> |
|
TwoPhaseCommitSinkFunction.TransactionHolder<TXN> |
Adds metadata (currently only the start time of the transaction) to the transaction object.
|
TwoStageOptimizedAggregateRule |
Rule that matches StreamPhysicalGroupAggregate on StreamPhysicalExchange with the
following condition: 1. mini-batch is enabled in given TableConfig, 2. two-phase aggregation is
enabled in given TableConfig, 3. all aggregate functions are mergeable, 4. the input of exchange
does not satisfy the shuffle distribution,
|
TwoStageOptimizedAggregateRule.TwoStageOptimizedAggregateRuleConfig |
Rule configuration.
|
TwoStageOptimizedWindowAggregateRule |
Rule that matches StreamPhysicalWindowAggregate on StreamPhysicalExchange with
following condition:
the applied windowing is not on processing-time, because processing-time should be
materialized in a single node.
|
TypeCheckUtils |
Utils for type.
|
TypeComparable<T> |
Wrapper that is used to store elements for which we have a TypeComparator in a Hash Map.
|
TypeComparator<T> |
This interface describes the methods that are required for a data type to be handled by the pact
runtime.
|
TypeComparatorFactory<T> |
|
TypeConversions |
|
TypeDescriptor<T> |
Descriptor interface to create TypeInformation instances.
|
TypeDescriptors |
Descriptor interface to create TypeInformation instances.
|
TypedResult<P> |
Result with an attached type (actual payload, EOS, etc.).
|
TypedResult.ResultType |
Result types.
|
TypedSetters |
Provide type specialized setters to reduce if/else and eliminate box and unbox.
|
TypeExtractionException |
Type extraction always contains some uncertainty due to unpredictable JVM differences between
vendors or versions.
|
TypeExtractionUtils |
|
TypeExtractionUtils.LambdaExecutable |
Similar to a Java 8 Executable but with a return type.
|
TypeExtractor |
A utility for reflection analysis on classes, to determine the return type of implementations of
transformation functions.
|
TypeHint<T> |
A utility class for describing generic types.
|
TypeInference |
Provides logic for the type inference of function calls.
|
TypeInference.Builder |
|
TypeInferenceExtractor |
|
TypeInferenceOperandChecker |
|
TypeInferenceOperandInference |
|
TypeInferenceReturnInference |
|
TypeInferenceUtil |
Utility for performing type inference.
|
TypeInferenceUtil.Result |
The result of a type inference run.
|
TypeInferenceUtil.SurroundingInfo |
Information what the outer world (i.e. an outer wrapping call) expects from the current
function call.
|
TypeInfo |
|
TypeInfoDataTypeConverter |
Deprecated.
|
TypeInfoDataTypeConverter |
|
TypeInfoFactory<T> |
Base class for implementing a type information factory.
|
TypeInfoLogicalTypeConverter |
Deprecated. |
TypeInformation<T> |
TypeInformation is the core class of Flink's type system.
|
TypeInformationRawType<T> |
Deprecated.
|
TypeInformationSerializationSchema<T> |
A serialization and deserialization schema that uses Flink's serialization stack to transform
typed from and to byte arrays.
|
TypeLiteralArgumentTypeStrategy |
Strategy that checks if an argument is a type literal.
|
TypeLiteralExpression |
Expression that wraps DataType as a literal.
|
TypeMappingUtils |
|
TypeOfFunction |
|
TypePairComparator<T1,T2> |
This interface defines the method required by the runtime to use data types in join-like
operations.
|
TypePairComparatorFactory<T1,T2> |
|
Types |
This class gives access to the type information of the most common types for which Flink has
built-in serializers and comparators.
|
Types |
Deprecated.
|
TypeSerializer<T> |
This interface describes the methods that are required for a data type to be handled by the Flink
runtime.
|
TypeSerializerFactory<T> |
|
TypeSerializerSchemaCompatibility<T> |
A TypeSerializerSchemaCompatibility represents information about whether or not a TypeSerializer can be safely used to read data written by a previous type serializer.
|
TypeSerializerSingleton<T> |
|
TypeSerializerSnapshot<T> |
A TypeSerializerSnapshot is a point-in-time view of a TypeSerializer 's
configuration.
|
TypeSerializerSnapshotSerializationUtil |
|
TypeSerializerUtils |
|
TypeStrategies |
Strategies for inferring an output or accumulator data type of a function call.
|
TypeStrategy |
Strategy for inferring a function call's result data type.
|
TypeStringUtils |
Deprecated.
|
TypeTransformation |
Transforms one data type to another.
|
TypeTransformations |
Transformations for transforming one data type to another.
|
TypeUtils |
Utility class to create objects via reflection.
|
UdfStreamOperatorFactory<OUT> |
Udf stream operator factory.
|
UnalignedWindowTableFunctionOperator |
The operator for unaligned window table function.
|
UnaryOperatorInformation<IN,OUT> |
A class for holding information about a single input operator, such as input/output
TypeInformation.
|
UnavailableDispatcherOperationException |
Exception indicating that a Dispatcher operation is temporarily unavailable.
|
UnboundedFollowingOverFrame |
The UnboundedFollowing window frame.
|
UnboundedOverWindowFrame |
The unbounded window frame calculates frames with the following SQL forms: ...
|
UnboundedPrecedingOverFrame |
The UnboundedPreceding window frame.
|
UncheckpointedCollectResultBuffer<T> |
A buffer which encapsulates the logic of dealing with the response from the CollectSinkFunction .
|
UncollectToTableFunctionScanRule |
Planner rule that converts Uncollect values to TableFunctionScan .
|
UncollectToTableFunctionScanRule.UncollectToTableFunctionScanRuleConfig |
|
UncompressedStreamCompressionDecorator |
This implementation does not decorate the stream with any compression.
|
UnfulfillableSlotRequestException |
Exception denoting that a slot request can not be fulfilled by any slot in the cluster.
|
UnhexFunction |
|
Union<T> |
This operator represents a Union between two inputs.
|
UnionInputGate |
Input gate wrapper to union the input from multiple input gates.
|
UnionIterator<T> |
An iterator that concatenates a collection of iterators.
|
UnionResultSubpartitionView |
|
UnionStateInputFormat<OT> |
Input format for reading operator union state.
|
UnionStreamOperator |
|
UnionTransformation<T> |
|
UnionTransformationTranslator<OUT> |
|
UnionWithTempOperator<T> |
|
UniqueConstraint |
A unique key constraint.
|
UniqueConstraint |
Deprecated.
|
UnknownCallContext |
|
UnknownKeyOrNamespaceException |
Thrown if the KvState does not hold any state for the given key or namespace.
|
UnknownKvStateIdException |
Thrown if no KvState with the given ID cannot found by the server handler.
|
UnknownKvStateKeyGroupLocationException |
Exception thrown if there is no location information available for the given key group.
|
UnknownKvStateLocation |
Thrown if there is no KvStateLocation found for the requested registration name.
|
UnknownLocationException |
Exception to fail Future if the Task Manager on which the Client Proxy is running on,
does not know the location of a requested state.
|
UnknownMessageException |
Exception which indicates that the PekkoRpcActor has
received an unknown message type.
|
UnknownOperationKeyException |
Exception that indicates that there is no ongoing or completed savepoint for a given JobID and TriggerId pair.
|
UnknownShuffleDescriptor |
|
UnknownTaskExecutorException |
Exception denoting that a requested TaskExecutor could not be found.
|
UnknownTierShuffleDescriptor |
This is a placeholder when the tier shuffle descriptor should be unknown because the netty
shuffle descriptor is unknown.
|
UnloadableDummyTypeSerializer<T> |
|
UnloadModuleOperation |
Operation to describe an UNLOAD MODULE statement.
|
UnmodifiableConfiguration |
Unmodifiable version of the Configuration class.
|
UnnestRowsFunction |
Flattens ARRAY, MAP, and MULTISET using a table function.
|
UnnestRowsFunction.CollectionUnnestTableFunction |
Table function that unwraps the elements of a collection (array or multiset).
|
UnnestRowsFunction.MapUnnestTableFunction |
Table function that unwraps the elements of a map.
|
UnorderedCollectIteratorAssert<T> |
This assertion used to compare records in the collect iterator to the target test data with
different semantics (AT_LEAST_ONCE, EXACTLY_ONCE) for unordered messages.
|
UnorderedStreamElementQueue<OUT> |
|
UnregisteredJobManagerJobMetricGroupFactory |
|
UnregisteredMetricGroups |
|
UnregisteredMetricGroups.UnregisteredJobManagerJobMetricGroup |
|
UnregisteredMetricGroups.UnregisteredJobManagerMetricGroup |
|
UnregisteredMetricGroups.UnregisteredJobMangerOperatorMetricGroup |
|
UnregisteredMetricGroups.UnregisteredOperatorMetricGroup |
|
UnregisteredMetricGroups.UnregisteredProcessMetricGroup |
|
UnregisteredMetricGroups.UnregisteredResourceManagerMetricGroup |
|
UnregisteredMetricGroups.UnregisteredSlotManagerMetricGroup |
|
UnregisteredMetricGroups.UnregisteredTaskManagerJobMetricGroup |
|
UnregisteredMetricGroups.UnregisteredTaskManagerMetricGroup |
|
UnregisteredMetricGroups.UnregisteredTaskMetricGroup |
|
UnregisteredMetricsGroup |
A special MetricGroup that does not register any metrics at the metrics registry and any
reporters.
|
UnregisteredSinkModifyOperation<T> |
DML operation that tells to write to the given sink.
|
UnresolvedCallExpression |
|
UnresolvedDataType |
Partially resolved data type that requires a lookup in a catalog or configuration before creating
the corresponding LogicalType .
|
UnresolvedException |
Exception for unwanted method calling on unresolved expression.
|
UnresolvedIdentifier |
Identifier of an object, such as table, view, function or type in a catalog.
|
UnresolvedReferenceExpression |
An unresolved reference to a field, table, or local reference.
|
UnresolvedTaskManagerLocation |
This class encapsulates the connection information of a TaskManager, without resolving the
hostname.
|
UnresolvedUserDefinedType |
|
UnsliceAssigner<W extends Window> |
A UnsliceAssigner assigns each element into a single window and not divides the window
into finite number of non-overlapping slice.
|
UnsliceAssigners |
|
UnsliceAssigners.SessionUnsliceAssigner |
|
UnsliceAssigners.WindowedUnsliceAssigner |
The UnsliceAssigner for elements have been merged into unslicing windows and attached
window start and end timestamps.
|
UnsliceWindowAggProcessor |
An window aggregate processor implementation which works for UnsliceAssigner , e.g.
|
UnslicingWindowProcessor<W> |
|
UnslicingWindowTimerServiceImpl |
|
UnsuccessfulExecutionException |
|
UnsupportedFileSystemSchemeException |
An exception to indicate that a specific file system scheme is not supported.
|
UnsupportedOperationExecutor |
|
UnsupportedProcessingTimeManager |
|
UnsupportedStateDataViewStore |
|
UnsupportedTimeCharacteristicException |
An exception that indicates that a time characteristic was used that is not supported in the
current operation.
|
UntypedResponseMessageHeaders<R extends RequestBody,M extends MessageParameters> |
Message headers for a web handler request.
|
UpdatableRowData |
An implementation of RowData which is backed by a RowData and an updated Java
object array.
|
UpdatableTopNFunction |
A TopN function could handle updating stream.
|
UpdateKind |
|
UpdateSchedulerNgOnInternalFailuresListener |
|
UpdatingTopCityExample |
Example for aggregating and ranking data using Flink SQL on updating tables.
|
UploadResult |
Result of uploading state changes.
|
UpperLimitExceptionParameter |
Specifies the upper limit of exceptions to return for JobExceptionsHandler.
|
UpsertKeyUtil |
Utility for upsertKey which represented as a Set of ImmutableBitSet .
|
UpsertStreamTableSink<T> |
Deprecated.
|
UpsertTestConnectorOptions |
Options for the UpsertTestConnector.
|
UpsertTestDynamicTableSinkFactory |
|
UpsertTestFileUtil |
Collection uf utility methods for reading and writing files from the UpsertTestSink .
|
UpsertTestSink<IN> |
Flink Sink to upsert test data into a file.
|
UpsertTestSinkBuilder<IN> |
|
UpstreamRecoveryTracker |
Tracks status of upstream channels while they recover.
|
UpTimeGauge |
A gauge that returns (in milliseconds) how long a job has been running.
|
UrlDecodeFunction |
|
UrlEncodeFunction |
|
UrlPrefixDecorator<R extends RequestBody,P extends ResponseBody,M extends MessageParameters> |
This class decorates the URL of the original message headers by adding a prefix.
|
UseCatalogOperation |
Operation to describe a USE CATALOG statement.
|
UseDatabaseOperation |
Operation to describe a USE [catalogName.]dataBaseName statement.
|
UseModulesOperation |
Operation to describe a USE MODULES statement.
|
UseOperation |
An Operation that describes the catalog/database switch statements, e.g.
|
User |
|
User.Builder |
RecordBuilder for User instances.
|
UserAccumulator |
User accumulator info.
|
UserCodeClassLoader |
UserCodeClassLoader allows to register release hooks for a user code class loader.
|
UserCodeClassWrapper<T> |
This holds a class containing user defined code.
|
UserCodeObjectWrapper<T> |
This holds an actual object containing user defined code.
|
UserCodeWrapper<T> |
UDf operators can have either a class or an object containing the user code, this is the common
interface to access them.
|
UserDefinedFunction |
Base class for all user-defined functions.
|
UserDefinedFunctionHelper |
|
UserDefinedType |
Logical type of a user-defined representation for one or more built-in types.
|
UserFunctionProvider<F extends Function> |
The interface with user function.
|
UserSystemExitException |
Indicates that user tried to exit JVM.
|
Utils |
Miscellaneous utilities for the file source.
|
Utils |
Contains various shared utility functions.
|
Utils |
Dummy util to test packaging of Flink dependencies in quickstarts.
|
Utils |
Utility class that contains helper methods to work with Java APIs.
|
Utils |
Utility class that provides helper methods to work with Apache Hadoop YARN.
|
Utils.ChecksumHashCode |
|
Utils.ChecksumHashCodeHelper<T> |
|
Utils.CollectHelper<T> |
Utility sink function that collects elements into an accumulator, from which it they can be
retrieved by the client.
|
Utils.CountHelper<T> |
Utility sink function that counts elements and writes the count into an accumulator, from
which it can be retrieved by the client.
|
ValidationException |
Exception for all errors occurring during validation phase.
|
Value |
Basic value interface for types that act as serializable values.
|
ValueComparator<T extends Value & Comparable<T>> |
Comparator for all Value types that extend Key
|
ValueDataTypeConverter |
Value-based data type extractor that supports extraction of clearly identifiable data types for
input conversion.
|
ValueLiteralExpression |
Expression for constant literal values.
|
ValueSerializer<T extends Value> |
Serializer for Value types.
|
ValueSerializer.ValueSerializerSnapshot<T extends Value> |
|
ValuesInputFormat |
Generated ValuesInputFormat.
|
ValuesQueryOperation |
Table operation that computes new table using given Expression s from its input relational
operation.
|
ValueState<T> |
State interface for partitioned single-value state.
|
ValueState<T> |
State interface for partitioned single-value state.
|
ValueStateAdaptor<K,N,V> |
|
ValueStateDeclaration<T> |
This represents a declaration of the value state.
|
ValueStateDescriptor<T> |
|
ValueStateDescriptor<T> |
|
ValueTypeDescriptorImpl<T extends Value> |
|
ValueTypeInfo<T extends Value> |
Type information for data types that extend the Value interface.
|
ValueWithTs<V> |
User state value with timestamps before and after update.
|
ValueWithTs.Serializer |
Serializer for Serializer.
|
ValueWithTs.ValueWithTsSerializerSnapshot |
|
VarBinaryType |
Logical type of a variable-length binary string (=a sequence of bytes).
|
VarBinaryWriter<T> |
|
VarBinaryWriter.VarBinaryWriterForArray |
|
VarBinaryWriter.VarBinaryWriterForRow |
|
VarCharType |
Logical type of a variable-length character string.
|
VarCharWriter<T> |
|
VarCharWriter.VarCharWriterForArray |
|
VarCharWriter.VarCharWriterForRow |
|
VariableLengthByteKeyAndValueComparator<INPUT> |
|
VariableNameUtil |
Util for dealing with variables names in OTel reporting.
|
VariableRankRange |
changing rank limit depends on input.
|
VaryingSequenceInputTypeStrategy |
Strategy for inferring and validating a varying function signature like f(INT, STRING,
NUMERIC...) or f(i INT, str STRING, num NUMERIC...) using a sequence of ArgumentTypeStrategy s.
|
VaryingStringTypeStrategy |
|
VectorizedColumnBatch |
A VectorizedColumnBatch is a set of rows, organized with each column as a vector.
|
Vectorizer<T> |
This class provides an abstracted set of methods to handle the lifecycle of VectorizedRowBatch .
|
Versioned |
This interface is implemented by classes that provide a version number.
|
VersionedIOReadableWritable |
This is the abstract base class for IOReadableWritable which allows to differentiate
between serialization versions.
|
VersionMismatchException |
This exception signals that incompatible versions have been found during serialization.
|
Vertex<VID extends VertexID,RID extends ResultID,V extends Vertex<VID,RID,V,R>,R extends Result<VID,RID,V,R>> |
Represents a logical or execution task.
|
VertexAttemptNumberStore |
Contains the attempt numbers per vertex.
|
VertexEndOfDataListener |
Records the end of data event of each task, and allows for checking whether all tasks of a JobGraph have reached the end of data.
|
VertexFinishedStateChecker |
This class encapsulates the operation that checks if there are illegal modification to the
JobGraph when restoring from a checkpoint with partially or fully finished operator states.
|
VertexFlameGraph |
Flame Graph representation for a job vertex or an execution vertex.
|
VertexFlameGraph.Node |
Graph node.
|
VertexFlameGraphFactory |
Factory class for creating Flame Graph representations.
|
VertexGroupComputeUtil |
Common utils for processing vertex groups.
|
VertexID |
|
VertexInputInfoComputationUtils |
|
VertexInputInfoStore |
|
VertexParallelism |
|
VertexParallelismAndInputInfosDecider |
|
VertexParallelismInformation |
Manages the parallelism properties for a vertex in the execution graph, as well as how they can
change during runtime.
|
VertexParallelismStore |
Contains the max parallelism per vertex, along with metadata about how these maxes were
calculated.
|
VertexStatsTracker<T extends Statistics> |
|
VertexThreadInfoStats |
Thread info statistics of single JobVertex or ExecutionVertex.
|
VertexThreadInfoTracker |
|
VertexThreadInfoTrackerBuilder |
|
VertexwiseSchedulingStrategy |
SchedulingStrategy instance which schedules tasks in granularity of vertex (which
indicates this strategy only supports batch jobs).
|
VertexwiseSchedulingStrategy.Factory |
|
View |
An interface for metrics which should be updated in regular intervals by a background thread.
|
ViewUpdater |
The ViewUpdater is responsible for updating all metrics that implement the View
interface.
|
VisibleForTesting |
This annotations declares that a function, field, constructor, or entire type, is only visible
for testing purposes.
|
Visitable<T extends Visitable<T>> |
This interface marks types as visitable during a traversal.
|
Visitor<T extends Visitable<T>> |
A visitor encapsulates functionality that is applied to each node in the process of a traversal
of a tree or DAG.
|
VoidBlobStore |
A blob store doing nothing.
|
VoidBlobWriter |
BlobWriter which does not support writing BLOBs to a store.
|
VoidHistoryServerArchivist |
|
VoidMetricFetcher |
|
VoidNamespace |
Singleton placeholder class for state without a namespace.
|
VoidNamespace |
Singleton placeholder class for state without a namespace.
|
VoidNamespaceSerializer |
|
VoidNamespaceSerializer |
|
VoidNamespaceSerializer.VoidNamespaceSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
VoidNamespaceTypeInfo |
|
VoidNamespaceTypeInfo |
|
VoidSerializer |
Serializer for Void .
|
VoidSerializer.VoidSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
VoidTriggerable<K,N> |
|
WaitStrategy |
Operations that are polling for a result to arrive require a waiting time between consecutive
polls.
|
Watermark |
Watermarks are the progress indicators in the data streams.
|
Watermark |
A Watermark tells operators that no elements with a timestamp older or equal to the watermark
timestamp should arrive at the operator.
|
WatermarkAlignmentEvent |
Signals source operators the maximum watermark that emitted records can have.
|
WatermarkAlignmentParams |
Configuration parameters for watermark alignment.
|
WatermarkAssignerChangelogNormalizeTransposeRule |
Transpose StreamPhysicalWatermarkAssigner past into StreamPhysicalChangelogNormalize .
|
WatermarkAssignerChangelogNormalizeTransposeRule.Config |
Rule configuration.
|
WatermarkAssignerOperator |
A stream operator that extracts timestamps from stream elements and generates periodic
watermarks.
|
WatermarkAssignerOperatorFactory |
|
WatermarkEmitStrategy |
The strategy for emitting watermark.
|
WatermarkGauge |
A Gauge for exposing the current input/output watermark.
|
WatermarkGaugeExposingOutput<T> |
|
WatermarkGenerator<T> |
The WatermarkGenerator generates watermarks either based on events or periodically (in a
fixed interval).
|
WatermarkGenerator |
|
WatermarkGeneratorCodeGeneratorFunctionContextWrapper |
|
WatermarkGeneratorSupplier<T> |
|
WatermarkGeneratorSupplier.Context |
|
WatermarkOutput |
An output for watermarks.
|
WatermarkOutputMultiplexer |
|
WatermarkOutputMultiplexer.WatermarkUpdateListener |
A callback for propagating changes to split based watermarks.
|
WatermarkParams |
Pojo class for watermark configs from table options or 'OPTIONS' hint.
|
WatermarkParams.WatermarkParamsBuilder |
Builder of WatermarkHintParams.
|
WatermarkPushDownSpec |
|
WatermarkSpec |
|
WatermarkSpec |
Deprecated.
|
WatermarkStatus |
A Watermark Status element informs stream tasks whether or not they should continue to expect
watermarks from the input stream that sent them.
|
WatermarkStrategy<T> |
The WatermarkStrategy defines how to generate Watermark s in the stream sources.
|
WatermarkStrategy |
Provides a strategy to generate watermarks for a rowtime attribute.
|
WatermarkStrategyWithPeriodicWatermarks<T> |
The WatermarkStrategyWithPeriodicWatermarks assigns event time timestamps to elements,
and generates low watermarks that signal event time progress within the stream.
|
WatermarkStrategyWithPunctuatedWatermarks<T> |
The AssignerWithPunctuatedWatermarks assigns event time timestamps to elements, and
generates low watermarks that signal event time progress within the stream.
|
WatermarksWithIdleness<T> |
A WatermarkGenerator that adds idleness detection to another WatermarkGenerator.
|
WatermarkToDataOutput |
|
WebContentHandlerSpecification |
Rest handler specification for the web content handler.
|
WebFrontendBootstrap |
This classes encapsulates the boot-strapping of netty for the web-frontend.
|
WebLogAnalysisData |
Test data for WebLogAnalysis programs.
|
WebMonitorEndpoint<T extends RestfulGateway> |
Rest endpoint which serves the web frontend REST calls.
|
WebMonitorExtension |
|
WebMonitorExtension.EmptyWebMonitorExtension |
Empty web monitor extension which can be used as a null object.
|
WebMonitorUtils |
Utilities for the web runtime monitor.
|
WebMonitorUtils.LogFileLocation |
Singleton to hold the log file, the stdout file, the log directory.
|
WebOptions |
Configuration options for the WebMonitorEndpoint.
|
WebSubmissionExecutorFactory |
|
WebSubmissionExecutorServiceLoader |
|
WebSubmissionExtension |
Container for the web submission handlers.
|
WebSubmissionJobClient |
A JobClient that only allows asking for the job id of the job it is attached to.
|
Whitebox |
Copied from mockito.
|
WildcardInputTypeStrategy |
Strategy that does not perform any modification or validation of the input.
|
Window |
A Window is a grouping of elements into finite buckets.
|
Window |
A Window is a grouping of elements into finite buckets.
|
WindowAggOperator<K,W> |
We divide windows into 2 categories: Aligned Windows and Unaligned Windows.
|
WindowAggOperatorBuilder |
|
WindowAggregateQueryOperation |
Relational operation that performs computations on top of subsets of input rows grouped by key
and group window.
|
WindowAggregateQueryOperation.ResolvedGroupWindow |
|
WindowAggregateQueryOperation.ResolvedGroupWindow.WindowType |
The type of window.
|
WindowAggregateReduceFunctionsRule |
Rule to convert complex aggregation functions into simpler ones.
|
WindowAssigner<T,W extends Window> |
A WindowAssigner assigns zero or more Windows to an element.
|
WindowAssigner |
WindowAssigner is used to assign windows to elements.
|
WindowAssigner.WindowAssignerContext |
A context provided to the WindowAssigner that allows it to query the current
processing time.
|
WindowAttachedWindowingStrategy |
A windowing strategy that gets windows from input columns as windows have been assigned and
attached to the physical columns.
|
WindowBuffer |
A buffer that buffers data in memory and flushes many values to state together at a time to avoid
frequently accessing state, or flushes to output to reduce shuffling data.
|
WindowBuffer.Factory |
|
WindowBuffer.LocalFactory |
|
WindowBytesHashMap |
A binary map in the structure like Map<WindowKey, BinaryRowData> .
|
WindowBytesMultiMap |
A binary map in the structure like Map<WindowKey, List<BinaryRowData>> .
|
WindowContents<S extends State,IN> |
An abstraction for transforming any State type into an iterable over its contents.
|
WindowedStateTransformation<T,K,W extends Window> |
|
WindowedStream<T,K,W extends Window> |
A WindowedStream represents a data stream where elements are grouped by key, and for each
key, the stream of elements is split into windows based on a WindowAssigner .
|
WindowEnd |
Deprecated.
|
WindowFunction<IN,OUT,KEY,W extends Window> |
Base interface for functions that are evaluated over keyed (grouped) windows.
|
WindowGroupedTable |
A table that has been windowed and grouped for GroupWindow s.
|
WindowingStrategy |
Logical representation of a windowing strategy.
|
WindowJoin |
Example illustrating a windowed stream join between two data streams.
|
WindowJoinOperator |
Streaming window join operator.
|
WindowJoinOperatorBuilder |
|
WindowJoinSampleData |
|
WindowKey |
The WindowKey structure represents a combination of key and window.
|
WindowKeySerializer |
|
WindowKeySerializer.WindowKeySerializerSnapshot |
|
WindowListState<W> |
A wrapper of ListState which is easier to update based on window namespace.
|
WindowMapState<W,UV> |
A wrapper of MapState which is easier to update based on window namespace.
|
WindowOperator<K,IN,ACC,OUT,W extends Window> |
|
WindowOperator<K,W extends Window> |
|
WindowOperator.Timer<K,W extends Window> |
Internal class for keeping track of in-flight timers.
|
WindowOperatorBuilder<T,K,W extends Window> |
|
WindowOperatorBuilder |
|
WindowOperatorBuilder.AggregateWindowOperatorBuilder |
|
WindowOperatorBuilder.TableAggregateWindowOperatorBuilder |
|
WindowOperatorFactory<K,IN,ACC,OUT,W extends Window> |
|
WindowProcessor<W> |
A processor that processes elements for windows.
|
WindowProcessor.Context<W> |
|
WindowProperty |
Deprecated.
|
WindowRankOperatorBuilder |
|
WindowRankProcessor |
A rowtime window rank processor.
|
WindowReaderFunction<IN,OUT,KEY,W extends Window> |
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context
for retrieving extra information.
|
WindowReaderFunction.Context<W extends Window> |
The context holding window metadata.
|
WindowReaderOperator<S extends State,KEY,IN,W extends Window,OUT> |
|
WindowReference |
Deprecated.
|
WindowSavepointReader<W extends Window> |
This class provides entry points for reading keyed state written out using the
WindowOperator .
|
WindowsGrouping |
Assigning windows from the sorted input buffers.
|
WindowSpec |
Logical representation of a window specification.
|
WindowStagger |
A WindowStagger staggers offset in runtime for each window assignment.
|
WindowStart |
Deprecated.
|
WindowState<W> |
A base interface for manipulate state with window namespace.
|
WindowTableFunctionOperatorBase |
|
WindowTableFunctionUtil |
Utilities for Window Table Function.
|
WindowTimeIndictorInputTypeStrategy |
|
WindowTimerService<W> |
Interface for working with window time and timers which considers timezone for window splitting.
|
WindowTimerServiceBase<W> |
|
WindowTrigger<W extends Window> |
A WindowTrigger determines when a window should be evaluated to emit the results.
|
WindowValueState<W> |
A wrapper of ValueState which is easier to update based on window namespace.
|
WindowWordCount |
Implements a windowed version of the streaming "WordCount" program.
|
WithBoundedness |
An interface to be implemented by transformations that have explicitly set Boundedness .
|
WithConfigurationOpenContext |
A special OpenContext for passing configuration to udf.
|
WithinCheckpointFileMergingSnapshotManager |
|
WithinType |
Type enum of time interval corresponds to the maximum time gap between events.
|
WithMasterCheckpointHook<E> |
This interface can be implemented by streaming functions that need to trigger a "global action"
on the master (in the checkpoint coordinator) as part of every checkpoint and restore operation.
|
WordCount |
Implements the "WordCount" program that computes a simple word occurrence histogram over text
files.
|
WordCount.Tokenizer |
Implements the string tokenizer that splits sentences into words as a user-defined
FlatMapFunction.
|
WordCountData |
Provides the default data sets used for the WordCount example program.
|
WordCountData |
|
WordCountSQLExample |
The famous word count example that shows a minimal Flink SQL job in batch execution mode.
|
WorkerDoneEvent |
Completion event sent from each IterationHead to the
IterationSynchronizationSinkTask .
|
WorkerRegistration<WorkerType extends ResourceIDRetrievable> |
|
WorkerResourceSpec |
Resource specification of a worker, mainly used by SlotManager requesting from ResourceManager.
|
WorkerResourceSpec.Builder |
|
WorkerResourceSpecFactory |
|
WorkflowException |
A workflow-related operation exception to materialized table, including create, suspend, resume,
drop workflow operation, etc.
|
WorkflowInfo |
The WorkflowInfo represents the required information of one materialized table background
workflow.
|
WorkflowScheduler<T extends RefreshHandler> |
This interface is used to interact with specific workflow scheduler services that support
creating, modifying, and deleting refreshed workflow of Materialized Table.
|
WorkflowSchedulerFactory |
|
WorkflowSchedulerFactory.Context |
Context provided when a workflow scheduler is created.
|
WorkflowSchedulerFactoryUtil |
|
WorkflowSchedulerFactoryUtil.DefaultWorkflowSchedulerContext |
|
WorkflowSchedulerFactoryUtil.WorkflowSchedulerFactoryHelper |
|
WorkingDirectory |
Class that manages a working directory for a process/instance.
|
WorksetEmptyConvergenceCriterion |
A workset iteration is by definition converged if no records have been updated in the
solutionset.
|
WorksetUpdateOutputCollector<T> |
A Collector to update the iteration workset (partial solution for bulk iterations).
|
WrapJsonAggFunctionArgumentsRule |
|
WrapJsonAggFunctionArgumentsRule.Config |
|
WrappedRowIterator<T extends RowData> |
|
WrappedSink<T> |
A simple Sink implementation that wrap a sink-v2 based sink.
|
WrappedSource<T> |
A simple Source implementation that wrap a FLIP-27 source.
|
WrappingCollector<T> |
|
WrappingFunction<T extends Function> |
|
WrappingProxy<T> |
Interface for objects that wrap another object and proxy (possibly a subset) of the methods of
that object.
|
WrappingProxyCloseable<T extends Closeable> |
|
WrappingProxyUtil |
|
WrappingRuntimeException |
A runtime exception that is explicitly used to wrap non-runtime exceptions.
|
WritableBooleanVector |
|
WritableBytesVector |
|
WritableByteVector |
|
WritableColumnVector |
|
WritableComparator<T extends org.apache.hadoop.io.Writable & Comparable<T>> |
|
WritableConfig |
Write access to a configuration object.
|
WritableDoubleVector |
|
WritableFloatVector |
|
WritableIntVector |
|
WritableLongVector |
|
WritableSerializer<T extends org.apache.hadoop.io.Writable> |
|
WritableSerializer.WritableSerializerSnapshot<T extends org.apache.hadoop.io.Writable> |
|
WritableShortVector |
|
WritableTimestampVector |
|
WritableTypeInfo<T extends org.apache.hadoop.io.Writable> |
Type information for data types that extend Hadoop's Writable interface.
|
WriterInitContext |
The interface exposes some runtime info for creating a SinkWriter .
|
WriterProperties |
|
WritingMetadataSpec |
|
XmlResponsesSaxParser |
XML Sax parser to read XML documents returned by S3 via the REST interface, converting these
documents into objects.
|
XmlResponsesSaxParser.AccessControlListHandler |
Handler for AccessControlList response XML documents.
|
XmlResponsesSaxParser.BucketAccelerateConfigurationHandler |
|
XmlResponsesSaxParser.BucketCrossOriginConfigurationHandler |
|
XmlResponsesSaxParser.BucketLifecycleConfigurationHandler |
HTTP/1.1 200 OK x-amz-id-2: Uuag1LuByRx9e6j5Onimru9pO4ZVKnJ2Qz7/C1NPcfTWAtRPfTaOFg==
x-amz-request-id: 656c76696e6727732072657175657374 Date: Tue, 20 Sep 2012 20:34:56 GMT
Content-Length: xxx Connection: keep-alive Server: AmazonS3
|
XmlResponsesSaxParser.BucketLocationHandler |
Handler for CreateBucketConfiguration response XML documents for a bucket.
|
XmlResponsesSaxParser.BucketLoggingConfigurationHandler |
Handler for LoggingStatus response XML documents for a bucket.
|
XmlResponsesSaxParser.BucketReplicationConfigurationHandler |
Handler for parsing the get replication configuration response from Amazon S3.
|
XmlResponsesSaxParser.BucketTaggingConfigurationHandler |
|
XmlResponsesSaxParser.BucketVersioningConfigurationHandler |
|
XmlResponsesSaxParser.BucketWebsiteConfigurationHandler |
|
XmlResponsesSaxParser.CompleteMultipartUploadHandler |
|
XmlResponsesSaxParser.CopyObjectResultHandler |
|
XmlResponsesSaxParser.DeleteObjectsHandler |
|
XmlResponsesSaxParser.GetBucketAnalyticsConfigurationHandler |
|
XmlResponsesSaxParser.GetBucketInventoryConfigurationHandler |
|
XmlResponsesSaxParser.GetBucketMetricsConfigurationHandler |
|
XmlResponsesSaxParser.GetObjectTaggingHandler |
Handler for unmarshalling the response from GET Object Tagging.
|
XmlResponsesSaxParser.InitiateMultipartUploadHandler |
|
XmlResponsesSaxParser.ListAllMyBucketsHandler |
Handler for ListAllMyBuckets response XML documents.
|
XmlResponsesSaxParser.ListBucketAnalyticsConfigurationHandler |
|
XmlResponsesSaxParser.ListBucketHandler |
Handler for ListBucket response XML documents.
|
XmlResponsesSaxParser.ListBucketInventoryConfigurationsHandler |
|
XmlResponsesSaxParser.ListBucketMetricsConfigurationsHandler |
|
XmlResponsesSaxParser.ListMultipartUploadsHandler |
|
XmlResponsesSaxParser.ListObjectsV2Handler |
Handler for ListObjectsV2 response XML documents.
|
XmlResponsesSaxParser.ListPartsHandler |
|
XmlResponsesSaxParser.ListVersionsHandler |
Handler for ListVersionsResult XML document.
|
XmlResponsesSaxParser.RequestPaymentConfigurationHandler |
Handler for parsing RequestPaymentConfiguration XML response associated with an Amazon S3
bucket.
|
XORShiftRandom |
Implement a random number generator based on the XORShift algorithm discovered by George
Marsaglia.
|
XXH64 |
xxHash64.
|
XZInputStreamFactory |
Factory for XZ decompressors.
|
YamlParserUtils |
This class contains utility methods to load standard yaml file and convert object to standard
yaml syntax.
|
YarnApplicationClusterEntryPoint |
|
YarnApplicationStatusMonitor |
Utility class which monitors the specified yarn application status periodically.
|
YarnCancelJobTerminationHeaders |
Deprecated.
|
YarnClientYarnClusterInformationRetriever |
|
YarnClusterClientFactory |
|
YarnClusterDescriptor |
The descriptor with deployment information for deploying a Flink cluster on Yarn.
|
YarnClusterInformationRetriever |
Interface which allows to retrieve information about a Yarn cluster.
|
YarnConfigKeys |
The Yarn environment variables used for settings of the containers.
|
YarnConfigOptions |
This class holds configuration constants used by Flink's YARN runners.
|
YarnConfigOptions.UserJarInclusion |
|
YarnConfigOptionsInternal |
Yarn configuration options that are not meant to be set by the user.
|
YarnDeploymentTarget |
A class containing all the supported deployment target names for Yarn.
|
YarnEntrypointUtils |
|
YarnJobClusterEntrypoint |
Deprecated.
|
YarnJobClusterExecutor |
Deprecated. |
YarnJobClusterExecutorFactory |
Deprecated. |
YarnLogConfigUtil |
A class with utilities for setting the log config file.
|
YarnNodeManagerClientFactory |
Factory interface for NMClientAsync .
|
YarnResourceManagerClientFactory |
Factory interface for AMRMClientAsync .
|
YarnResourceManagerDriver |
|
YarnResourceManagerDriverConfiguration |
|
YarnResourceManagerFactory |
|
YarnSessionClusterEntrypoint |
Entry point for Yarn session clusters.
|
YarnSessionClusterExecutor |
The PipelineExecutor to be used when executing a job on an already running cluster.
|
YarnSessionClusterExecutorFactory |
|
YarnStopJobTerminationHeaders |
Deprecated.
|
YarnTaskExecutorRunner |
This class is the executable entry point for running a TaskExecutor in a YARN container.
|
YarnWorkerNode |
A stored YARN worker, which contains the YARN container.
|
YarnWorkerResourceSpecFactory |
|
YearMonthIntervalPeriodConverter |
|
YearMonthIntervalType |
Logical type for a group of year-month interval types.
|
YearMonthIntervalType.YearMonthResolution |
Supported resolutions of this type.
|
YieldingOperator<OUT> |
A V1 operator that needs access to the MailboxExecutor should implement this interface.
|
YieldingOperatorFactory<OUT> |
Deprecated. |
ZonedTimestampType |
Logical type of a timestamp WITH time zone consisting of year-month-day
hour:minute:second[.fractional] zone with up to nanosecond precision and values ranging from
0000-01-01 00:00:00.000000000 +14:59 to 9999-12-31 23:59:59.999999999 -14:59 .
|
ZooKeeperCheckpointIDCounter |
|
ZooKeeperCheckpointRecoveryFactory |
|
ZooKeeperCheckpointStoreUtil |
|
ZooKeeperClientHAServices |
|
ZooKeeperExecutionPlanStoreUtil |
|
ZooKeeperExecutionPlanStoreWatcher |
|
ZooKeeperLeaderElectionDriver |
|
ZooKeeperLeaderElectionDriverFactory |
|
ZooKeeperLeaderElectionHaServices |
ZooKeeper HA services that only use a single leader election per process.
|
ZooKeeperLeaderRetrievalDriver |
|
ZooKeeperLeaderRetrievalDriver.LeaderInformationClearancePolicy |
Policy when to clear the leader information and to notify the listener about it.
|
ZooKeeperLeaderRetrievalDriverFactory |
|
ZooKeeperModule |
Responsible for installing a process-wide ZooKeeper security configuration.
|
ZookeeperModuleFactory |
|
ZooKeeperSharedCount |
Wrapper class for a SharedCount so that we don't expose a curator dependency in our
internal APIs.
|
ZooKeeperSharedValue |
Wrapper class for a SharedValue so that we don't expose a curator dependency in our
internal APIs.
|
ZooKeeperStateHandleStore<T extends Serializable> |
|
ZooKeeperUtils |
Class containing helper functions to interact with ZooKeeper.
|
ZooKeeperUtils.SecureAclProvider |
Secure ACLProvider implementation.
|
ZooKeeperUtils.ZkClientACLMode |
ZooKeeper client ACL mode enum.
|
ZooKeeperVersionedValue<T> |
Wrapper class for a VersionedValue so that we don't expose a curator dependency in our
internal APIs.
|
ZStandardInputStreamFactory |
Factory for ZStandard decompressors.
|