Uses of Class
org.apache.flink.runtime.executiongraph.ExecutionVertex
-
-
Uses of ExecutionVertex in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type ExecutionVertex Modifier and Type Method Description List<ExecutionVertex>
CheckpointPlan. getTasksToCommitTo()
Returns tasks that are still running when taking the checkpoint, these need to be sent a message when the checkpoint is confirmed.List<ExecutionVertex>
DefaultCheckpointPlan. getTasksToCommitTo()
Methods in org.apache.flink.runtime.checkpoint with parameters of type ExecutionVertex Modifier and Type Method Description void
DefaultCheckpointPlan. reportTaskFinishedOnRestore(ExecutionVertex task)
void
FinishedTaskStateProvider. reportTaskFinishedOnRestore(ExecutionVertex task)
Reports thetask
is finished on restoring.void
DefaultCheckpointPlan. reportTaskHasFinishedOperators(ExecutionVertex task)
void
FinishedTaskStateProvider. reportTaskHasFinishedOperators(ExecutionVertex task)
Reports thetask
has finished all the operators. -
Uses of ExecutionVertex in org.apache.flink.runtime.executiongraph
Subclasses of ExecutionVertex in org.apache.flink.runtime.executiongraph Modifier and Type Class Description class
SpeculativeExecutionVertex
The ExecutionVertex which supports speculative execution.Methods in org.apache.flink.runtime.executiongraph that return ExecutionVertex Modifier and Type Method Description protected ExecutionVertex
ExecutionJobVertex. createExecutionVertex(ExecutionJobVertex jobVertex, int subTaskIndex, IntermediateResult[] producedDataSets, Duration timeout, long createTimestamp, int executionHistorySizeLimit, int initialAttemptCount)
protected ExecutionVertex
SpeculativeExecutionJobVertex. createExecutionVertex(ExecutionJobVertex jobVertex, int subTaskIndex, IntermediateResult[] producedDataSets, Duration timeout, long createTimestamp, int executionHistorySizeLimit, int initialAttemptCount)
ExecutionVertex
DefaultExecutionGraph. getExecutionVertexOrThrow(ExecutionVertexID id)
ExecutionVertex
InternalExecutionGraphAccessor. getExecutionVertexOrThrow(ExecutionVertexID id)
ExecutionVertex
IntermediateResultPartition. getProducer()
ExecutionVertex[]
ExecutionJobVertex. getTaskVertices()
ExecutionVertex
Execution. getVertex()
Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type ExecutionVertex Modifier and Type Method Description Iterable<ExecutionVertex>
DefaultExecutionGraph. getAllExecutionVertices()
Iterable<ExecutionVertex>
ExecutionGraph. getAllExecutionVertices()
Constructors in org.apache.flink.runtime.executiongraph with parameters of type ExecutionVertex Constructor Description ArchivedExecutionVertex(ExecutionVertex vertex)
Execution(Executor executor, ExecutionVertex vertex, int attemptNumber, long startTimestamp, Duration rpcTimeout)
Creates a new Execution attempt.IntermediateResultPartition(IntermediateResult totalResult, ExecutionVertex producer, int partitionNumber, EdgeManager edgeManager)
-
Uses of ExecutionVertex in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return ExecutionVertex Modifier and Type Method Description ExecutionVertex
SchedulerBase. getExecutionVertex(ExecutionVertexID executionVertexId)
-
Uses of ExecutionVertex in org.apache.flink.runtime.scheduler.adaptivebatch
Constructor parameters in org.apache.flink.runtime.scheduler.adaptivebatch with type arguments of type ExecutionVertex Constructor Description DefaultSpeculativeExecutionHandler(org.apache.flink.configuration.Configuration jobMasterConfiguration, BlocklistOperations blocklistOperations, Function<ExecutionVertexID,ExecutionVertex> executionVertexRetriever, Supplier<Map<ExecutionAttemptID,Execution>> registerExecutionsSupplier, BiConsumer<List<Execution>,Collection<ExecutionVertexID>> allocateSlotsAndDeployFunction, org.slf4j.Logger log)
-