Uses of Interface
org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
-
Packages that use CheckpointStatsTracker Package Description org.apache.flink.runtime.checkpoint org.apache.flink.runtime.executiongraph org.apache.flink.runtime.scheduler -
-
Uses of CheckpointStatsTracker in org.apache.flink.runtime.checkpoint
Classes in org.apache.flink.runtime.checkpoint that implement CheckpointStatsTracker Modifier and Type Class Description class
DefaultCheckpointStatsTracker
class
NoOpCheckpointStatsTracker
Methods in org.apache.flink.runtime.checkpoint with parameters of type CheckpointStatsTracker Modifier and Type Method Description void
PendingCheckpoint. abort(CheckpointFailureReason reason, Throwable cause, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup, Executor executor, CheckpointStatsTracker statsTracker)
Aborts a checkpoint with reason and cause.void
CheckpointFailureManager. handleCheckpointException(PendingCheckpoint pendingCheckpoint, CheckpointProperties checkpointProperties, CheckpointException exception, ExecutionAttemptID executionAttemptID, JobID job, PendingCheckpointStats pendingCheckpointStats, CheckpointStatsTracker statsTracker)
Failures on JM: all checkpoints - go against failure counter. -
Uses of CheckpointStatsTracker in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph with parameters of type CheckpointStatsTracker Modifier and Type Method Description static DefaultExecutionGraph
DefaultExecutionGraphBuilder. buildGraph(JobGraph jobGraph, 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)
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 CheckpointStatsTracker in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return CheckpointStatsTracker Modifier and Type Method Description static CheckpointStatsTracker
SchedulerUtils. createCheckpointStatsTrackerIfCheckpointingIsEnabled(JobGraph jobGraph, Supplier<CheckpointStatsTracker> checkpointStatsTrackerFactory)
Methods in org.apache.flink.runtime.scheduler with parameters of type CheckpointStatsTracker 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, 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, org.slf4j.Logger log)
Create and restoreExecutionGraph
from the givenJobGraph
and services.Method parameters in org.apache.flink.runtime.scheduler with type arguments of type CheckpointStatsTracker Modifier and Type Method Description static CheckpointStatsTracker
SchedulerUtils. createCheckpointStatsTrackerIfCheckpointingIsEnabled(JobGraph jobGraph, Supplier<CheckpointStatsTracker> checkpointStatsTrackerFactory)
-