Class ArchivedExecution
- java.lang.Object
-
- org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- All Implemented Interfaces:
Serializable,AccessExecution
public class ArchivedExecution extends Object implements AccessExecution, Serializable
ArchivedExecutionis a readonly representation ofExecution.- See Also:
- Serialized Form
-
-
Constructor Summary
Constructors Constructor Description ArchivedExecution(StringifiedAccumulatorResult[] userAccumulators, IOMetrics ioMetrics, ExecutionAttemptID attemptId, ExecutionState state, ErrorInfo failureCause, TaskManagerLocation assignedResourceLocation, AllocationID assignedAllocationID, long[] stateTimestamps, long[] stateEndTimestamps)ArchivedExecution(Execution execution)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description AllocationIDgetAssignedAllocationID()TaskManagerLocationgetAssignedResourceLocation()Returns theTaskManagerLocationfor this execution.ExecutionAttemptIDgetAttemptId()Returns theExecutionAttemptIDfor this Execution.intgetAttemptNumber()Returns the attempt number for this execution.Optional<ErrorInfo>getFailureInfo()Returns the exception that caused the job to fail.IOMetricsgetIOMetrics()intgetParallelSubtaskIndex()Returns the subtask index of this execution.ExecutionStategetState()Returns the currentExecutionStatefor this execution.longgetStateEndTimestamp(ExecutionState state)Returns the end timestamp for the givenExecutionState.long[]getStateEndTimestamps()Returns the end timestamps for everyExecutionState.longgetStateTimestamp(ExecutionState state)Returns the timestamp for the givenExecutionState.long[]getStateTimestamps()Returns the timestamps for everyExecutionState.StringifiedAccumulatorResult[]getUserAccumulatorsStringified()Returns the user-defined accumulators as strings.
-
-
-
Constructor Detail
-
ArchivedExecution
public ArchivedExecution(Execution execution)
-
ArchivedExecution
public ArchivedExecution(StringifiedAccumulatorResult[] userAccumulators, IOMetrics ioMetrics, ExecutionAttemptID attemptId, ExecutionState state, @Nullable ErrorInfo failureCause, TaskManagerLocation assignedResourceLocation, AllocationID assignedAllocationID, long[] stateTimestamps, long[] stateEndTimestamps)
-
-
Method Detail
-
getAttemptId
public ExecutionAttemptID getAttemptId()
Description copied from interface:AccessExecutionReturns theExecutionAttemptIDfor this Execution.- Specified by:
getAttemptIdin interfaceAccessExecution- Returns:
- ExecutionAttemptID for this execution
-
getAttemptNumber
public int getAttemptNumber()
Description copied from interface:AccessExecutionReturns the attempt number for this execution.- Specified by:
getAttemptNumberin interfaceAccessExecution- Returns:
- attempt number for this execution.
-
getStateTimestamps
public long[] getStateTimestamps()
Description copied from interface:AccessExecutionReturns the timestamps for everyExecutionState.- Specified by:
getStateTimestampsin interfaceAccessExecution- Returns:
- timestamps for each state
-
getStateEndTimestamps
public long[] getStateEndTimestamps()
Description copied from interface:AccessExecutionReturns the end timestamps for everyExecutionState.- Specified by:
getStateEndTimestampsin interfaceAccessExecution- Returns:
- timestamps for each state
-
getState
public ExecutionState getState()
Description copied from interface:AccessExecutionReturns the currentExecutionStatefor this execution.- Specified by:
getStatein interfaceAccessExecution- Returns:
- execution state for this execution
-
getAssignedResourceLocation
public TaskManagerLocation getAssignedResourceLocation()
Description copied from interface:AccessExecutionReturns theTaskManagerLocationfor this execution.- Specified by:
getAssignedResourceLocationin interfaceAccessExecution- Returns:
- taskmanager location for this execution.
-
getAssignedAllocationID
public AllocationID getAssignedAllocationID()
-
getFailureInfo
public Optional<ErrorInfo> getFailureInfo()
Description copied from interface:AccessExecutionReturns the exception that caused the job to fail. This is the first root exception that was not recoverable and triggered job failure.- Specified by:
getFailureInfoin interfaceAccessExecution- Returns:
- an
OptionalofErrorInfocontaining theThrowableand the time it was registered if an error occurred. If no error occurred an emptyOptionalwill be returned.
-
getStateTimestamp
public long getStateTimestamp(ExecutionState state)
Description copied from interface:AccessExecutionReturns the timestamp for the givenExecutionState.- Specified by:
getStateTimestampin interfaceAccessExecution- Parameters:
state- state for which the timestamp should be returned- Returns:
- timestamp for the given state
-
getStateEndTimestamp
public long getStateEndTimestamp(ExecutionState state)
Description copied from interface:AccessExecutionReturns the end timestamp for the givenExecutionState.- Specified by:
getStateEndTimestampin interfaceAccessExecution- Parameters:
state- state for which the timestamp should be returned- Returns:
- timestamp for the given state
-
getUserAccumulatorsStringified
public StringifiedAccumulatorResult[] getUserAccumulatorsStringified()
Description copied from interface:AccessExecutionReturns the user-defined accumulators as strings.- Specified by:
getUserAccumulatorsStringifiedin interfaceAccessExecution- Returns:
- user-defined accumulators as strings.
-
getParallelSubtaskIndex
public int getParallelSubtaskIndex()
Description copied from interface:AccessExecutionReturns the subtask index of this execution.- Specified by:
getParallelSubtaskIndexin interfaceAccessExecution- Returns:
- subtask index of this execution.
-
getIOMetrics
public IOMetrics getIOMetrics()
- Specified by:
getIOMetricsin interfaceAccessExecution
-
-