Uses of Interface
org.apache.flink.runtime.state.KeyedStateHandle
-
Packages that use KeyedStateHandle Package Description org.apache.flink.runtime.checkpoint org.apache.flink.runtime.checkpoint.metadata org.apache.flink.runtime.state org.apache.flink.runtime.state.changelog org.apache.flink.runtime.state.changelog.inmemory org.apache.flink.runtime.state.heap This package contains the classes for key/value state backends that store the state on the JVM heap as objects.org.apache.flink.runtime.state.restore org.apache.flink.runtime.state.v2.adaptor org.apache.flink.streaming.api.operators org.apache.flink.streaming.api.operators.sorted.state -
-
Uses of KeyedStateHandle in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return KeyedStateHandle Modifier and Type Method Description KeyedStateHandle
SubtaskState. getManagedKeyedState()
Deprecated.KeyedStateHandle
SubtaskState. getRawKeyedState()
Deprecated.Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type KeyedStateHandle Modifier and Type Method Description StateObjectCollection<KeyedStateHandle>
PrioritizedOperatorSubtaskState. getJobManagerManagedKeyedState()
Returns the managed keyed state from the job manager, which represents the ground truth about what this state should represent.StateObjectCollection<KeyedStateHandle>
PrioritizedOperatorSubtaskState. getJobManagerRawKeyedState()
Returns the raw keyed state from the job manager, which represents the ground truth about what this state should represent.StateObjectCollection<KeyedStateHandle>
OperatorSubtaskState. getManagedKeyedState()
static List<KeyedStateHandle>
StateAssignmentOperation. getManagedKeyedStateHandles(OperatorState operatorState, KeyGroupRange subtaskKeyGroupRange)
CollectmanagedKeyedStateHandles
which have intersection with givenKeyGroupRange
fromoperatorState
.List<StateObjectCollection<KeyedStateHandle>>
PrioritizedOperatorSubtaskState. getPrioritizedManagedKeyedState()
Returns an immutable list with all alternative snapshots to restore the managed keyed state, in the order in which we should attempt to restore.List<StateObjectCollection<KeyedStateHandle>>
PrioritizedOperatorSubtaskState. getPrioritizedRawKeyedState()
Returns an immutable list with all alternative snapshots to restore the raw keyed state, in the order in which we should attempt to restore.StateObjectCollection<KeyedStateHandle>
OperatorSubtaskState. getRawKeyedState()
static List<KeyedStateHandle>
StateAssignmentOperation. getRawKeyedStateHandles(OperatorState operatorState, KeyGroupRange subtaskKeyGroupRange)
Methods in org.apache.flink.runtime.checkpoint with parameters of type KeyedStateHandle Modifier and Type Method Description OperatorSubtaskState.Builder
OperatorSubtaskState.Builder. setManagedKeyedState(KeyedStateHandle managedKeyedState)
OperatorSubtaskState.Builder
OperatorSubtaskState.Builder. setRawKeyedState(KeyedStateHandle rawKeyedState)
Method parameters in org.apache.flink.runtime.checkpoint with type arguments of type KeyedStateHandle Modifier and Type Method Description static void
StateAssignmentOperation. extractIntersectingState(Collection<? extends KeyedStateHandle> originalSubtaskStateHandles, KeyGroupRange rangeToExtract, List<KeyedStateHandle> extractedStateCollector)
Extracts certain key group ranges from the given state handles and adds them to the collector.static void
StateAssignmentOperation. extractIntersectingState(Collection<? extends KeyedStateHandle> originalSubtaskStateHandles, KeyGroupRange rangeToExtract, List<KeyedStateHandle> extractedStateCollector)
Extracts certain key group ranges from the given state handles and adds them to the collector.OperatorSubtaskState.Builder
OperatorSubtaskState.Builder. setManagedKeyedState(StateObjectCollection<KeyedStateHandle> managedKeyedState)
OperatorSubtaskState.Builder
OperatorSubtaskState.Builder. setRawKeyedState(StateObjectCollection<KeyedStateHandle> rawKeyedState)
Constructors in org.apache.flink.runtime.checkpoint with parameters of type KeyedStateHandle Constructor Description SubtaskState(ChainedStateHandle<OperatorStateHandle> managedOperatorState, ChainedStateHandle<OperatorStateHandle> rawOperatorState, KeyedStateHandle managedKeyedState, KeyedStateHandle rawKeyedState)
Deprecated. -
Uses of KeyedStateHandle in org.apache.flink.runtime.checkpoint.metadata
Methods in org.apache.flink.runtime.checkpoint.metadata that return KeyedStateHandle Modifier and Type Method Description KeyedStateHandle
MetadataV3Serializer. deserializeKeyedStateHandleUtil(DataInputStream dis)
Methods in org.apache.flink.runtime.checkpoint.metadata with parameters of type KeyedStateHandle Modifier and Type Method Description void
MetadataV3Serializer. serializeKeyedStateHandleUtil(KeyedStateHandle stateHandle, DataOutputStream dos)
-
Uses of KeyedStateHandle in org.apache.flink.runtime.state
Subinterfaces of KeyedStateHandle in org.apache.flink.runtime.state Modifier and Type Interface Description interface
CheckpointBoundKeyedStateHandle
KeyedStateHandle
that is bound to a specific checkpoint.interface
IncrementalKeyedStateHandle
Common interface to all incrementalKeyedStateHandle
.interface
SavepointKeyedStateHandle
AKeyedStateHandle
that points to a savepoint taken in the unified format.Classes in org.apache.flink.runtime.state that implement KeyedStateHandle Modifier and Type Class Description class
AbstractIncrementalStateHandle
Abstract superclass for allIncrementalKeyedStateHandle
.class
IncrementalLocalKeyedStateHandle
State handle for local copies ofIncrementalRemoteKeyedStateHandle
.class
IncrementalRemoteKeyedStateHandle
The handle to states of an incremental snapshot.class
KeyGroupsSavepointStateHandle
AKeyGroupsStateHandle
that describes a savepoint in the unified format.class
KeyGroupsStateHandle
A handle to the partitioned stream operator state after it has been checkpointed.Fields in org.apache.flink.runtime.state with type parameters of type KeyedStateHandle Modifier and Type Field Description protected RunnableFuture<SnapshotResult<KeyedStateHandle>>
StateSnapshotContextSynchronousImpl. keyedStateCheckpointClosingFuture
protected Collection<KeyedStateHandle>
AbstractKeyedStateBackendBuilder. restoreStateHandles
Methods in org.apache.flink.runtime.state that return KeyedStateHandle Modifier and Type Method Description KeyedStateHandle
CheckpointStreamWithResultProvider.KeyedStateHandleFactory. create(KeyGroupRangeOffsets keyGroupRangeOffsets, StreamStateHandle streamStateHandle)
KeyedStateHandle
AbstractIncrementalStateHandle. getIntersection(KeyGroupRange keyGroupRange)
KeyedStateHandle
KeyedStateHandle. getIntersection(KeyGroupRange keyGroupRange)
Returns a state over a range that is the intersection between this handle's key-group range and the provided key-group range.Methods in org.apache.flink.runtime.state that return types with arguments of type KeyedStateHandle Modifier and Type Method Description SnapshotStrategy.SnapshotResultSupplier<KeyedStateHandle>
SavepointSnapshotStrategy. asyncSnapshot(FullSnapshotResources<K> savepointResources, long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
SnapshotResult<KeyedStateHandle>
FullSnapshotAsyncWriter. get(org.apache.flink.core.fs.CloseableRegistry snapshotCloseableRegistry)
RunnableFuture<SnapshotResult<KeyedStateHandle>>
StateSnapshotContextSynchronousImpl. getKeyedStateStreamFuture()
Collection<KeyedStateHandle>
KeyedStateBackendParametersImpl. getStateHandles()
Collection<KeyedStateHandle>
StateBackend.KeyedStateBackendParameters. getStateHandles()
static SnapshotResult<KeyedStateHandle>
CheckpointStreamWithResultProvider. toKeyedStateHandleSnapshotResult(SnapshotResult<StreamStateHandle> snapshotResult, KeyGroupRangeOffsets keyGroupRangeOffsets, CheckpointStreamWithResultProvider.KeyedStateHandleFactory stateHandleFactory)
Helper method that takes aSnapshotResult
and aKeyGroupRangeOffsets
and creates aSnapshotResult
by combining the key groups offsets with all the present stream state handles.Method parameters in org.apache.flink.runtime.state with type arguments of type KeyedStateHandle Modifier and Type Method Description static StateBackend
StateBackendLoader. loadStateBackendFromKeyedStateHandles(StateBackend originalStateBackend, ClassLoader classLoader, Collection<KeyedStateHandle> keyedStateHandles)
Load state backend which may wrap the original state backend for recovery.KeyedStateBackendParametersImpl<K>
KeyedStateBackendParametersImpl. setStateHandles(Collection<KeyedStateHandle> stateHandles)
Constructor parameters in org.apache.flink.runtime.state with type arguments of type KeyedStateHandle Constructor Description AbstractKeyedStateBackendBuilder(TaskKvStateRegistry kvStateRegistry, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, ClassLoader userCodeClassLoader, int numberOfKeyGroups, KeyGroupRange keyGroupRange, org.apache.flink.api.common.ExecutionConfig executionConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, SizeTrackingStateConfig sizeTrackingStateConfig, Collection<KeyedStateHandle> stateHandles, StreamCompressionDecorator keyGroupCompressionDecorator, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry)
KeyedStateBackendParametersImpl(Environment env, org.apache.flink.api.common.JobID jobID, String operatorIdentifier, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, int numberOfKeyGroups, KeyGroupRange keyGroupRange, TaskKvStateRegistry kvStateRegistry, TtlTimeProvider ttlTimeProvider, org.apache.flink.metrics.MetricGroup metricGroup, Collection<KeyedStateHandle> stateHandles, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry)
KeyedStateBackendParametersImpl(Environment env, org.apache.flink.api.common.JobID jobID, String operatorIdentifier, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, int numberOfKeyGroups, KeyGroupRange keyGroupRange, TaskKvStateRegistry kvStateRegistry, TtlTimeProvider ttlTimeProvider, org.apache.flink.metrics.MetricGroup metricGroup, StateBackend.CustomInitializationMetrics customInitializationMetrics, Collection<KeyedStateHandle> stateHandles, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry, double managedMemoryFraction)
-
Uses of KeyedStateHandle in org.apache.flink.runtime.state.changelog
Subinterfaces of KeyedStateHandle in org.apache.flink.runtime.state.changelog Modifier and Type Interface Description interface
ChangelogStateBackendHandle
A handle to ChangelogStateBackend state.interface
ChangelogStateHandle
A handle to savedstate changes
.Classes in org.apache.flink.runtime.state.changelog that implement KeyedStateHandle Modifier and Type Class Description static class
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
class
ChangelogStateBackendLocalHandle
State handle for local copies ofChangelogStateHandleStreamImpl
.class
ChangelogStateHandleStreamImpl
ChangelogStateHandle
implementation based onStreamStateHandle
.Methods in org.apache.flink.runtime.state.changelog that return KeyedStateHandle Modifier and Type Method Description KeyedStateHandle
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl. getIntersection(KeyGroupRange keyGroupRange)
KeyedStateHandle
ChangelogStateBackendLocalHandle. getIntersection(KeyGroupRange keyGroupRange)
KeyedStateHandle
ChangelogStateHandleStreamImpl. getIntersection(KeyGroupRange keyGroupRange)
Methods in org.apache.flink.runtime.state.changelog that return types with arguments of type KeyedStateHandle Modifier and Type Method Description List<KeyedStateHandle>
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl. getMaterializedStateHandles()
List<KeyedStateHandle>
ChangelogStateBackendHandle. getMaterializedStateHandles()
List<KeyedStateHandle>
ChangelogStateBackendLocalHandle. getMaterializedStateHandles()
List<KeyedStateHandle>
ChangelogStateBackendLocalHandle. getRemoteMaterializedStateHandles()
Methods in org.apache.flink.runtime.state.changelog with parameters of type KeyedStateHandle Modifier and Type Method Description static ChangelogStateBackendHandle
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl. getChangelogStateBackendHandle(KeyedStateHandle originKeyedStateHandle)
Method parameters in org.apache.flink.runtime.state.changelog with type arguments of type KeyedStateHandle Modifier and Type Method Description static ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl. restore(List<KeyedStateHandle> materialized, List<ChangelogStateHandle> nonMaterialized, KeyGroupRange keyGroupRange, long checkpointId, long materializationID, long persistedSizeOfThisCheckpoint, StateHandleID stateHandleId)
Constructor parameters in org.apache.flink.runtime.state.changelog with type arguments of type KeyedStateHandle Constructor Description ChangelogStateBackendHandleImpl(List<KeyedStateHandle> materialized, List<ChangelogStateHandle> nonMaterialized, KeyGroupRange keyGroupRange, long checkpointId, long materializationID, long persistedSizeOfThisCheckpoint)
ChangelogStateBackendLocalHandle(List<KeyedStateHandle> localMaterialized, List<ChangelogStateHandle> localNonMaterialized, ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl remoteHandle)
-
Uses of KeyedStateHandle in org.apache.flink.runtime.state.changelog.inmemory
Classes in org.apache.flink.runtime.state.changelog.inmemory that implement KeyedStateHandle Modifier and Type Class Description class
InMemoryChangelogStateHandle
In-memoryChangelogStateHandle
.Methods in org.apache.flink.runtime.state.changelog.inmemory that return KeyedStateHandle Modifier and Type Method Description KeyedStateHandle
InMemoryChangelogStateHandle. getIntersection(KeyGroupRange keyGroupRange)
-
Uses of KeyedStateHandle in org.apache.flink.runtime.state.heap
Methods in org.apache.flink.runtime.state.heap that return types with arguments of type KeyedStateHandle Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
HeapKeyedStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
Constructor parameters in org.apache.flink.runtime.state.heap with type arguments of type KeyedStateHandle Constructor Description HeapKeyedStateBackendBuilder(TaskKvStateRegistry kvStateRegistry, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, ClassLoader userCodeClassLoader, int numberOfKeyGroups, KeyGroupRange keyGroupRange, org.apache.flink.api.common.ExecutionConfig executionConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, SizeTrackingStateConfig sizeTrackingStateConfig, Collection<KeyedStateHandle> stateHandles, StreamCompressionDecorator keyGroupCompressionDecorator, LocalRecoveryConfig localRecoveryConfig, HeapPriorityQueueSetFactory priorityQueueSetFactory, boolean asynchronousSnapshots, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry)
-
Uses of KeyedStateHandle in org.apache.flink.runtime.state.restore
Constructor parameters in org.apache.flink.runtime.state.restore with type arguments of type KeyedStateHandle Constructor Description FullSnapshotRestoreOperation(KeyGroupRange keyGroupRange, ClassLoader userCodeClassLoader, Collection<KeyedStateHandle> restoreStateHandles, StateSerializerProvider<K> keySerializerProvider)
-
Uses of KeyedStateHandle in org.apache.flink.runtime.state.v2.adaptor
Methods in org.apache.flink.runtime.state.v2.adaptor that return types with arguments of type KeyedStateHandle Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
AsyncKeyedStateBackendAdaptor. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
-
Uses of KeyedStateHandle in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return types with arguments of type KeyedStateHandle Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
OperatorSnapshotFutures. getKeyedStateManagedFuture()
RunnableFuture<SnapshotResult<KeyedStateHandle>>
OperatorSnapshotFutures. getKeyedStateRawFuture()
static SnapshotStrategyRunner<KeyedStateHandle,? extends FullSnapshotResources<?>>
StreamOperatorStateHandler. prepareCanonicalSavepoint(CheckpointableKeyedStateBackend<?> keyedStateBackend, org.apache.flink.core.fs.CloseableRegistry closeableRegistry)
Method parameters in org.apache.flink.streaming.api.operators with type arguments of type KeyedStateHandle Modifier and Type Method Description protected org.apache.flink.util.CloseableIterable<KeyGroupStatePartitionStreamProvider>
StreamTaskStateInitializerImpl. rawKeyedStateInputs(Iterator<StateObjectCollection<KeyedStateHandle>> restoreStateAlternatives, StateObject.StateObjectSizeStatsCollector statsCollector)
void
OperatorSnapshotFutures. setKeyedStateManagedFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateManagedFuture)
void
OperatorSnapshotFutures. setKeyedStateRawFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateRawFuture)
Constructor parameters in org.apache.flink.streaming.api.operators with type arguments of type KeyedStateHandle Constructor Description OperatorSnapshotFutures(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateManagedFuture, RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateRawFuture, RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateManagedFuture, RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateRawFuture, Future<SnapshotResult<StateObjectCollection<InputStateHandle>>> inputChannelStateFuture, Future<SnapshotResult<StateObjectCollection<OutputStateHandle>>> resultSubpartitionStateFuture)
-
Uses of KeyedStateHandle in org.apache.flink.streaming.api.operators.sorted.state
Methods in org.apache.flink.streaming.api.operators.sorted.state that return types with arguments of type KeyedStateHandle Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
BatchExecutionKeyedStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
-