Modifier and Type | Method and Description |
---|---|
CompletedCheckpointStore |
KubernetesCheckpointRecoveryFactory.createCheckpointStore(JobID jobID,
int maxNumberOfCheckpointsToRetain,
ClassLoader userClassLoader) |
Modifier and Type | Method and Description |
---|---|
static CompletedCheckpointStore |
KubernetesUtils.createCompletedCheckpointStore(Configuration configuration,
FlinkKubeClient kubeClient,
Executor executor,
String configMapName,
String lockIdentity,
int maxNumberOfCheckpointsToRetain)
Create a
DefaultCompletedCheckpointStore with KubernetesStateHandleStore . |
Modifier and Type | Class and Description |
---|---|
class |
DefaultCompletedCheckpointStore<R extends ResourceVersion<R>>
Default implementation of
CompletedCheckpointStore . |
class |
EmbeddedCompletedCheckpointStore
An embedded in-memory checkpoint store, which supports shutdown and suspend.
|
class |
StandaloneCompletedCheckpointStore
CompletedCheckpointStore for JobManagers running in HighAvailabilityMode.NONE . |
Modifier and Type | Method and Description |
---|---|
CompletedCheckpointStore |
ZooKeeperCheckpointRecoveryFactory.createCheckpointStore(JobID jobId,
int maxNumberOfCheckpointsToRetain,
ClassLoader userClassLoader) |
CompletedCheckpointStore |
StandaloneCheckpointRecoveryFactory.createCheckpointStore(JobID jobId,
int maxNumberOfCheckpointsToRetain,
ClassLoader userClassLoader) |
CompletedCheckpointStore |
PerJobCheckpointRecoveryFactory.createCheckpointStore(JobID jobId,
int maxNumberOfCheckpointsToRetain,
ClassLoader userClassLoader) |
CompletedCheckpointStore |
CheckpointRecoveryFactory.createCheckpointStore(JobID jobId,
int maxNumberOfCheckpointsToRetain,
ClassLoader userClassLoader)
Creates a
CompletedCheckpointStore instance for a job. |
CompletedCheckpointStore |
CheckpointCoordinator.getCheckpointStore() |
static CompletedCheckpointStore |
CompletedCheckpointStore.storeFor(Runnable postCleanupAction,
CompletedCheckpoint... checkpoints) |
Modifier and Type | Method and Description |
---|---|
static CheckpointRecoveryFactory |
PerJobCheckpointRecoveryFactory.useSameServicesForAllJobs(CompletedCheckpointStore store,
CheckpointIDCounter counter) |
Constructor and Description |
---|
PerJobCheckpointRecoveryFactory(java.util.function.Function<Integer,CompletedCheckpointStore> completedCheckpointStorePerJobFactory,
java.util.function.Supplier<CheckpointIDCounter> checkpointIDCounterPerJobFactory) |
Modifier and Type | Method and Description |
---|---|
void |
ExecutionGraph.enableCheckpointing(CheckpointCoordinatorConfiguration chkConfig,
List<ExecutionJobVertex> verticesToTrigger,
List<ExecutionJobVertex> verticesToWaitFor,
List<ExecutionJobVertex> verticesToCommitTo,
List<MasterTriggerRestoreHook<?>> masterHooks,
CheckpointIDCounter checkpointIDCounter,
CompletedCheckpointStore checkpointStore,
StateBackend checkpointStateBackend,
CheckpointStatsTracker statsTracker) |
Modifier and Type | Method and Description |
---|---|
static CompletedCheckpointStore |
ZooKeeperUtils.createCompletedCheckpoints(org.apache.flink.shaded.curator4.org.apache.curator.framework.CuratorFramework client,
Configuration configuration,
JobID jobId,
int maxNumberOfCheckpointsToRetain,
Executor executor)
Creates a
DefaultCompletedCheckpointStore instance with ZooKeeperStateHandleStore . |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.