Uses of Interface
org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
Packages that use CompletedCheckpointStore Package Description org.apache.flink.runtime.checkpoint org.apache.flink.runtime.executiongraph org.apache.flink.runtime.scheduler org.apache.flink.runtime.util -
-
Uses of CompletedCheckpointStore in org.apache.flink.runtime.checkpoint
Classes in org.apache.flink.runtime.checkpoint with type parameters of type CompletedCheckpointStore Modifier and Type Class Description class
PerJobCheckpointRecoveryFactory<T extends CompletedCheckpointStore>
SimpleCheckpointRecoveryFactory
which creates and keeps separateCompletedCheckpointStore
andCheckpointIDCounter
for eachJobID
.static interface
PerJobCheckpointRecoveryFactory.CheckpointStoreRecoveryHelper<StoreType extends CompletedCheckpointStore>
Restores or creates aCompletedCheckpointStore
, optionally using an existing one.Classes in org.apache.flink.runtime.checkpoint that implement CompletedCheckpointStore Modifier and Type Class Description class
AbstractCompleteCheckpointStore
The abstract class ofCompletedCheckpointStore
, which holds theSharedStateRegistry
and provides the registration of shared state.class
DeactivatedCheckpointCompletedCheckpointStore
This class represents aCompletedCheckpointStore
if checkpointing has been disabled.class
DefaultCompletedCheckpointStore<R extends ResourceVersion<R>>
Default implementation ofCompletedCheckpointStore
.class
EmbeddedCompletedCheckpointStore
An embedded in-memory checkpoint store, which supports shutdown and suspend.class
StandaloneCompletedCheckpointStore
CompletedCheckpointStore
for JobManagers running inHighAvailabilityMode.NONE
.Methods in org.apache.flink.runtime.checkpoint with type parameters of type CompletedCheckpointStore Modifier and Type Method Description static <T extends CompletedCheckpointStore>
CheckpointRecoveryFactoryPerJobCheckpointRecoveryFactory. withoutCheckpointStoreRecovery(IntFunction<T> storeFn)
Methods in org.apache.flink.runtime.checkpoint that return CompletedCheckpointStore 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)
CompletedCheckpointStore
CheckpointCoordinator. getCheckpointStore()
Constructors in org.apache.flink.runtime.checkpoint with parameters of type CompletedCheckpointStore Constructor Description CheckpointCoordinator(org.apache.flink.api.common.JobID job, CheckpointCoordinatorConfiguration chkConfig, Collection<OperatorCoordinatorCheckpointContext> coordinatorsToCheckpoint, CheckpointIDCounter checkpointIDCounter, CompletedCheckpointStore completedCheckpointStore, CheckpointStorage checkpointStorage, Executor executor, CheckpointsCleaner checkpointsCleaner, org.apache.flink.util.concurrent.ScheduledExecutor timer, CheckpointFailureManager failureManager, CheckpointPlanCalculator checkpointPlanCalculator, CheckpointStatsTracker statsTracker)
CheckpointCoordinator(org.apache.flink.api.common.JobID job, CheckpointCoordinatorConfiguration chkConfig, Collection<OperatorCoordinatorCheckpointContext> coordinatorsToCheckpoint, CheckpointIDCounter checkpointIDCounter, CompletedCheckpointStore completedCheckpointStore, CheckpointStorage checkpointStorage, Executor executor, CheckpointsCleaner checkpointsCleaner, org.apache.flink.util.concurrent.ScheduledExecutor timer, CheckpointFailureManager failureManager, CheckpointPlanCalculator checkpointPlanCalculator, org.apache.flink.util.clock.Clock clock, CheckpointStatsTracker statsTracker, BiFunction<Set<ExecutionJobVertex>,Map<OperatorID,OperatorState>,VertexFinishedStateChecker> vertexFinishedStateCheckerFactory)
-
Uses of CompletedCheckpointStore in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph with parameters of type CompletedCheckpointStore Modifier and Type Method Description static DefaultExecutionGraph
DefaultExecutionGraphBuilder. buildGraph(JobGraph jobGraph, org.apache.flink.configuration.Configuration jobManagerConfig, ScheduledExecutorService futureExecutor, Executor ioExecutor, ClassLoader classLoader, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, Duration rpcTimeout, BlobWriter blobWriter, org.slf4j.Logger log, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, ExecutionDeploymentListener executionDeploymentListener, ExecutionStateUpdateListener executionStateUpdateListener, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, CheckpointStatsTracker checkpointStatsTracker, boolean isDynamicGraph, ExecutionJobVertex.Factory executionJobVertexFactory, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, boolean nonFinishedHybridPartitionShouldBeUnknown, JobManagerJobMetricGroup jobManagerJobMetricGroup, ExecutionPlanSchedulingContext executionPlanSchedulingContext)
void
DefaultExecutionGraph. enableCheckpointing(CheckpointCoordinatorConfiguration chkConfig, List<MasterTriggerRestoreHook<?>> masterHooks, CheckpointIDCounter checkpointIDCounter, CompletedCheckpointStore checkpointStore, StateBackend checkpointStateBackend, CheckpointStorage checkpointStorage, CheckpointStatsTracker statsTracker, CheckpointsCleaner checkpointsCleaner, String changelogStorageName)
void
ExecutionGraph. enableCheckpointing(CheckpointCoordinatorConfiguration chkConfig, List<MasterTriggerRestoreHook<?>> masterHooks, CheckpointIDCounter checkpointIDCounter, CompletedCheckpointStore checkpointStore, StateBackend checkpointStateBackend, CheckpointStorage checkpointStorage, CheckpointStatsTracker statsTracker, CheckpointsCleaner checkpointsCleaner, String changelogStorage)
-
Uses of CompletedCheckpointStore in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return CompletedCheckpointStore Modifier and Type Method Description static CompletedCheckpointStore
SchedulerUtils. createCompletedCheckpointStoreIfCheckpointingIsEnabled(JobGraph jobGraph, org.apache.flink.configuration.Configuration configuration, CheckpointRecoveryFactory checkpointRecoveryFactory, Executor ioExecutor, org.slf4j.Logger log)
Methods in org.apache.flink.runtime.scheduler with parameters of type CompletedCheckpointStore Modifier and Type Method Description ExecutionGraph
DefaultExecutionGraphFactory. createAndRestoreExecutionGraph(JobGraph jobGraph, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, CheckpointStatsTracker checkpointStatsTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, ExecutionStateUpdateListener executionStateUpdateListener, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, ExecutionPlanSchedulingContext executionPlanSchedulingContext, org.slf4j.Logger log)
ExecutionGraph
ExecutionGraphFactory. createAndRestoreExecutionGraph(JobGraph jobGraph, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, CheckpointStatsTracker checkpointStatsTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, ExecutionStateUpdateListener executionStateUpdateListener, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, ExecutionPlanSchedulingContext executionPlanSchedulingContext, org.slf4j.Logger log)
Create and restoreExecutionGraph
from the givenJobGraph
and services. -
Uses of CompletedCheckpointStore in org.apache.flink.runtime.util
Methods in org.apache.flink.runtime.util that return CompletedCheckpointStore 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
.
-