All Classes Interface Summary Class Summary Enum Summary
| Class |
Description |
| AggregateEvictingWindowReaderFunction<IN,ACC,R,OUT,KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window> |
A wrapper for reading an evicting window operator with an aggregate function.
|
| BootstrapStreamTaskRunner<IN> |
The runtime for a BootstrapStreamTask.
|
| BroadcastStateBootstrapFunction<IN> |
Interface for writing elements to broadcast state.
|
| BroadcastStateBootstrapFunction.Context |
|
| BroadcastStateBootstrapOperator<IN> |
|
| BroadcastStateInputFormat<K,V> |
The input format for reading BroadcastState.
|
| EvictingWindowReaderFunction<IN,R,OUT,KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window> |
Wrapper for reading state from an evicting window operator.
|
| EvictingWindowSavepointReader<W extends org.apache.flink.streaming.api.windowing.windows.Window> |
This class provides entry points for reading keyed state written out using the
WindowOperator.
|
| FileCopyFunction |
This output format copies files from an existing savepoint into a new directory.
|
| GroupReduceOperator<IN,OUT> |
An operator for executing a GroupReduceFunction on a bounded DataStream.
|
| KeyedStateBootstrapFunction<K,IN> |
A function that writes keyed state to a new operator.
|
| KeyedStateBootstrapOperator<K,IN> |
|
| KeyedStateInputFormat<K,N,OUT> |
Input format for reading partitioned state.
|
| KeyedStateReader |
Keyed state reader function for value, list and map state types.
|
| KeyedStateReaderFunction<K,OUT> |
A function that processes keys from a restored operator
|
| KeyedStateReaderFunction.Context |
|
| KeyedStateReaderOperator<KEY,OUT> |
|
| KeyedStateTransformation<K,T> |
|
| KeyGroupRangeInputSplit |
An input split representing a key-group range from a savepoint.
|
| LazyTimerService |
A timer service that initializes its internal timer service lazily.
|
| ListStateInputFormat<OT> |
Input format for reading operator list state.
|
| MergeOperatorStates |
A reducer that aggregates multiple OperatorState's into a single CheckpointMetadata.
|
| MultiStateKeyIterator<K> |
An iterator for reading all keys in a state backend across multiple partitioned states.
|
| MutableConfig |
A utility for creating a mutable Configuration from a ReadableConfig.
|
| NeverFireProcessingTimeService |
A processing time service whose timers never fire so all timers are included in savepoints.
|
| OneInputStateTransformation<T> |
OneInputStateTransformation represents a user defined transformation applied on an OperatorTransformation with one input.
|
| OperatorIdentifier |
Identifies an operator, either based on a uid or uidHash.
|
| OperatorIDGenerator |
Utility for generating Operator Id's from uid strings.
|
| OperatorStateInputSplit |
An input split containing state handles for operator state.
|
| OperatorSubtaskStateReducer |
A reducer that aggregates all OperatorSubtaskState's for a particular operator into a
single OperatorState.
|
| OperatorTransformation |
This class provides the entry point for building StateBootstrapTransformations, which
represents procedures to bootstrap new operator states with a given DataStream.
|
| PassThroughReader<KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window,IN> |
|
| PrioritizedOperatorSubtaskStateInputSplit |
An input split that returns PrioritizedOperatorSubtaskState.
|
| ProcessEvictingWindowReader<IN,OUT,KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window> |
A wrapper function for reading an evicting window with no pre-aggregation.
|
| ReduceEvictingWindowReaderFunction<IN,OUT,KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window> |
A wrapper function for reading state from an evicting window operator with a reduce function.
|
| SavepointConnectorOptions |
Options for the savepoint connector.
|
| SavepointConnectorOptions.StateType |
Value state types.
|
| SavepointConnectorOptionsUtil |
|
| SavepointDataStreamScanProvider |
Savepoint data stream scan provider.
|
| SavepointDynamicTableSource |
Savepoint dynamic source.
|
| SavepointDynamicTableSourceFactory |
|
| SavepointEnvironment |
A minimally implemented Environment that provides the functionality required to run the
state-processor-api.
|
| SavepointEnvironment.Builder |
|
| SavepointLoader |
Utility class for loading CheckpointMetadata metadata.
|
| SavepointMetadataTableFunction |
|
| SavepointMetadataV2 |
Savepoint metadata that can be modified.
|
| SavepointOutputFormat |
An output format to serialize CheckpointMetadata metadata to distributed storage.
|
| SavepointReader |
The entry point for reading state from a Flink savepoint.
|
| SavepointRuntimeContext |
A streaming RuntimeContext which delegates to the underlying batch RuntimeContext
along with a specified KeyedStateStore.
|
| SavepointTypeInformationFactory |
TypeInformation factory for decoding savepoint value data.
|
| SavepointWriter |
A SavepointWriter can create new savepoints from bounded data streams.
|
| SavepointWriterOperatorFactory |
Creates a savepoint writing operator from a savepoint path.
|
| SnapshotUtils |
Takes a final snapshot of the state of an operator subtask.
|
| SourceBuilder |
A utility for constructing InputFormat based sources that are marked as BOUNDED.
|
| 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 org.apache.flink.streaming.api.operators.AbstractStreamOperator<OUT> & org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>> |
Wraps an existing operator so it can be bootstrapped.
|
| StateBootstrapWrapperOperatorFactory<IN,OUT,OP extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<OUT> & org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>,OPF extends org.apache.flink.streaming.api.operators.OneInputStreamOperatorFactory<IN,OUT>> |
|
| StateModule |
Module of state in Flink.
|
| StateModuleFactory |
|
| StatePathExtractor |
Extracts all file paths that are part of the provided OperatorState.
|
| StateReaderOperator<F extends org.apache.flink.api.common.functions.Function,KEY,N,OUT> |
Base class for executing functions that read keyed state.
|
| StateValueColumnConfiguration |
Configuration for SQL savepoint columns.
|
| TaggedOperatorSubtaskState |
A simple wrapper pojo that tags OperatorSubtaskState with metadata.
|
| Timestamper<T> |
Assigns an event time timestamp to the given record.
|
| UnionStateInputFormat<OT> |
Input format for reading operator union state.
|
| VoidTriggerable<K,N> |
A Triggerable that does nothing.
|
| WindowContents<S extends org.apache.flink.api.common.state.State,IN> |
An abstraction for transforming any State type into an iterable over its contents.
|
| WindowedStateTransformation<T,K,W extends org.apache.flink.streaming.api.windowing.windows.Window> |
|
| WindowReaderFunction<IN,OUT,KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window> |
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context
for retrieving extra information.
|
| WindowReaderFunction.Context<W extends org.apache.flink.streaming.api.windowing.windows.Window> |
The context holding window metadata.
|
| WindowReaderOperator<S extends org.apache.flink.api.common.state.State,KEY,IN,W extends org.apache.flink.streaming.api.windowing.windows.Window,OUT> |
|
| WindowSavepointReader<W extends org.apache.flink.streaming.api.windowing.windows.Window> |
This class provides entry points for reading keyed state written out using the
WindowOperator.
|