Package | Description |
---|---|
org.apache.flink.runtime.executiongraph | |
org.apache.flink.runtime.jobmaster | |
org.apache.flink.runtime.scheduler | |
org.apache.flink.runtime.taskmanager |
Modifier and Type | Method and Description |
---|---|
boolean |
ExecutionGraph.updateState(TaskExecutionState state)
Updates the state of one of the ExecutionVertex's Execution attempts.
|
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
void |
TaskManagerActions.updateTaskExecutionState(TaskExecutionState taskExecutionState)
Notifies the task manager about the task execution state update.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.