public class TaskExecutionStateTransition extends Object
TaskExecutionState
, along with actions to take if it is FAILED state.构造器和说明 |
---|
TaskExecutionStateTransition(TaskExecutionState taskExecutionState) |
TaskExecutionStateTransition(TaskExecutionState taskExecutionState,
boolean cancelTask,
boolean releasePartitions) |
限定符和类型 | 方法和说明 |
---|---|
AccumulatorSnapshot |
getAccumulators() |
boolean |
getCancelTask() |
Throwable |
getError(ClassLoader userCodeClassloader) |
ExecutionState |
getExecutionState() |
ExecutionAttemptID |
getID() |
IOMetrics |
getIOMetrics() |
org.apache.flink.api.common.JobID |
getJobID() |
boolean |
getReleasePartitions() |
public TaskExecutionStateTransition(TaskExecutionState taskExecutionState)
public TaskExecutionStateTransition(TaskExecutionState taskExecutionState, boolean cancelTask, boolean releasePartitions)
public Throwable getError(ClassLoader userCodeClassloader)
public ExecutionAttemptID getID()
public ExecutionState getExecutionState()
public org.apache.flink.api.common.JobID getJobID()
public AccumulatorSnapshot getAccumulators()
public IOMetrics getIOMetrics()
public boolean getCancelTask()
public boolean getReleasePartitions()
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.