Uses of Interface
org.apache.flink.runtime.state.SharedStateRegistryFactory
-
Packages that use SharedStateRegistryFactory Package Description org.apache.flink.runtime.checkpoint org.apache.flink.runtime.dispatcher.cleanup org.apache.flink.runtime.state org.apache.flink.runtime.util -
-
Uses of SharedStateRegistryFactory in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint with parameters of type SharedStateRegistryFactory Modifier and Type Method Description CompletedCheckpointStore
CheckpointRecoveryFactory. createRecoveredCompletedCheckpointStore(org.apache.flink.api.common.JobID jobId, int maxNumberOfCheckpointsToRetain, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, org.apache.flink.core.execution.RecoveryClaimMode recoveryClaimMode)
Creates a RECOVEREDCompletedCheckpointStore
instance for a job.CompletedCheckpointStore
PerJobCheckpointRecoveryFactory. createRecoveredCompletedCheckpointStore(org.apache.flink.api.common.JobID jobId, int maxNumberOfCheckpointsToRetain, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, org.apache.flink.core.execution.RecoveryClaimMode recoveryClaimMode)
CompletedCheckpointStore
StandaloneCheckpointRecoveryFactory. createRecoveredCompletedCheckpointStore(org.apache.flink.api.common.JobID jobId, int maxNumberOfCheckpointsToRetain, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, org.apache.flink.core.execution.RecoveryClaimMode recoveryClaimMode)
CompletedCheckpointStore
ZooKeeperCheckpointRecoveryFactory. createRecoveredCompletedCheckpointStore(org.apache.flink.api.common.JobID jobId, int maxNumberOfCheckpointsToRetain, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, org.apache.flink.core.execution.RecoveryClaimMode recoveryClaimMode)
StoreType
PerJobCheckpointRecoveryFactory.CheckpointStoreRecoveryHelper. recoverCheckpointStore(int maxNumberOfCheckpointsToRetain, StoreType previousStore, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, org.apache.flink.core.execution.RecoveryClaimMode recoveryClaimMode)
Constructors in org.apache.flink.runtime.checkpoint with parameters of type SharedStateRegistryFactory Constructor Description StandaloneCompletedCheckpointStore(int maxNumberOfCheckpointsToRetain, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, org.apache.flink.core.execution.RecoveryClaimMode recoveryClaimMode)
CreatesStandaloneCompletedCheckpointStore
. -
Uses of SharedStateRegistryFactory in org.apache.flink.runtime.dispatcher.cleanup
Constructors in org.apache.flink.runtime.dispatcher.cleanup with parameters of type SharedStateRegistryFactory Constructor Description CheckpointResourcesCleanupRunner(JobResult jobResult, CheckpointRecoveryFactory checkpointRecoveryFactory, SharedStateRegistryFactory sharedStateRegistryFactory, org.apache.flink.configuration.Configuration jobManagerConfiguration, Executor cleanupExecutor, long initializationTimestamp)
-
Uses of SharedStateRegistryFactory in org.apache.flink.runtime.state
Fields in org.apache.flink.runtime.state declared as SharedStateRegistryFactory Modifier and Type Field Description static SharedStateRegistryFactory
SharedStateRegistry. DEFAULT_FACTORY
A singleton object for the default implementation of aSharedStateRegistryFactory
-
Uses of SharedStateRegistryFactory in org.apache.flink.runtime.util
Methods in org.apache.flink.runtime.util with parameters of type SharedStateRegistryFactory Modifier and Type Method Description static CompletedCheckpointStore
ZooKeeperUtils. createCompletedCheckpoints(org.apache.flink.shaded.curator5.org.apache.curator.framework.CuratorFramework client, org.apache.flink.configuration.Configuration configuration, int maxNumberOfCheckpointsToRetain, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, Executor executor, org.apache.flink.core.execution.RecoveryClaimMode recoveryClaimMode)
Creates aDefaultCompletedCheckpointStore
instance withZooKeeperStateHandleStore
.
-