Uses of Interface
org.apache.flink.runtime.state.SharedStateRegistry
-
-
Uses of SharedStateRegistry in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return SharedStateRegistry Modifier and Type Method Description SharedStateRegistry
AbstractCompleteCheckpointStore. getSharedStateRegistry()
SharedStateRegistry
CompletedCheckpointStore. getSharedStateRegistry()
Returns theSharedStateRegistry
used to register the shared state.SharedStateRegistry
DeactivatedCheckpointCompletedCheckpointStore. getSharedStateRegistry()
Methods in org.apache.flink.runtime.checkpoint with parameters of type SharedStateRegistry Modifier and Type Method Description void
OperatorState. registerSharedStates(SharedStateRegistry sharedStateRegistry, long checkpointID)
void
OperatorSubtaskState. registerSharedStates(SharedStateRegistry sharedStateRegistry, long checkpointID)
void
SubtaskState. registerSharedStates(SharedStateRegistry sharedStateRegistry, long checkpointID)
Deprecated.void
TaskState. registerSharedStates(SharedStateRegistry sharedStateRegistry, long checkpointID)
Deprecated.void
TaskStateSnapshot. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)
void
CompletedCheckpoint. registerSharedStatesAfterRestored(SharedStateRegistry sharedStateRegistry, org.apache.flink.core.execution.RecoveryClaimMode recoveryClaimMode)
Register all shared states in the given registry.Constructors in org.apache.flink.runtime.checkpoint with parameters of type SharedStateRegistry Constructor Description AbstractCompleteCheckpointStore(SharedStateRegistry sharedStateRegistry)
DefaultCompletedCheckpointStore(int maxNumberOfCheckpointsToRetain, StateHandleStore<CompletedCheckpoint,R> stateHandleStore, CheckpointStoreUtil completedCheckpointStoreUtil, Collection<CompletedCheckpoint> completedCheckpoints, SharedStateRegistry sharedStateRegistry, Executor executor)
Creates aDefaultCompletedCheckpointStore
instance.EmbeddedCompletedCheckpointStore(int maxRetainedCheckpoints, Collection<CompletedCheckpoint> initialCheckpoints, SharedStateRegistry sharedStateRegistry)
-
Uses of SharedStateRegistry in org.apache.flink.runtime.state
Classes in org.apache.flink.runtime.state that implement SharedStateRegistry Modifier and Type Class Description class
SharedStateRegistryImpl
SharedStateRegistry
implementation.Methods in org.apache.flink.runtime.state that return SharedStateRegistry Modifier and Type Method Description SharedStateRegistry
SharedStateRegistryFactory. create(Executor deleteExecutor, Collection<CompletedCheckpoint> checkpoints, org.apache.flink.core.execution.RecoveryClaimMode recoveryClaimMode)
Factory method forSharedStateRegistry
.SharedStateRegistry
IncrementalRemoteKeyedStateHandle. getSharedStateRegistry()
Methods in org.apache.flink.runtime.state with parameters of type SharedStateRegistry Modifier and Type Method Description void
CompositeStateHandle. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)
Register both newly created and already referenced shared states in the givenSharedStateRegistry
.void
IncrementalLocalKeyedStateHandle. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)
void
IncrementalRemoteKeyedStateHandle. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)
void
KeyGroupsStateHandle. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)
-
Uses of SharedStateRegistry in org.apache.flink.runtime.state.changelog
Methods in org.apache.flink.runtime.state.changelog with parameters of type SharedStateRegistry Modifier and Type Method Description void
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)
void
ChangelogStateBackendLocalHandle. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)
void
ChangelogStateHandleStreamImpl. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)
-
Uses of SharedStateRegistry in org.apache.flink.runtime.state.changelog.inmemory
Methods in org.apache.flink.runtime.state.changelog.inmemory with parameters of type SharedStateRegistry Modifier and Type Method Description void
InMemoryChangelogStateHandle. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)
-
Uses of SharedStateRegistry in org.apache.flink.runtime.state.filemerging
Methods in org.apache.flink.runtime.state.filemerging with parameters of type SharedStateRegistry Modifier and Type Method Description void
FileMergingOperatorStreamStateHandle. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointId)
-