Uses of Package
org.apache.flink.runtime.state
-
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.asyncprocessing.operators Class Description AsyncKeyedStateBackend An async keyed state backend provides methods supporting to access keyed state asynchronously and in batch.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.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.VoidNamespace Singleton placeholder class for state without a namespace. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.asyncprocessing.operators.windowing Class Description AsyncKeyedStateBackend An async keyed state backend provides methods supporting to access keyed state asynchronously and in batch.DefaultKeyedStateStore Default implementation of KeyedStateStore that currently forwards state registration to aRuntimeContext
. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.checkpoint Class Description ChainedStateHandle Handle to state handles for the operators in an operator chain.CheckpointStorage CheckpointStorage defines howStateBackend
's store their state for fault tolerance in streaming applications.CheckpointStorageCoordinatorView This interface creates aCheckpointStorageLocation
to which an individual checkpoint or savepoint is stored.CheckpointStorageLocation A storage location for one particular checkpoint, offering data persistent, metadata persistence, and lifecycle/cleanup methods.CheckpointStorageLocationReference A reference to a storage location.CompletedCheckpointStorageLocation The CompletedCheckpointStorageLocation describes the storage aspect of a completed checkpoint.CompositeStateHandle Base of all snapshots that are taken byStateBackend
s and some other components in tasks.InputChannelStateHandle Handle
to anInputChannel
state.KeyedStateHandle Base for the handles of the checkpointed states in keyed streams.KeyGroupRange This class defines a range of key-group indexes.OperatorStateHandle Interface of a state handle for operator state.ResultSubpartitionStateHandle Handle
to aResultSubpartition
state.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 Simple factory to produceSharedStateRegistry
objects.StateBackend A State Backend defines how the state of a streaming application is stored locally within the cluster.StateObject Base of all handles that represent checkpointed state in some form.StateObject.StateObjectSizeStatsCollector Collector for size and location stats from a state object viaStateObject.collectSizeStats(StateObjectSizeStatsCollector)
.StreamStateHandle AStateObject
that represents state that was written to a stream. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.checkpoint.channel Class Description AbstractChannelStateHandle.StateContentMetaInfo Describes the underlying content.CheckpointStorageWorkerView This interface implements the durable storage of checkpoint data and metadata streams.InputChannelStateHandle Handle
to anInputChannel
state.ResultSubpartitionStateHandle Handle
to aResultSubpartition
state.StreamStateHandle AStateObject
that represents state that was written to a stream. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.checkpoint.filemerging Class Description CheckpointedStateScope The scope for a chunk of checkpointed state.StreamStateHandle AStateObject
that represents state that was written to a stream. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.checkpoint.metadata Class Description InputChannelStateHandle Handle
to anInputChannel
state.KeyedStateHandle Base for the handles of the checkpointed states in keyed streams.OperatorStateHandle Interface of a state handle for operator state.ResultSubpartitionStateHandle Handle
to aResultSubpartition
state.StreamStateHandle AStateObject
that represents state that was written to a stream. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.dispatcher.cleanup Class Description SharedStateRegistryFactory Simple factory to produceSharedStateRegistry
objects. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.execution Class Description CheckpointStorageAccess Implementations of this interface should implement methods acting as an administration role for checkpoint storage, which defined inCheckpointStorageCoordinatorView
.TaskStateManager This interface provides methods to report and retrieve state for a task. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.executiongraph Class Description CheckpointStorage CheckpointStorage defines howStateBackend
's store their state for fault tolerance in streaming applications.StateBackend A State Backend defines how the state of a streaming application is stored locally within the cluster. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.jobgraph.tasks Class Description CheckpointStorage CheckpointStorage defines howStateBackend
's store their state for fault tolerance in streaming applications.StateBackend A State Backend defines how the state of a streaming application is stored locally within the cluster. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.jobmaster Class Description KeyGroupRange This class defines a range of key-group indexes. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.persistence Class Description RetrievableStateHandle Handle to state that can be read back again viaRetrievableStateHandle.retrieveState()
. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.persistence.filesystem Class Description RetrievableStateHandle Handle to state that can be read back again viaRetrievableStateHandle.retrieveState()
. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.query Class Description KeyGroupRange This class defines a range of key-group indexes. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.scheduler Class Description KeyGroupRange This class defines a range of key-group indexes. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.scheduler.adaptive Class Description KeyGroupRange This class defines a range of key-group indexes. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.scheduler.adaptive.allocator Class Description KeyGroupRange This class defines a range of key-group indexes. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.source.coordinator Class Description PriorityComparable Interface for objects that can be compared by priority. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state Class Description AbstractChannelStateHandle Abstract channel state handle.AbstractChannelStateHandle.StateContentMetaInfo Describes the underlying content.AbstractIncrementalStateHandle Abstract superclass for allIncrementalKeyedStateHandle
.AbstractKeyedStateBackend Base implementation of KeyedStateBackend.AbstractKeyedStateBackend.PartitionStateFactory AbstractStateBackend An abstract base implementation of theStateBackend
interface.ArrayListSerializer AsyncKeyedStateBackend An async keyed state backend provides methods supporting to access keyed state asynchronously and in batch.AsyncSnapshotCallable.AsyncSnapshotTask FutureTask
that wraps aAsyncSnapshotCallable
and connects it with cancellation and closing.BackendBuildingException Exceptions which indicate that a state backend building has failed.BackendWritableBroadcastState An interface with methods related to the interplay between theBroadcast State
and theOperatorStateBackend
.ChainedStateHandle Handle to state handles for the operators in an operator chain.CheckpointableKeyedStateBackend Interface that combines both, theKeyedStateBackend
interface, which encapsulates methods responsible for keyed state management and theSnapshotable
which tells the system how to snapshot the underlying state.CheckpointBoundKeyedStateHandle KeyedStateHandle
that is bound to a specific checkpoint.CheckpointedStateScope The scope for a chunk of checkpointed state.CheckpointMetadataOutputStream An output stream for checkpoint metadata.CheckpointStateOutputStream A dedicated output stream that produces aStreamStateHandle
when closed.CheckpointStateToolset A toolset of operations that can be performed on a location embedded within the class.CheckpointStorage CheckpointStorage defines howStateBackend
'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 inCheckpointStorageCoordinatorView
.CheckpointStorageCoordinatorView This interface creates aCheckpointStorageLocation
to which an individual checkpoint or savepoint is stored.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.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 theSnapshotResult
.CheckpointStreamWithResultProvider.KeyedStateHandleFactory Factory method for aKeyedStateHandle
to be used inCheckpointStreamWithResultProvider.toKeyedStateHandleSnapshotResult(SnapshotResult, KeyGroupRangeOffsets, KeyedStateHandleFactory)
.CompletedCheckpointStorageLocation The CompletedCheckpointStorageLocation describes the storage aspect of a completed checkpoint.CompositeStateHandle Base of all snapshots that are taken byStateBackend
s and some other components in tasks.DefaultOperatorStateBackend Default implementation of OperatorStateStore that provides the ability to make snapshots.DirectoryStateHandle This state handle represents a directory.DoneFuture AFuture
that is always done and will just yield the object that was given at creation time.DuplicatingCheckpointOutputStream A CheckpointStateOutputStream that wraps a primary and a secondary CheckpointStateOutputStream and duplicates all writes into both streams.FileMergingSnapshotManagerClosableWrapper A wrapper that wrapsFileMergingSnapshotManager
and aCloseable
.FullSnapshotResources ASnapshotResources
to be used with the backend-independentFullSnapshotAsyncWriter
.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).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.HeapBroadcastState ABroadcast State
backed a heap-basedMap
.IncrementalKeyedStateHandle Common interface to all incrementalKeyedStateHandle
.IncrementalKeyedStateHandle.HandleAndLocalPath A Holder of StreamStateHandle and the corresponding localPath.IncrementalRemoteKeyedStateHandle The handle to states of an incremental snapshot.InternalKeyContext This interface is the current context of a keyed state.InternalPriorityQueue Interface for collection that gives in order access to elements w.r.t their priority.Keyed Interface for objects that have a key attribute.KeyedStateBackend A keyed state backend provides methods for managing keyed state.KeyedStateBackend.KeySelectionListener Listener is given a callback whenKeyedStateBackend.setCurrentKey(K)
is called (key context changes).KeyedStateBackendParametersImpl Internal POJO implementingStateBackend.KeyedStateBackendParameters
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 A function to be applied to all keyed states.KeyedStateHandle Base for the handles of the checkpointed states in keyed streams.KeyExtractorFunction Function to extract a key from a given object.KeyGroupedInternalPriorityQueue This interface exists as (temporary) adapter between the newInternalPriorityQueue
and the old way in which timers are written in a snapshot.KeyGroupPartitioner.ElementReaderFunction This functional interface defines how one element is read from aDataInputView
.KeyGroupPartitioner.ElementWriterFunction This functional interface defines how one element is written to aDataOutputView
.KeyGroupPartitioner.KeyGroupElementsConsumer Functional interface to consume elements from a key group.KeyGroupPartitioner.PartitioningResult This represents the result of key-group partitioning.KeyGroupRange This class defines a range of key-group indexes.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.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.KeyValueStateIterator Iterator that over all key-value state entries in aKeyedStateBackend
.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.LocalSnapshotDirectoryProvider Provides directories for local backup or local recovery.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).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.NonClosingCheckpointOutputStream Abstract class to implement custom checkpoint output streams which should not be closable for user code.OperatorStateBackend Interface that combines both, the user facingOperatorStateStore
interface and the system interfaceSnapshotable
.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 The modes that determine how anOperatorStreamStateHandle
is assigned to tasks during restore.OperatorStateHandle.StateMetaInfo Meta information about the operator state handle.OwnedTaskLocalStateStore This interface represents the administrative interface toTaskLocalStateStore
, that only the owner of the object should see.PartitionableListState Implementation of operator list state.PhysicalStateHandleID Unique ID that allows for physical comparison between state handles.PriorityComparable Interface for objects that can be compared by priority.PriorityComparator This interface works similar toComparable
and is used to prioritize between two objects.PriorityQueueSetFactory Factory forKeyGroupedInternalPriorityQueue
instances.RegisteredBroadcastStateBackendMetaInfo RegisteredKeyValueStateBackendMetaInfo Compound meta information for a registered state in a keyed state backend.RegisteredOperatorStateBackendMetaInfo Compound meta information for a registered state in an operator state backend.RegisteredPriorityQueueStateBackendMetaInfo Meta information about a priority queue state in a backend.RegisteredStateMetaInfoBase Base class for all registered state in state backends.RegisteredStateMetaInfoBase.Key Wrapper class that can be used to represent the wrappedRegisteredStateMetaInfoBase
as key in aMap
.RestoreOperation Interface for restore operation.RetrievableStateHandle Handle to state that can be read back again viaRetrievableStateHandle.retrieveState()
.SavepointKeyedStateHandle AKeyedStateHandle
that points to a savepoint taken in the unified format.SavepointResources Savepoint resources for aKeyedStateBackend
.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 Simple factory to produceSharedStateRegistry
objects.SharedStateRegistryKey This class represents a key that uniquely identifies (on a logical level) state handles for registration in theSharedStateRegistry
.Snapshotable 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 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.SnapshotStrategy Interface for different snapshot approaches in state backends.SnapshotStrategy.SnapshotResultSupplier A supplier for aSnapshotResult
with an access to aCloseableRegistry
for io tasks that need to be closed when cancelling the async part of the checkpoint.SnapshotStrategyRunner A class to execute aSnapshotStrategy
.StateBackend A State Backend defines how the state of a streaming application is stored locally within the cluster.StateBackend.CustomInitializationMetrics StateBackend.KeyedStateBackendParameters Parameters passed toStateBackend.createKeyedStateBackend(KeyedStateBackendParameters)
.StateBackend.OperatorStateBackendParameters Parameters passed toStateBackend.createOperatorStateBackend(OperatorStateBackendParameters)
.StateBackendBuilder A mutable builder to build a state backend instance.StateEntry Interface of entries in a state backend.StateHandleID Unique ID that allows for logical comparison between state handles.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.StateObject Base of all handles that represent checkpointed state in some form.StateObject.StateObjectLocation Enum for state locations.StateObject.StateObjectSizeStatsCollector Collector for size and location stats from a state object viaStateObject.collectSizeStats(StateObjectSizeStatsCollector)
.StatePartitionStreamProvider This class provides access to input streams that contain data of one state partition of a partitionable state.StateSerializerProvider AStateSerializerProvider
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.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.StateSnapshotKeyGroupReader Interface for state de-serialization intoStateTable
s by key-group.StateSnapshotTransformer Transformer of state values which are included or skipped in the snapshot.StateSnapshotTransformer.CollectionStateSnapshotTransformer.TransformStrategy StateSnapshotTransformer.StateSnapshotTransformFactory This factory creates state transformers depending on the form of values to transform.StateSnapshotTransformers.StateSnapshotTransformFactoryWrapAdaptor StreamCompressionDecorator Implementations of this interface decorate streams with a compression scheme.StreamStateHandle AStateObject
that represents state that was written to a stream.TaskExecutorStateChangelogStoragesManager This class holds the allStateChangelogStorage
objects for a task executor (manager).TaskLocalStateStore Classes that implement this interface serve as a task-manager-level local storage for local checkpointed state.TaskLocalStateStoreImpl Main implementation of aTaskLocalStateStore
.TaskStateManager This interface provides methods to report and retrieve state for a task.TestableKeyedStateBackend A keyed state backend interface for internal testing purpose.VoidNamespace Singleton placeholder class for state without a namespace.VoidNamespaceSerializer Serializer forVoidNamespace
.VoidNamespaceTypeInfo TypeInformation
forVoidNamespace
. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.changelog Class Description CheckpointBoundKeyedStateHandle KeyedStateHandle
that is bound to a specific checkpoint.CompositeStateHandle Base of all snapshots that are taken byStateBackend
s and some other components in tasks.KeyedStateHandle Base for the handles of the checkpointed states in keyed streams.KeyGroupRange This class defines a range of key-group indexes.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.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.SnapshotResult 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.StateHandleID Unique ID that allows for logical comparison between state handles.StateObject Base of all handles that represent checkpointed state in some form.StreamStateHandle AStateObject
that represents state that was written to a stream. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.changelog.inmemory Class Description CompositeStateHandle Base of all snapshots that are taken byStateBackend
s and some other components in tasks.KeyedStateHandle Base for the handles of the checkpointed states in keyed streams.KeyGroupRange This class defines a range of key-group indexes.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.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.StateHandleID Unique ID that allows for logical comparison between state handles.StateObject Base of all handles that represent checkpointed state in some form.StateObject.StateObjectSizeStatsCollector Collector for size and location stats from a state object viaStateObject.collectSizeStats(StateObjectSizeStatsCollector)
. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.delegate Class Description StateBackend A State Backend defines how the state of a streaming application is stored locally within the cluster. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.filemerging Class Description CheckpointedStateScope The scope for a chunk of checkpointed state.CompositeStateHandle Base of all snapshots that are taken byStateBackend
s and some other components in tasks.OperatorStateHandle Interface of a state handle for operator state.OperatorStateHandle.StateMetaInfo Meta information about the operator state handle.OperatorStreamStateHandle State handle for partitionable operator state.PhysicalStateHandleID Unique ID that allows for physical comparison between state handles.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.SharedStateRegistryKey This class represents a key that uniquely identifies (on a logical level) state handles for registration in theSharedStateRegistry
.StateObject Base of all handles that represent checkpointed state in some form.StateObject.StateObjectSizeStatsCollector Collector for size and location stats from a state object viaStateObject.collectSizeStats(StateObjectSizeStatsCollector)
.StreamStateHandle AStateObject
that represents state that was written to a stream. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.filesystem Class Description AbstractStateBackend An abstract base implementation of theStateBackend
interface.CheckpointedStateScope The scope for a chunk of checkpointed state.CheckpointMetadataOutputStream An output stream for checkpoint metadata.CheckpointStateOutputStream A dedicated output stream that produces aStreamStateHandle
when closed.CheckpointStateToolset A toolset of operations that can be performed on a location embedded within the class.CheckpointStorage CheckpointStorage defines howStateBackend
'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 inCheckpointStorageCoordinatorView
.CheckpointStorageCoordinatorView This interface creates aCheckpointStorageLocation
to which an individual checkpoint or savepoint is stored.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.CheckpointStreamFactory A factory for checkpoint output streams, which are used to persist data for checkpoints.CompletedCheckpointStorageLocation The CompletedCheckpointStorageLocation describes the storage aspect of a completed checkpoint.PhysicalStateHandleID Unique ID that allows for physical comparison between state handles.StateBackend A State Backend defines how the state of a streaming application is stored locally within the cluster.StateObject Base of all handles that represent checkpointed state in some form.StateObject.StateObjectSizeStatsCollector Collector for size and location stats from a state object viaStateObject.collectSizeStats(StateObjectSizeStatsCollector)
.StreamStateHandle AStateObject
that represents state that was written to a stream. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.hashmap Class Description AbstractKeyedStateBackend Base implementation of KeyedStateBackend.AbstractStateBackend An abstract base implementation of theStateBackend
interface.BackendBuildingException Exceptions which indicate that a state backend building has failed.ConfigurableStateBackend An interface for state backends that pick up additional parameters from a configuration.OperatorStateBackend Interface that combines both, the user facingOperatorStateStore
interface and the system interfaceSnapshotable
.StateBackend A State Backend defines how the state of a streaming application is stored locally within the cluster.StateBackend.KeyedStateBackendParameters Parameters passed toStateBackend.createKeyedStateBackend(KeyedStateBackendParameters)
.StateBackend.OperatorStateBackendParameters Parameters passed toStateBackend.createOperatorStateBackend(OperatorStateBackendParameters)
.StateBackendFactory A factory to create a specific state backend. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.heap Class Description AbstractKeyedStateBackend Base implementation of KeyedStateBackend.AbstractKeyedStateBackend.PartitionStateFactory AbstractKeyedStateBackendBuilder An abstract base implementation of theStateBackendBuilder
interface.BackendBuildingException Exceptions which indicate that a state backend building has failed.CheckpointableKeyedStateBackend Interface that combines both, theKeyedStateBackend
interface, which encapsulates methods responsible for keyed state management and theSnapshotable
which tells the system how to snapshot the underlying state.CheckpointStreamFactory A factory for checkpoint output streams, which are used to persist data for checkpoints.InternalKeyContext This interface is the current context of a keyed state.InternalPriorityQueue Interface for collection that gives in order access to elements w.r.t their priority.IterableStateSnapshot AStateSnapshot
that can return an iterator over all containedStateEntries
.Keyed Interface for objects that have a key attribute.KeyedStateBackend A keyed state backend provides methods for managing keyed state.KeyedStateFactory This factory produces concrete internal state objects.KeyedStateFunction A function to be applied to all keyed states.KeyedStateHandle Base for the handles of the checkpointed states in keyed streams.KeyExtractorFunction Function to extract a key from a given object.KeyGroupedInternalPriorityQueue This interface exists as (temporary) adapter between the newInternalPriorityQueue
and the old way in which timers are written in a snapshot.KeyGroupRange This class defines a range of key-group indexes.KeyValueStateIterator Iterator that over all key-value state entries in aKeyedStateBackend
.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.PriorityComparable Interface for objects that can be compared by priority.PriorityComparator This interface works similar toComparable
and is used to prioritize between two objects.PriorityQueueSetFactory Factory forKeyGroupedInternalPriorityQueue
instances.RegisteredKeyValueStateBackendMetaInfo Compound meta information for a registered state in a keyed state backend.RegisteredPriorityQueueStateBackendMetaInfo Meta information about a priority queue state in a backend.RestoreOperation Interface for restore operation.SavepointResources Savepoint resources for aKeyedStateBackend
.Snapshotable Interface for objects that can snapshot its state (state backends currently).SnapshotExecutionType Determines how the write-part of a snapshot should be executed.SnapshotResult 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.StateBackendBuilder A mutable builder to build a state backend instance.StateEntry Interface of entries in a state backend.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.StateSnapshotKeyGroupReader Interface for state de-serialization intoStateTable
s by key-group.StateSnapshotRestore Interface to deal with state snapshot and restore of state.StateSnapshotTransformer Transformer of state values which are included or skipped in the snapshot.StateSnapshotTransformer.StateSnapshotTransformFactory This factory creates state transformers depending on the form of values to transform.StateTransformationFunction Interface for a binary function that is used for push-down of state transformation into state backends.StreamCompressionDecorator Implementations of this interface decorate streams with a compression scheme.TestableKeyedStateBackend A keyed state backend interface for internal testing purpose. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.internal Class Description StateEntry Interface of entries in a state backend. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.memory Class Description CheckpointedStateScope The scope for a chunk of checkpointed state.CheckpointMetadataOutputStream An output stream for checkpoint metadata.CheckpointStateOutputStream A dedicated output stream that produces aStreamStateHandle
when closed.CheckpointStateToolset A toolset of operations that can be performed on a location embedded within the class.CheckpointStorageAccess Implementations of this interface should implement methods acting as an administration role for checkpoint storage, which defined inCheckpointStorageCoordinatorView
.CheckpointStorageCoordinatorView This interface creates aCheckpointStorageLocation
to which an individual checkpoint or savepoint is stored.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.CheckpointStreamFactory A factory for checkpoint output streams, which are used to persist data for checkpoints.PhysicalStateHandleID Unique ID that allows for physical comparison between state handles.StateObject Base of all handles that represent checkpointed state in some form.StateObject.StateObjectSizeStatsCollector Collector for size and location stats from a state object viaStateObject.collectSizeStats(StateObjectSizeStatsCollector)
.StreamStateHandle AStateObject
that represents state that was written to a stream. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.restore Class Description KeyedStateHandle Base for the handles of the checkpointed states in keyed streams.KeyGroupRange This class defines a range of key-group indexes.RestoreOperation Interface for restore operation.StateSerializerProvider AStateSerializerProvider
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. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.storage Class Description CheckpointStorage CheckpointStorage defines howStateBackend
'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 inCheckpointStorageCoordinatorView
.CompletedCheckpointStorageLocation The CompletedCheckpointStorageLocation describes the storage aspect of a completed checkpoint.ConfigurableCheckpointStorage An interface for checkpoint storage types that pick up additional parameters from a configuration. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.ttl Class Description KeyedStateBackend A keyed state backend provides methods for managing keyed state. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.v2 Class Description RegisteredStateMetaInfoBase Base class for all registered state in state backends.StateSnapshotTransformer.StateSnapshotTransformFactory This factory creates state transformers depending on the form of values to transform. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.v2.adaptor Class Description AsyncKeyedStateBackend An async keyed state backend provides methods supporting to access keyed state asynchronously and in batch.CheckpointableKeyedStateBackend Interface that combines both, theKeyedStateBackend
interface, which encapsulates methods responsible for keyed state management and theSnapshotable
which tells the system how to snapshot the underlying state.CheckpointStreamFactory A factory for checkpoint output streams, which are used to persist data for checkpoints.Keyed Interface for objects that have a key attribute.KeyedStateHandle Base for the handles of the checkpointed states in keyed streams.KeyGroupedInternalPriorityQueue This interface exists as (temporary) adapter between the newInternalPriorityQueue
and the old way in which timers are written in a snapshot.KeyGroupRange This class defines a range of key-group indexes.PriorityComparable Interface for objects that can be compared by priority.PriorityQueueSetFactory Factory forKeyGroupedInternalPriorityQueue
instances.Snapshotable Interface for objects that can snapshot its state (state backends currently).SnapshotResult 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. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.state.v2.ttl Class Description AsyncKeyedStateBackend An async keyed state backend provides methods supporting to access keyed state asynchronously and in batch. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.taskexecutor Class Description TaskExecutorChannelStateExecutorFactoryManager This class holds the allChannelStateWriteRequestExecutorFactory
objects for a task executor (manager).TaskExecutorFileMergingManager There is oneFileMergingSnapshotManager
for each job per task manager.TaskExecutorLocalStateStoresManager This class holds the allTaskLocalStateStoreImpl
objects for a task executor (manager).TaskExecutorStateChangelogStoragesManager This class holds the allStateChangelogStorage
objects for a task executor (manager). -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.taskexecutor.rpc Class Description KeyGroupRange This class defines a range of key-group indexes. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.taskmanager Class Description CheckpointStorageAccess Implementations of this interface should implement methods acting as an administration role for checkpoint storage, which defined inCheckpointStorageCoordinatorView
.TaskStateManager This interface provides methods to report and retrieve state for a task. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.util Class Description SharedStateRegistryFactory Simple factory to produceSharedStateRegistry
objects.StateObject Base of all handles that represent checkpointed state in some form. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.runtime.zookeeper Class Description RetrievableStateHandle Handle to state that can be read back again viaRetrievableStateHandle.retrieveState()
. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.streaming.api Class Description VoidNamespace Singleton placeholder class for state without a namespace. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.streaming.api.checkpoint Class Description 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).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. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.streaming.api.functions.co Class Description KeyedStateFunction A function to be applied to all keyed states. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.streaming.api.functions.source Class Description 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.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. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.streaming.api.functions.source.legacy Class Description 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).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. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.streaming.api.graph Class Description CheckpointStorage CheckpointStorage defines howStateBackend
's store their state for fault tolerance in streaming applications.StateBackend A State Backend defines how the state of a streaming application is stored locally within the cluster. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.streaming.api.operators Class Description AsyncKeyedStateBackend An async keyed state backend provides methods supporting to access keyed state asynchronously and in batch.CheckpointableKeyedStateBackend Interface that combines both, theKeyedStateBackend
interface, which encapsulates methods responsible for keyed state management and theSnapshotable
which tells the system how to snapshot the underlying state.CheckpointStreamFactory A factory for checkpoint output streams, which are used to persist data for checkpoints.FullSnapshotResources ASnapshotResources
to be used with the backend-independentFullSnapshotAsyncWriter
.InputChannelStateHandle Handle
to anInputChannel
state.Keyed Interface for objects that have a key attribute.KeyedStateBackend A keyed state backend provides methods for managing keyed state.KeyedStateCheckpointOutputStream Checkpoint output stream that allows to write raw keyed state in a partitioned way, split into key-groups.KeyedStateHandle Base for the handles of the checkpointed states in keyed streams.KeyExtractorFunction Function to extract a key from a given object.KeyGroupedInternalPriorityQueue This interface exists as (temporary) adapter between the newInternalPriorityQueue
and the old way in which timers are written in a snapshot.KeyGroupRange This class defines a range of key-group indexes.KeyGroupStatePartitionStreamProvider This class provides access to an input stream that contains state data for one key group and the key group id.OperatorStateBackend Interface that combines both, the user facingOperatorStateStore
interface and the system interfaceSnapshotable
.OperatorStateHandle Interface of a state handle for operator state.PriorityComparable Interface for objects that can be compared by priority.PriorityComparator This interface works similar toComparable
and is used to prioritize between two objects.PriorityQueueSetFactory Factory forKeyGroupedInternalPriorityQueue
instances.ResultSubpartitionStateHandle Handle
to aResultSubpartition
state.SnapshotResult 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.SnapshotStrategyRunner A class to execute aSnapshotStrategy
.StateBackend A State Backend defines how the state of a streaming application is stored locally within the cluster.StateBackend.KeyedStateBackendParameters Parameters passed toStateBackend.createKeyedStateBackend(KeyedStateBackendParameters)
.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.StateObject Base of all handles that represent checkpointed state in some form.StateObject.StateObjectSizeStatsCollector Collector for size and location stats from a state object viaStateObject.collectSizeStats(StateObjectSizeStatsCollector)
.StatePartitionStreamProvider This class provides access to input streams that contain data of one state partition of a partitionable state.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.VoidNamespace Singleton placeholder class for state without a namespace. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.streaming.api.operators.co Class Description 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.VoidNamespace Singleton placeholder class for state without a namespace. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.streaming.api.operators.collect Class Description 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).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. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.streaming.api.operators.sorted.state Class Description CheckpointableKeyedStateBackend Interface that combines both, theKeyedStateBackend
interface, which encapsulates methods responsible for keyed state management and theSnapshotable
which tells the system how to snapshot the underlying state.CheckpointStorage CheckpointStorage defines howStateBackend
'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 inCheckpointStorageCoordinatorView
.CheckpointStreamFactory A factory for checkpoint output streams, which are used to persist data for checkpoints.CompletedCheckpointStorageLocation The CompletedCheckpointStorageLocation describes the storage aspect of a completed checkpoint.Keyed Interface for objects that have a key attribute.KeyedStateBackend A keyed state backend provides methods for managing keyed state.KeyedStateBackend.KeySelectionListener Listener is given a callback whenKeyedStateBackend.setCurrentKey(K)
is called (key context changes).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 A function to be applied to all keyed states.KeyedStateHandle Base for the handles of the checkpointed states in keyed streams.KeyGroupedInternalPriorityQueue This interface exists as (temporary) adapter between the newInternalPriorityQueue
and the old way in which timers are written in a snapshot.KeyGroupRange This class defines a range of key-group indexes.KeyGroupStatePartitionStreamProvider This class provides access to an input stream that contains state data for one key group and the key group id.OperatorStateBackend Interface that combines both, the user facingOperatorStateStore
interface and the system interfaceSnapshotable
.PriorityComparable Interface for objects that can be compared by priority.PriorityQueueSetFactory Factory forKeyGroupedInternalPriorityQueue
instances.SavepointResources Savepoint resources for aKeyedStateBackend
.Snapshotable Interface for objects that can snapshot its state (state backends currently).SnapshotResult 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.StateBackend A State Backend defines how the state of a streaming application is stored locally within the cluster.StateBackend.KeyedStateBackendParameters Parameters passed toStateBackend.createKeyedStateBackend(KeyedStateBackendParameters)
.StateBackend.OperatorStateBackendParameters Parameters passed toStateBackend.createOperatorStateBackend(OperatorStateBackendParameters)
.StateSnapshotTransformer.StateSnapshotTransformFactory This factory creates state transformers depending on the form of values to transform. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.streaming.runtime.operators.sink Class Description 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.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. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.streaming.runtime.operators.windowing Class Description DefaultKeyedStateStore Default implementation of KeyedStateStore that currently forwards state registration to aRuntimeContext
.KeyedStateBackend A keyed state backend provides methods for managing keyed state. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.streaming.runtime.tasks Class Description CheckpointStorage CheckpointStorage defines howStateBackend
's store their state for fault tolerance in streaming applications.CheckpointStorageWorkerView This interface implements the durable storage of checkpoint data and metadata streams.CheckpointStreamFactory A factory for checkpoint output streams, which are used to persist data for checkpoints.StateBackend A State Backend defines how the state of a streaming application is stored locally within the cluster. -
Classes in org.apache.flink.runtime.state used by org.apache.flink.streaming.util.functions Class Description OperatorStateBackend Interface that combines both, the user facingOperatorStateStore
interface and the system interfaceSnapshotable
.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.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.