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 KeyedStateHandleSubtaskState. getManagedKeyedState()Deprecated.KeyedStateHandleSubtaskState. 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)CollectmanagedKeyedStateHandleswhich have intersection with givenKeyGroupRangefromoperatorState.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.BuilderOperatorSubtaskState.Builder. setManagedKeyedState(KeyedStateHandle managedKeyedState)OperatorSubtaskState.BuilderOperatorSubtaskState.Builder. setRawKeyedState(KeyedStateHandle rawKeyedState)Method parameters in org.apache.flink.runtime.checkpoint with type arguments of type KeyedStateHandle Modifier and Type Method Description static voidStateAssignmentOperation. 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 voidStateAssignmentOperation. 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.BuilderOperatorSubtaskState.Builder. setManagedKeyedState(StateObjectCollection<KeyedStateHandle> managedKeyedState)OperatorSubtaskState.BuilderOperatorSubtaskState.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 KeyedStateHandleMetadataV3Serializer. deserializeKeyedStateHandleUtil(DataInputStream dis)Methods in org.apache.flink.runtime.checkpoint.metadata with parameters of type KeyedStateHandle Modifier and Type Method Description voidMetadataV3Serializer. 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 interfaceCheckpointBoundKeyedStateHandleKeyedStateHandlethat is bound to a specific checkpoint.interfaceIncrementalKeyedStateHandleCommon interface to all incrementalKeyedStateHandle.interfaceSavepointKeyedStateHandleAKeyedStateHandlethat points to a savepoint taken in the unified format.Classes in org.apache.flink.runtime.state that implement KeyedStateHandle Modifier and Type Class Description classAbstractIncrementalStateHandleAbstract superclass for allIncrementalKeyedStateHandle.classIncrementalLocalKeyedStateHandleState handle for local copies ofIncrementalRemoteKeyedStateHandle.classIncrementalRemoteKeyedStateHandleThe handle to states of an incremental snapshot.classKeyGroupsSavepointStateHandleAKeyGroupsStateHandlethat describes a savepoint in the unified format.classKeyGroupsStateHandleA 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. keyedStateCheckpointClosingFutureprotected Collection<KeyedStateHandle>AbstractKeyedStateBackendBuilder. restoreStateHandlesMethods in org.apache.flink.runtime.state that return KeyedStateHandle Modifier and Type Method Description KeyedStateHandleCheckpointStreamWithResultProvider.KeyedStateHandleFactory. create(KeyGroupRangeOffsets keyGroupRangeOffsets, StreamStateHandle streamStateHandle)KeyedStateHandleAbstractIncrementalStateHandle. getIntersection(KeyGroupRange keyGroupRange)KeyedStateHandleKeyedStateHandle. 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 aSnapshotResultand aKeyGroupRangeOffsetsand creates aSnapshotResultby 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 StateBackendStateBackendLoader. 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 interfaceChangelogStateBackendHandleA handle to ChangelogStateBackend state.interfaceChangelogStateHandleA handle to savedstate changes.Classes in org.apache.flink.runtime.state.changelog that implement KeyedStateHandle Modifier and Type Class Description static classChangelogStateBackendHandle.ChangelogStateBackendHandleImplclassChangelogStateBackendLocalHandleState handle for local copies ofChangelogStateHandleStreamImpl.classChangelogStateHandleStreamImplChangelogStateHandleimplementation based onStreamStateHandle.Methods in org.apache.flink.runtime.state.changelog that return KeyedStateHandle Modifier and Type Method Description KeyedStateHandleChangelogStateBackendHandle.ChangelogStateBackendHandleImpl. getIntersection(KeyGroupRange keyGroupRange)KeyedStateHandleChangelogStateBackendLocalHandle. getIntersection(KeyGroupRange keyGroupRange)KeyedStateHandleChangelogStateHandleStreamImpl. 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 ChangelogStateBackendHandleChangelogStateBackendHandle.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.ChangelogStateBackendHandleImplChangelogStateBackendHandle.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 classInMemoryChangelogStateHandleIn-memoryChangelogStateHandle.Methods in org.apache.flink.runtime.state.changelog.inmemory that return KeyedStateHandle Modifier and Type Method Description KeyedStateHandleInMemoryChangelogStateHandle. 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)voidOperatorSnapshotFutures. setKeyedStateManagedFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateManagedFuture)voidOperatorSnapshotFutures. 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)
-