Class DefaultCheckpointStatsTracker
- java.lang.Object
-
- org.apache.flink.runtime.checkpoint.DefaultCheckpointStatsTracker
-
- All Implemented Interfaces:
CheckpointStatsTracker
public class DefaultCheckpointStatsTracker extends Object implements CheckpointStatsTracker
-
-
Constructor Summary
Constructors Constructor Description DefaultCheckpointStatsTracker(int numRememberedCheckpoints, JobManagerJobMetricGroup metricGroup)
Creates a new checkpoint stats tracker.DefaultCheckpointStatsTracker(int numRememberedCheckpoints, JobManagerJobMetricGroup metricGroup, CheckpointStatsListener checkpointStatsListener)
Creates a new checkpoint stats tracker.
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description CheckpointStatsSnapshot
createSnapshot()
Creates a new snapshot of the available stats.PendingCheckpointStats
getPendingCheckpointStats(long checkpointId)
void
reportCompletedCheckpoint(CompletedCheckpointStats completed)
Callback when a checkpoint completes.void
reportFailedCheckpoint(FailedCheckpointStats failed)
void
reportFailedCheckpointsWithoutInProgress()
Callback when a checkpoint failure without in progress checkpoint.void
reportIncompleteStats(long checkpointId, ExecutionAttemptID attemptId, CheckpointMetrics metrics)
void
reportInitializationMetrics(ExecutionAttemptID executionAttemptId, SubTaskInitializationMetrics initializationMetrics)
void
reportInitializationStarted(Set<ExecutionAttemptID> toInitialize, long initializationStartTs)
PendingCheckpointStats
reportPendingCheckpoint(long checkpointId, long triggerTimestamp, CheckpointProperties props, Map<JobVertexID,Integer> vertexToDop)
Creates a new pending checkpoint tracker.void
reportRestoredCheckpoint(long checkpointID, CheckpointProperties properties, String externalPath, long stateSize)
-
-
-
Constructor Detail
-
DefaultCheckpointStatsTracker
public DefaultCheckpointStatsTracker(int numRememberedCheckpoints, JobManagerJobMetricGroup metricGroup)
Creates a new checkpoint stats tracker.- Parameters:
numRememberedCheckpoints
- Maximum number of checkpoints to remember, including in progress ones.metricGroup
- Metric group for exposed metrics
-
DefaultCheckpointStatsTracker
public DefaultCheckpointStatsTracker(int numRememberedCheckpoints, JobManagerJobMetricGroup metricGroup, @Nullable CheckpointStatsListener checkpointStatsListener)
Creates a new checkpoint stats tracker.- Parameters:
numRememberedCheckpoints
- Maximum number of checkpoints to remember, including in progress ones.metricGroup
- Metric group for exposed metrics.checkpointStatsListener
- Listener for monitoring checkpoint-related events.
-
-
Method Detail
-
createSnapshot
public CheckpointStatsSnapshot createSnapshot()
Description copied from interface:CheckpointStatsTracker
Creates a new snapshot of the available stats.- Specified by:
createSnapshot
in interfaceCheckpointStatsTracker
- Returns:
- The latest statistics snapshot.
-
reportPendingCheckpoint
public PendingCheckpointStats reportPendingCheckpoint(long checkpointId, long triggerTimestamp, CheckpointProperties props, Map<JobVertexID,Integer> vertexToDop)
Description copied from interface:CheckpointStatsTracker
Creates a new pending checkpoint tracker.- Specified by:
reportPendingCheckpoint
in interfaceCheckpointStatsTracker
- Parameters:
checkpointId
- ID of the checkpoint.triggerTimestamp
- Trigger timestamp of the checkpoint.props
- The checkpoint properties.vertexToDop
- mapping ofJobVertexID
to DOP- Returns:
- Tracker for statistics gathering or
null
if no stats were tracked.
-
reportRestoredCheckpoint
public void reportRestoredCheckpoint(long checkpointID, CheckpointProperties properties, String externalPath, long stateSize)
- Specified by:
reportRestoredCheckpoint
in interfaceCheckpointStatsTracker
-
reportCompletedCheckpoint
public void reportCompletedCheckpoint(CompletedCheckpointStats completed)
Description copied from interface:CheckpointStatsTracker
Callback when a checkpoint completes.- Specified by:
reportCompletedCheckpoint
in interfaceCheckpointStatsTracker
- Parameters:
completed
- The completed checkpoint stats.
-
reportFailedCheckpoint
public void reportFailedCheckpoint(FailedCheckpointStats failed)
- Specified by:
reportFailedCheckpoint
in interfaceCheckpointStatsTracker
-
reportFailedCheckpointsWithoutInProgress
public void reportFailedCheckpointsWithoutInProgress()
Description copied from interface:CheckpointStatsTracker
Callback when a checkpoint failure without in progress checkpoint. For example, it should be callback when triggering checkpoint failure before creating PendingCheckpoint.- Specified by:
reportFailedCheckpointsWithoutInProgress
in interfaceCheckpointStatsTracker
-
getPendingCheckpointStats
public PendingCheckpointStats getPendingCheckpointStats(long checkpointId)
- Specified by:
getPendingCheckpointStats
in interfaceCheckpointStatsTracker
-
reportIncompleteStats
public void reportIncompleteStats(long checkpointId, ExecutionAttemptID attemptId, CheckpointMetrics metrics)
- Specified by:
reportIncompleteStats
in interfaceCheckpointStatsTracker
-
reportInitializationStarted
public void reportInitializationStarted(Set<ExecutionAttemptID> toInitialize, long initializationStartTs)
- Specified by:
reportInitializationStarted
in interfaceCheckpointStatsTracker
-
reportInitializationMetrics
public void reportInitializationMetrics(ExecutionAttemptID executionAttemptId, SubTaskInitializationMetrics initializationMetrics)
- Specified by:
reportInitializationMetrics
in interfaceCheckpointStatsTracker
-
-