Interface TaskExecutorGateway

    • Method Detail

      • requestSlot

        CompletableFuture<Acknowledge> requestSlot​(SlotID slotId,
                                                   org.apache.flink.api.common.JobID jobId,
                                                   AllocationID allocationId,
                                                   ResourceProfile resourceProfile,
                                                   String targetAddress,
                                                   ResourceManagerId resourceManagerId,
                                                   Duration timeout)
        Requests a slot from the TaskManager.
        Parameters:
        slotId - slot id for the request
        jobId - for which to request a slot
        allocationId - id for the request
        resourceProfile - of requested slot, used only for dynamic slot allocation and will be ignored otherwise
        targetAddress - to which to offer the requested slots
        resourceManagerId - current leader id of the ResourceManager
        timeout - for the operation
        Returns:
        answer to the slot request
      • updatePartitions

        CompletableFuture<Acknowledge> updatePartitions​(ExecutionAttemptID executionAttemptID,
                                                        Iterable<PartitionInfo> partitionInfos,
                                                        Duration timeout)
        Update the task where the given partitions can be found.
        Parameters:
        executionAttemptID - identifying the task
        partitionInfos - telling where the partition can be retrieved from
        timeout - for the update partitions operation
        Returns:
        Future acknowledge if the partitions have been successfully updated
      • releasePartitions

        void releasePartitions​(org.apache.flink.api.common.JobID jobId,
                               Set<ResultPartitionID> partitionIds)
        Batch release intermediate result partitions.
        Parameters:
        jobId - id of the job that the partitions belong to
        partitionIds - partition ids to release
      • promotePartitions

        CompletableFuture<Acknowledge> promotePartitions​(org.apache.flink.api.common.JobID jobId,
                                                         Set<ResultPartitionID> partitionIds)
        Batch promote intermediate result partitions.
        Parameters:
        jobId - id of the job that the partitions belong to
        partitionIds - partition ids to release
        Returns:
        Future acknowledge that the partitions are successfully promoted.
      • releaseClusterPartitions

        CompletableFuture<Acknowledge> releaseClusterPartitions​(Collection<IntermediateDataSetID> dataSetsToRelease,
                                                                Duration timeout)
        Releases all cluster partitions belong to any of the given data sets.
        Parameters:
        dataSetsToRelease - data sets for which all cluster partitions should be released
        timeout - for the partitions release operation
        Returns:
        Future acknowledge that the request was received
      • triggerCheckpoint

        CompletableFuture<Acknowledge> triggerCheckpoint​(ExecutionAttemptID executionAttemptID,
                                                         long checkpointID,
                                                         long checkpointTimestamp,
                                                         CheckpointOptions checkpointOptions)
        Trigger the checkpoint for the given task. The checkpoint is identified by the checkpoint ID and the checkpoint timestamp.
        Parameters:
        executionAttemptID - identifying the task
        checkpointID - unique id for the checkpoint
        checkpointTimestamp - is the timestamp when the checkpoint has been initiated
        checkpointOptions - for performing the checkpoint
        Returns:
        Future acknowledge if the checkpoint has been successfully triggered
      • confirmCheckpoint

        CompletableFuture<Acknowledge> confirmCheckpoint​(ExecutionAttemptID executionAttemptID,
                                                         long completedCheckpointId,
                                                         long completedCheckpointTimestamp,
                                                         long lastSubsumedCheckpointId)
        Confirm a checkpoint for the given task. The checkpoint is identified by the checkpoint ID and the checkpoint timestamp.
        Parameters:
        executionAttemptID - identifying the task
        completedCheckpointId - unique id for the completed checkpoint
        completedCheckpointTimestamp - is the timestamp when the checkpoint has been initiated
        lastSubsumedCheckpointId - unique id for the checkpoint to be subsumed
        Returns:
        Future acknowledge if the checkpoint has been successfully confirmed
      • abortCheckpoint

        CompletableFuture<Acknowledge> abortCheckpoint​(ExecutionAttemptID executionAttemptID,
                                                       long checkpointId,
                                                       long latestCompletedCheckpointId,
                                                       long checkpointTimestamp)
        Abort a checkpoint for the given task. The checkpoint is identified by the checkpoint ID and the checkpoint timestamp.
        Parameters:
        executionAttemptID - identifying the task
        checkpointId - unique id for the checkpoint
        latestCompletedCheckpointId - the id of the latest completed checkpoint
        checkpointTimestamp - is the timestamp when the checkpoint has been initiated
        Returns:
        Future acknowledge if the checkpoint has been successfully confirmed
      • cancelTask

        CompletableFuture<Acknowledge> cancelTask​(ExecutionAttemptID executionAttemptID,
                                                  Duration timeout)
        Cancel the given task.
        Parameters:
        executionAttemptID - identifying the task
        timeout - for the cancel operation
        Returns:
        Future acknowledge if the task is successfully canceled
      • heartbeatFromJobManager

        CompletableFuture<Void> heartbeatFromJobManager​(ResourceID heartbeatOrigin,
                                                        AllocatedSlotReport allocatedSlotReport)
        Heartbeat request from the job manager.
        Parameters:
        heartbeatOrigin - unique id of the job manager
        Returns:
        future which is completed exceptionally if the operation fails
      • heartbeatFromResourceManager

        CompletableFuture<Void> heartbeatFromResourceManager​(ResourceID heartbeatOrigin)
        Heartbeat request from the resource manager.
        Parameters:
        heartbeatOrigin - unique id of the resource manager
        Returns:
        future which is completed exceptionally if the operation fails
      • disconnectJobManager

        void disconnectJobManager​(org.apache.flink.api.common.JobID jobId,
                                  Exception cause)
        Disconnects the given JobManager from the TaskManager.
        Parameters:
        jobId - JobID for which the JobManager was the leader
        cause - for the disconnection from the JobManager
      • disconnectResourceManager

        void disconnectResourceManager​(Exception cause)
        Disconnects the ResourceManager from the TaskManager.
        Parameters:
        cause - for the disconnection from the ResourceManager
      • freeSlot

        CompletableFuture<Acknowledge> freeSlot​(AllocationID allocationId,
                                                Throwable cause,
                                                Duration timeout)
        Frees the slot with the given allocation ID.
        Parameters:
        allocationId - identifying the slot to free
        cause - of the freeing operation
        timeout - for the operation
        Returns:
        Future acknowledge which is returned once the slot has been freed
      • freeInactiveSlots

        void freeInactiveSlots​(org.apache.flink.api.common.JobID jobId,
                               Duration timeout)
        Frees all currently inactive slot allocated for the given job.
        Parameters:
        jobId - job for which all inactive slots should be released
        timeout - for the operation
      • requestFileUploadByNameAndType

        CompletableFuture<TransientBlobKey> requestFileUploadByNameAndType​(String fileName,
                                                                           FileType fileType,
                                                                           Duration timeout)
        Requests the file upload of the specified name and file type to the cluster's BlobServer.
        Parameters:
        fileName - to upload
        fileType - to upload
        timeout - for the asynchronous operation
        Returns:
        Future which is completed with the TransientBlobKey of the uploaded file.
      • requestMetricQueryServiceAddress

        CompletableFuture<org.apache.flink.types.SerializableOptional<String>> requestMetricQueryServiceAddress​(Duration timeout)
        Returns the gateway of Metric Query Service on the TaskManager.
        Returns:
        Future gateway of Metric Query Service on the TaskManager.
      • canBeReleased

        CompletableFuture<Boolean> canBeReleased()
        Checks whether the task executor can be released. It cannot be released if there're unconsumed result partitions.
        Returns:
        Future flag indicating whether the task executor can be released.
      • requestLogList

        CompletableFuture<Collection<LogInfo>> requestLogList​(Duration timeout)
        Requests for the historical log file names on the TaskManager.
        Returns:
        A Tuple2 Array with all log file names with its length.
      • updateDelegationTokens

        CompletableFuture<Acknowledge> updateDelegationTokens​(ResourceManagerId resourceManagerId,
                                                              byte[] tokens)
        Sends new delegation tokens to this TaskManager.
        Parameters:
        resourceManagerId - current leader id of the ResourceManager
        tokens - new tokens
        Returns:
        Future acknowledge of the successful operation
      • getAndRetainPartitionWithMetrics

        default CompletableFuture<Collection<PartitionWithMetrics>> getAndRetainPartitionWithMetrics​(org.apache.flink.api.common.JobID jobId)
        Get and retain all partitions and their metrics located on this task executor, the metrics mainly includes the meta information of partition(partition bytes, etc).
        Parameters:
        jobId - ID of the target job
        Returns:
        All partitions belong to the target job and their metrics
      • requestProfilingList

        CompletableFuture<Collection<ProfilingInfo>> requestProfilingList​(Duration timeout)
        Requests for the historical profiling file names on the TaskManager.
        Returns:
        A Collection with all profiling instances information.