public class SpeculativeExecutionVertex extends ExecutionVertex
MAX_DISTINCT_LOCATIONS_TO_CONSIDER
Constructor and Description |
---|
SpeculativeExecutionVertex(ExecutionJobVertex jobVertex,
int subTaskIndex,
IntermediateResult[] producedDataSets,
Time timeout,
long createTimestamp,
int executionHistorySizeLimit,
int initialAttemptCount) |
Modifier and Type | Method and Description |
---|---|
ArchivedExecutionVertex |
archive() |
void |
archiveFailedExecution(ExecutionAttemptID executionAttemptId)
Remove execution from currentExecutions if it is failed.
|
CompletableFuture<?> |
cancel()
Cancels this ExecutionVertex.
|
boolean |
containsSinks() |
boolean |
containsSources() |
Execution |
createNewSpeculativeExecution(long timestamp) |
void |
deploy() |
void |
deployToSlot(LogicalSlot slot) |
void |
fail(Throwable t) |
Execution |
getCurrentExecution(int attemptNumber) |
Execution |
getCurrentExecutionAttempt()
Returns the current execution for this execution vertex.
|
Collection<Execution> |
getCurrentExecutions()
Returns the current executions for this execution vertex.
|
CompletableFuture<TaskManagerLocation> |
getCurrentTaskManagerLocationFuture() |
Optional<InputSplit> |
getNextInputSplit(String host,
int attemptNumber) |
Execution |
getPartitionProducer() |
Optional<TaskManagerLocation> |
getPreferredLocationBasedOnState()
Gets the preferred location to execute the current task execution attempt, based on the state
that the execution attempt will resume.
|
boolean |
isOriginalAttempt(int attemptNumber)
Returns whether the given attempt is the original execution attempt of the execution vertex,
i.e.
|
void |
markFailed(Throwable t)
This method marks the task as failed, but will make no attempt to remove task execution from
the task manager.
|
void |
resetForNewExecution()
Archives the current Execution and creates a new Execution for this vertex.
|
CompletableFuture<?> |
suspend() |
void |
tryAssignResource(LogicalSlot slot) |
addConsumedPartitionGroup, findLastAllocation, findLastLocation, finishAllBlockingPartitions, getAllConsumedPartitionGroups, getConsumedPartitionGroup, getCurrentAssignedResource, getCurrentAssignedResourceLocation, getExecutionGraphAccessor, getExecutionHistory, getExecutionState, getFailureInfo, getID, getJobId, getJobVertex, getJobvertexId, getMaxParallelism, getNumberOfInputs, getParallelSubtaskIndex, getProducedPartitions, getResourceProfile, getStateTimestamp, getTaskName, getTaskNameWithSubtaskIndex, getTotalNumberOfParallelSubtasks, toString
public SpeculativeExecutionVertex(ExecutionJobVertex jobVertex, int subTaskIndex, IntermediateResult[] producedDataSets, Time timeout, long createTimestamp, int executionHistorySizeLimit, int initialAttemptCount)
public boolean containsSources()
public boolean containsSinks()
public Execution createNewSpeculativeExecution(long timestamp)
public boolean isOriginalAttempt(int attemptNumber)
public Collection<Execution> getCurrentExecutions()
AccessExecutionVertex
getCurrentExecutions
in interface AccessExecutionVertex
getCurrentExecutions
in class ExecutionVertex
public Execution getCurrentExecution(int attemptNumber)
getCurrentExecution
in class ExecutionVertex
public Execution getPartitionProducer()
getPartitionProducer
in class ExecutionVertex
public CompletableFuture<?> cancel()
ExecutionVertex
cancel
in class ExecutionVertex
public CompletableFuture<?> suspend()
suspend
in class ExecutionVertex
public void fail(Throwable t)
fail
in class ExecutionVertex
public void markFailed(Throwable t)
ExecutionVertex
markFailed
in class ExecutionVertex
t
- The exception that caused the task to fail.public void resetForNewExecution()
ExecutionVertex
resetForNewExecution
in class ExecutionVertex
public void archiveFailedExecution(ExecutionAttemptID executionAttemptId)
executionAttemptId
- attemptID of the execution to be removedpublic Execution getCurrentExecutionAttempt()
AccessExecutionVertex
getCurrentExecutionAttempt
in interface AccessExecutionVertex
getCurrentExecutionAttempt
in class ExecutionVertex
public Optional<InputSplit> getNextInputSplit(String host, int attemptNumber)
getNextInputSplit
in class ExecutionVertex
public ArchivedExecutionVertex archive()
archive
in interface Archiveable<ArchivedExecutionVertex>
archive
in class ExecutionVertex
public void tryAssignResource(LogicalSlot slot)
tryAssignResource
in class ExecutionVertex
public void deploy()
deploy
in class ExecutionVertex
public void deployToSlot(LogicalSlot slot)
deployToSlot
in class ExecutionVertex
public Optional<TaskManagerLocation> getPreferredLocationBasedOnState()
ExecutionVertex
getPreferredLocationBasedOnState
in class ExecutionVertex
public CompletableFuture<TaskManagerLocation> getCurrentTaskManagerLocationFuture()
getCurrentTaskManagerLocationFuture
in class ExecutionVertex
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.