public class RpcTaskManagerGateway extends Object implements TaskManagerGateway
TaskManagerGateway
for Flink's RPC system.构造器和说明 |
---|
RpcTaskManagerGateway(TaskExecutorGateway taskExecutorGateway,
JobMasterId jobMasterId) |
限定符和类型 | 方法和说明 |
---|---|
CompletableFuture<Acknowledge> |
cancelTask(ExecutionAttemptID executionAttemptID,
org.apache.flink.api.common.time.Time timeout)
Cancel the given task.
|
void |
disconnectFromJobManager(InstanceID instanceId,
Exception cause)
Disconnect the task manager from the job manager.
|
void |
failPartition(ExecutionAttemptID executionAttemptID)
Fail all intermediate result partitions of the given task.
|
CompletableFuture<Acknowledge> |
freeSlot(AllocationID allocationId,
Throwable cause,
org.apache.flink.api.common.time.Time timeout)
Frees the slot with the given allocation ID.
|
String |
getAddress()
Return the address of the task manager with which the gateway is associated.
|
void |
notifyCheckpointComplete(ExecutionAttemptID executionAttemptID,
org.apache.flink.api.common.JobID jobId,
long checkpointId,
long timestamp)
Notify the given task about a completed checkpoint.
|
CompletableFuture<StackTrace> |
requestStackTrace(org.apache.flink.api.common.time.Time timeout)
Request the stack trace from the task manager.
|
CompletableFuture<StackTraceSampleResponse> |
requestStackTraceSample(ExecutionAttemptID executionAttemptID,
int sampleId,
int numSamples,
org.apache.flink.api.common.time.Time delayBetweenSamples,
int maxStackTraceDepth,
org.apache.flink.api.common.time.Time timeout)
Request a stack trace sample from the given task.
|
CompletableFuture<TransientBlobKey> |
requestTaskManagerLog(org.apache.flink.api.common.time.Time timeout)
Request the task manager log from the task manager.
|
CompletableFuture<TransientBlobKey> |
requestTaskManagerStdout(org.apache.flink.api.common.time.Time timeout)
Request the task manager stdout from the task manager.
|
void |
stopCluster(ApplicationStatus applicationStatus,
String message)
Stop the cluster.
|
CompletableFuture<Acknowledge> |
stopTask(ExecutionAttemptID executionAttemptID,
org.apache.flink.api.common.time.Time timeout)
Stop the given task.
|
CompletableFuture<Acknowledge> |
submitTask(TaskDeploymentDescriptor tdd,
org.apache.flink.api.common.time.Time timeout)
Submit a task to the task manager.
|
void |
triggerCheckpoint(ExecutionAttemptID executionAttemptID,
org.apache.flink.api.common.JobID jobId,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions)
Trigger for the given task a checkpoint.
|
CompletableFuture<Acknowledge> |
updatePartitions(ExecutionAttemptID executionAttemptID,
Iterable<PartitionInfo> partitionInfos,
org.apache.flink.api.common.time.Time timeout)
Update the task where the given partitions can be found.
|
public RpcTaskManagerGateway(TaskExecutorGateway taskExecutorGateway, JobMasterId jobMasterId)
public String getAddress()
TaskManagerGateway
getAddress
在接口中 TaskManagerGateway
public void disconnectFromJobManager(InstanceID instanceId, Exception cause)
TaskManagerGateway
disconnectFromJobManager
在接口中 TaskManagerGateway
instanceId
- identifying the task managercause
- of the disconnectionpublic void stopCluster(ApplicationStatus applicationStatus, String message)
TaskManagerGateway
stopCluster
在接口中 TaskManagerGateway
applicationStatus
- to stop the cluster withmessage
- to deliverpublic CompletableFuture<StackTrace> requestStackTrace(org.apache.flink.api.common.time.Time timeout)
TaskManagerGateway
requestStackTrace
在接口中 TaskManagerGateway
timeout
- for the stack trace requestpublic CompletableFuture<StackTraceSampleResponse> requestStackTraceSample(ExecutionAttemptID executionAttemptID, int sampleId, int numSamples, org.apache.flink.api.common.time.Time delayBetweenSamples, int maxStackTraceDepth, org.apache.flink.api.common.time.Time timeout)
TaskManagerGateway
requestStackTraceSample
在接口中 TaskManagerGateway
executionAttemptID
- identifying the task to samplesampleId
- of the samplenumSamples
- to take from the given taskdelayBetweenSamples
- to wait formaxStackTraceDepth
- of the returned sampletimeout
- of the requestpublic CompletableFuture<Acknowledge> submitTask(TaskDeploymentDescriptor tdd, org.apache.flink.api.common.time.Time timeout)
TaskManagerGateway
submitTask
在接口中 TaskManagerGateway
tdd
- describing the task to submittimeout
- of the submit operationpublic CompletableFuture<Acknowledge> stopTask(ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.time.Time timeout)
TaskManagerGateway
stopTask
在接口中 TaskManagerGateway
executionAttemptID
- identifying the tasktimeout
- of the submit operationpublic CompletableFuture<Acknowledge> cancelTask(ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.time.Time timeout)
TaskManagerGateway
cancelTask
在接口中 TaskManagerGateway
executionAttemptID
- identifying the tasktimeout
- of the submit operationpublic CompletableFuture<Acknowledge> updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, org.apache.flink.api.common.time.Time timeout)
TaskManagerGateway
updatePartitions
在接口中 TaskManagerGateway
executionAttemptID
- identifying the taskpartitionInfos
- telling where the partition can be retrieved fromtimeout
- of the submit operationpublic void failPartition(ExecutionAttemptID executionAttemptID)
TaskManagerGateway
failPartition
在接口中 TaskManagerGateway
executionAttemptID
- identifying the taskpublic void notifyCheckpointComplete(ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.JobID jobId, long checkpointId, long timestamp)
TaskManagerGateway
notifyCheckpointComplete
在接口中 TaskManagerGateway
executionAttemptID
- identifying the taskjobId
- identifying the job to which the task belongscheckpointId
- of the completed checkpointtimestamp
- of the completed checkpointpublic void triggerCheckpoint(ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.JobID jobId, long checkpointId, long timestamp, CheckpointOptions checkpointOptions)
TaskManagerGateway
triggerCheckpoint
在接口中 TaskManagerGateway
executionAttemptID
- identifying the taskjobId
- identifying the job to which the task belongscheckpointId
- of the checkpoint to triggertimestamp
- of the checkpoint to triggercheckpointOptions
- of the checkpoint to triggerpublic CompletableFuture<TransientBlobKey> requestTaskManagerLog(org.apache.flink.api.common.time.Time timeout)
TaskManagerGateway
requestTaskManagerLog
在接口中 TaskManagerGateway
timeout
- for the requestpublic CompletableFuture<TransientBlobKey> requestTaskManagerStdout(org.apache.flink.api.common.time.Time timeout)
TaskManagerGateway
requestTaskManagerStdout
在接口中 TaskManagerGateway
timeout
- for the requestpublic CompletableFuture<Acknowledge> freeSlot(AllocationID allocationId, Throwable cause, org.apache.flink.api.common.time.Time timeout)
TaskManagerGateway
freeSlot
在接口中 TaskManagerGateway
allocationId
- identifying the slot to freecause
- of the freeing operationtimeout
- for the operationCopyright © 2014–2019 The Apache Software Foundation. All rights reserved.