程序包 | 说明 |
---|---|
org.apache.flink.runtime.executiongraph | |
org.apache.flink.runtime.jobmaster | |
org.apache.flink.runtime.scheduler | |
org.apache.flink.runtime.taskmanager |
限定符和类型 | 方法和说明 |
---|---|
boolean |
ExecutionGraph.updateState(TaskExecutionState state)
Updates the state of one of the ExecutionVertex's Execution attempts.
|
限定符和类型 | 方法和说明 |
---|---|
CompletableFuture<Acknowledge> |
JobMasterGateway.updateTaskExecutionState(TaskExecutionState taskExecutionState)
Updates the task execution state for a given task.
|
CompletableFuture<Acknowledge> |
JobMaster.updateTaskExecutionState(TaskExecutionState taskExecutionState)
Updates the task execution state for a given task.
|
限定符和类型 | 方法和说明 |
---|---|
boolean |
SchedulerBase.updateTaskExecutionState(TaskExecutionState taskExecutionState) |
boolean |
SchedulerNG.updateTaskExecutionState(TaskExecutionState taskExecutionState) |
protected void |
SchedulerBase.updateTaskExecutionStateInternal(ExecutionVertexID executionVertexId,
TaskExecutionState taskExecutionState) |
protected void |
DefaultScheduler.updateTaskExecutionStateInternal(ExecutionVertexID executionVertexId,
TaskExecutionState taskExecutionState) |
限定符和类型 | 方法和说明 |
---|---|
void |
TaskManagerActions.updateTaskExecutionState(TaskExecutionState taskExecutionState)
Notifies the task manager about the task execution state update.
|
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.