Class RpcCheckpointResponder

    • Method Detail

      • acknowledgeCheckpoint

        public void acknowledgeCheckpoint​(org.apache.flink.api.common.JobID jobID,
                                          ExecutionAttemptID executionAttemptID,
                                          long checkpointId,
                                          CheckpointMetrics checkpointMetrics,
                                          TaskStateSnapshot subtaskState)
        Description copied from interface: CheckpointResponder
        Acknowledges the given checkpoint.
        Specified by:
        acknowledgeCheckpoint in interface CheckpointResponder
        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

        public void reportCheckpointMetrics​(org.apache.flink.api.common.JobID jobID,
                                            ExecutionAttemptID executionAttemptID,
                                            long checkpointId,
                                            CheckpointMetrics checkpointMetrics)
        Description copied from interface: CheckpointResponder
        Report metrics for the given checkpoint. Can be used upon receiving abortion notification.
        Specified by:
        reportCheckpointMetrics in interface CheckpointResponder
        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

        public void declineCheckpoint​(org.apache.flink.api.common.JobID jobID,
                                      ExecutionAttemptID executionAttemptID,
                                      long checkpointId,
                                      CheckpointException checkpointException)
        Description copied from interface: CheckpointResponder
        Declines the given checkpoint.
        Specified by:
        declineCheckpoint in interface CheckpointResponder
        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