Package | Description |
---|---|
org.apache.flink.runtime.execution | |
org.apache.flink.runtime.executiongraph | |
org.apache.flink.runtime.taskmanager |
Modifier and Type | Method and Description |
---|---|
static ExecutionState |
ExecutionState.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static ExecutionState[] |
ExecutionState.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
void |
ExecutionObserver.executionStateChanged(ExecutionState newExecutionState,
String optionalMessage)
Called when the execution state of the associated task has changed.
|
Modifier and Type | Method and Description |
---|---|
static ExecutionState |
ExecutionJobVertex.getAggregateJobVertexState(int[] verticesPerState,
int parallelism) |
ExecutionState |
ExecutionJobVertex.getAggregateState() |
ExecutionState |
ExecutionVertex.getExecutionState() |
ExecutionState |
Execution.getState() |
Modifier and Type | Method and Description |
---|---|
long |
ExecutionVertex.getStateTimestamp(ExecutionState state) |
long |
Execution.getStateTimestamp(ExecutionState state) |
Modifier and Type | Method and Description |
---|---|
ExecutionState |
Task.getExecutionState()
Returns the current execution state of the task.
|
ExecutionState |
TaskExecutionState.getExecutionState()
Returns the new execution state of the task.
|
Modifier and Type | Method and Description |
---|---|
void |
Task.onPartitionStateUpdate(IntermediateDataSetID resultId,
IntermediateResultPartitionID partitionId,
ExecutionState partitionState)
Answer to a partition state check issued after a failed partition request.
|
Constructor and Description |
---|
TaskExecutionState(JobID jobID,
ExecutionAttemptID executionId,
ExecutionState executionState)
Creates a new task execution state update, with no attached exception and no accumulators.
|
TaskExecutionState(JobID jobID,
ExecutionAttemptID executionId,
ExecutionState executionState,
Throwable error)
Creates a new task execution state update, with an attached exception but no accumulators.
|
TaskExecutionState(JobID jobID,
ExecutionAttemptID executionId,
ExecutionState executionState,
Throwable error,
AccumulatorSnapshot accumulators)
Creates a new task execution state update, with an attached exception.
|
Copyright © 2014–2016 The Apache Software Foundation. All rights reserved.