Uses of Interface
org.apache.flink.runtime.state.SharedStateRegistryFactory
-
-
Uses of SharedStateRegistryFactory in org.apache.flink.kubernetes.highavailability
Methods in org.apache.flink.kubernetes.highavailability with parameters of type SharedStateRegistryFactory Modifier and Type Method Description CompletedCheckpointStore
KubernetesCheckpointRecoveryFactory. createRecoveredCompletedCheckpointStore(JobID jobID, int maxNumberOfCheckpointsToRetain, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, RecoveryClaimMode recoveryClaimMode)
-
Uses of SharedStateRegistryFactory in org.apache.flink.kubernetes.utils
Methods in org.apache.flink.kubernetes.utils with parameters of type SharedStateRegistryFactory Modifier and Type Method Description static CompletedCheckpointStore
KubernetesUtils. createCompletedCheckpointStore(Configuration configuration, FlinkKubeClient kubeClient, Executor executor, String configMapName, String lockIdentity, int maxNumberOfCheckpointsToRetain, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, RecoveryClaimMode recoveryClaimMode)
Create aDefaultCompletedCheckpointStore
withKubernetesStateHandleStore
. -
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(JobID jobId, int maxNumberOfCheckpointsToRetain, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, RecoveryClaimMode recoveryClaimMode)
Creates a RECOVEREDCompletedCheckpointStore
instance for a job.CompletedCheckpointStore
PerJobCheckpointRecoveryFactory. createRecoveredCompletedCheckpointStore(JobID jobId, int maxNumberOfCheckpointsToRetain, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, RecoveryClaimMode recoveryClaimMode)
CompletedCheckpointStore
StandaloneCheckpointRecoveryFactory. createRecoveredCompletedCheckpointStore(JobID jobId, int maxNumberOfCheckpointsToRetain, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, RecoveryClaimMode recoveryClaimMode)
CompletedCheckpointStore
ZooKeeperCheckpointRecoveryFactory. createRecoveredCompletedCheckpointStore(JobID jobId, int maxNumberOfCheckpointsToRetain, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, RecoveryClaimMode recoveryClaimMode)
StoreType
PerJobCheckpointRecoveryFactory.CheckpointStoreRecoveryHelper. recoverCheckpointStore(int maxNumberOfCheckpointsToRetain, StoreType previousStore, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, RecoveryClaimMode recoveryClaimMode)
Constructors in org.apache.flink.runtime.checkpoint with parameters of type SharedStateRegistryFactory Constructor Description StandaloneCompletedCheckpointStore(int maxNumberOfCheckpointsToRetain, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, 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, 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, Configuration configuration, int maxNumberOfCheckpointsToRetain, SharedStateRegistryFactory sharedStateRegistryFactory, Executor ioExecutor, Executor executor, RecoveryClaimMode recoveryClaimMode)
Creates aDefaultCompletedCheckpointStore
instance withZooKeeperStateHandleStore
.
-