Class RpcTaskManagerGateway

    • Method Detail

      • getAddress

        public String getAddress()
        Description copied from interface: TaskManagerGateway
        Return the address of the task manager with which the gateway is associated.
        Specified by:
        getAddress in interface TaskManagerGateway
        Returns:
        Address of the task manager with which this gateway is associated.
      • releasePartitions

        public void releasePartitions​(org.apache.flink.api.common.JobID jobId,
                                      Set<ResultPartitionID> partitionIds)
        Description copied from interface: TaskManagerGateway
        Batch release intermediate result partitions.
        Specified by:
        releasePartitions in interface TaskManagerGateway
        Parameters:
        jobId - id of the job that the partitions belong to
        partitionIds - partition ids to release
      • notifyCheckpointOnComplete

        public void notifyCheckpointOnComplete​(ExecutionAttemptID executionAttemptID,
                                               org.apache.flink.api.common.JobID jobId,
                                               long completedCheckpointId,
                                               long completedTimestamp,
                                               long lastSubsumedCheckpointId)
        Description copied from interface: TaskManagerGateway
        Notify the given task about a completed checkpoint and the last subsumed checkpoint id if possible.
        Specified by:
        notifyCheckpointOnComplete in interface TaskManagerGateway
        Parameters:
        executionAttemptID - identifying the task
        jobId - identifying the job to which the task belongs
        completedCheckpointId - of the completed checkpoint
        completedTimestamp - of the completed checkpoint
        lastSubsumedCheckpointId - of the last subsumed checkpoint id,
      • notifyCheckpointAborted

        public void notifyCheckpointAborted​(ExecutionAttemptID executionAttemptID,
                                            org.apache.flink.api.common.JobID jobId,
                                            long checkpointId,
                                            long latestCompletedCheckpointId,
                                            long timestamp)
        Description copied from interface: TaskManagerGateway
        Notify the given task about a aborted checkpoint.
        Specified by:
        notifyCheckpointAborted in interface TaskManagerGateway
        Parameters:
        executionAttemptID - identifying the task
        jobId - identifying the job to which the task belongs
        checkpointId - of the subsumed checkpoint
        latestCompletedCheckpointId - of the latest completed checkpoint
        timestamp - of the subsumed checkpoint
      • triggerCheckpoint

        public CompletableFuture<Acknowledge> triggerCheckpoint​(ExecutionAttemptID executionAttemptID,
                                                                org.apache.flink.api.common.JobID jobId,
                                                                long checkpointId,
                                                                long timestamp,
                                                                CheckpointOptions checkpointOptions)
        Description copied from interface: TaskManagerGateway
        Trigger for the given task a checkpoint.
        Specified by:
        triggerCheckpoint in interface TaskManagerGateway
        Parameters:
        executionAttemptID - identifying the task
        jobId - identifying the job to which the task belongs
        checkpointId - of the checkpoint to trigger
        timestamp - of the checkpoint to trigger
        checkpointOptions - of the checkpoint to trigger
        Returns:
        Future acknowledge which is returned once the checkpoint has been triggered