Class SpeculativeExecutionJobVertex
- java.lang.Object
-
- org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- org.apache.flink.runtime.executiongraph.SpeculativeExecutionJobVertex
-
- All Implemented Interfaces:
Archiveable<ArchivedExecutionJobVertex>
,AccessExecutionJobVertex
public class SpeculativeExecutionJobVertex extends ExecutionJobVertex
The ExecutionJobVertex which supports speculative execution.
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static class
SpeculativeExecutionJobVertex.Factory
Factory to createSpeculativeExecutionJobVertex
.
-
Constructor Summary
Constructors Constructor Description SpeculativeExecutionJobVertex(InternalExecutionGraphAccessor graph, JobVertex jobVertex, VertexParallelismInformation parallelismInfo, CoordinatorStore coordinatorStore, JobManagerJobMetricGroup jobManagerJobMetricGroup)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected ExecutionVertex
createExecutionVertex(ExecutionJobVertex jobVertex, int subTaskIndex, IntermediateResult[] producedDataSets, Duration timeout, long createTimestamp, int executionHistorySizeLimit, int initialAttemptCount)
protected OperatorCoordinatorHolder
createOperatorCoordinatorHolder(SerializedValue<OperatorCoordinator.Provider> provider, ClassLoader classLoader, CoordinatorStore coordinatorStore, JobManagerJobMetricGroup jobManagerJobMetricGroup)
-
Methods inherited from class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
archive, cancel, cancelWithFuture, canRescaleMaxParallelism, connectToPredecessors, fail, getAggregatedUserAccumulatorsStringified, getAggregateJobVertexState, getAggregateState, getCoLocationGroup, getGraph, getInputs, getJobId, getJobVertex, getJobVertexId, getMaxParallelism, getName, getOperatorCoordinators, getOperatorIDs, getParallelism, getProducedDataSets, getResourceProfile, getSlotSharingGroup, getSourceCoordinators, getSplitAssigner, getTaskInformation, getTaskInformationOrBlobKey, getTaskVertices, initialize, isFinished, isInitialized, isParallelismDecided, setMaxParallelism, setParallelism, suspend
-
-
-
-
Constructor Detail
-
SpeculativeExecutionJobVertex
public SpeculativeExecutionJobVertex(InternalExecutionGraphAccessor graph, JobVertex jobVertex, VertexParallelismInformation parallelismInfo, CoordinatorStore coordinatorStore, JobManagerJobMetricGroup jobManagerJobMetricGroup) throws JobException
- Throws:
JobException
-
-
Method Detail
-
createExecutionVertex
protected ExecutionVertex createExecutionVertex(ExecutionJobVertex jobVertex, int subTaskIndex, IntermediateResult[] producedDataSets, Duration timeout, long createTimestamp, int executionHistorySizeLimit, int initialAttemptCount)
- Overrides:
createExecutionVertex
in classExecutionJobVertex
-
createOperatorCoordinatorHolder
protected OperatorCoordinatorHolder createOperatorCoordinatorHolder(SerializedValue<OperatorCoordinator.Provider> provider, ClassLoader classLoader, CoordinatorStore coordinatorStore, JobManagerJobMetricGroup jobManagerJobMetricGroup) throws Exception
- Overrides:
createOperatorCoordinatorHolder
in classExecutionJobVertex
- Throws:
Exception
-
-