Interface CheckpointResponder

  • All Known Implementing Classes:
    RpcCheckpointResponder

    @Internal
    public interface CheckpointResponder
    Responder for checkpoint acknowledge and decline messages in the Task.
    • Method Detail

      • acknowledgeCheckpoint

        void acknowledgeCheckpoint​(org.apache.flink.api.common.JobID jobID,
                                   ExecutionAttemptID executionAttemptID,
                                   long checkpointId,
                                   CheckpointMetrics checkpointMetrics,
                                   TaskStateSnapshot subtaskState)
        Acknowledges the given checkpoint.
        Parameters:
        jobID - Job ID of the running job
        executionAttemptID - Execution attempt ID of the running task
        checkpointId - Meta data for this checkpoint
        checkpointMetrics - Metrics of this checkpoint
        subtaskState - State handles for the checkpoint
      • reportCheckpointMetrics

        void reportCheckpointMetrics​(org.apache.flink.api.common.JobID jobID,
                                     ExecutionAttemptID executionAttemptID,
                                     long checkpointId,
                                     CheckpointMetrics checkpointMetrics)
        Report metrics for the given checkpoint. Can be used upon receiving abortion notification.
        Parameters:
        jobID - Job ID of the running job
        executionAttemptID - Execution attempt ID of the running task
        checkpointId - Meta data for this checkpoint
        checkpointMetrics - Metrics of this checkpoint
      • declineCheckpoint

        void declineCheckpoint​(org.apache.flink.api.common.JobID jobID,
                               ExecutionAttemptID executionAttemptID,
                               long checkpointId,
                               CheckpointException checkpointException)
        Declines the given checkpoint.
        Parameters:
        jobID - Job ID of the running job
        executionAttemptID - Execution attempt ID of the running task
        checkpointId - The ID of the declined checkpoint
        checkpointException - The exception why the checkpoint was declined