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 SharedStateRegistryAbstractCompleteCheckpointStore. getSharedStateRegistry()SharedStateRegistryCompletedCheckpointStore. getSharedStateRegistry()Returns theSharedStateRegistryused to register the shared state.SharedStateRegistryDeactivatedCheckpointCompletedCheckpointStore. getSharedStateRegistry()Methods in org.apache.flink.runtime.checkpoint with parameters of type SharedStateRegistry Modifier and Type Method Description voidOperatorState. registerSharedStates(SharedStateRegistry sharedStateRegistry, long checkpointID)voidOperatorSubtaskState. registerSharedStates(SharedStateRegistry sharedStateRegistry, long checkpointID)voidSubtaskState. registerSharedStates(SharedStateRegistry sharedStateRegistry, long checkpointID)Deprecated.voidTaskState. registerSharedStates(SharedStateRegistry sharedStateRegistry, long checkpointID)Deprecated.voidTaskStateSnapshot. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)voidCompletedCheckpoint. 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 aDefaultCompletedCheckpointStoreinstance.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 classSharedStateRegistryImplSharedStateRegistryimplementation.Methods in org.apache.flink.runtime.state that return SharedStateRegistry Modifier and Type Method Description SharedStateRegistrySharedStateRegistryFactory. create(Executor deleteExecutor, Collection<CompletedCheckpoint> checkpoints, org.apache.flink.core.execution.RecoveryClaimMode recoveryClaimMode)Factory method forSharedStateRegistry.SharedStateRegistryIncrementalRemoteKeyedStateHandle. getSharedStateRegistry()Methods in org.apache.flink.runtime.state with parameters of type SharedStateRegistry Modifier and Type Method Description voidCompositeStateHandle. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)Register both newly created and already referenced shared states in the givenSharedStateRegistry.voidIncrementalLocalKeyedStateHandle. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)voidIncrementalRemoteKeyedStateHandle. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)voidKeyGroupsStateHandle. 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 voidChangelogStateBackendHandle.ChangelogStateBackendHandleImpl. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)voidChangelogStateBackendLocalHandle. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointID)voidChangelogStateHandleStreamImpl. 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 voidInMemoryChangelogStateHandle. 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 voidFileMergingOperatorStreamStateHandle. registerSharedStates(SharedStateRegistry stateRegistry, long checkpointId)
-