Uses of Class
org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
-
Uses of ExecutionJobVertex in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type ExecutionJobVertex Modifier and Type Method Description Collection<ExecutionJobVertex>CheckpointPlan. getFullyFinishedJobVertex()Returns the job vertices whose tasks are all finished when taking the checkpoint.Collection<ExecutionJobVertex>DefaultCheckpointPlan. getFullyFinishedJobVertex()Method parameters in org.apache.flink.runtime.checkpoint with type arguments of type ExecutionJobVertex Modifier and Type Method Description static CompletedCheckpointCheckpoints. loadAndValidateCheckpoint(org.apache.flink.api.common.JobID jobId, Map<JobVertexID,ExecutionJobVertex> tasks, CompletedCheckpointStorageLocation location, ClassLoader classLoader, boolean allowNonRestoredState, CheckpointProperties checkpointProperties)booleanCheckpointCoordinator. restoreInitialCheckpointIfPresent(Set<ExecutionJobVertex> tasks)Restores the latest checkpointed at the beginning of the job execution.booleanCheckpointCoordinator. restoreLatestCheckpointedStateToAll(Set<ExecutionJobVertex> tasks, boolean allowNonRestoredState)Restores the latest checkpointed state to all tasks and all coordinators.OptionalLongCheckpointCoordinator. restoreLatestCheckpointedStateToSubtasks(Set<ExecutionJobVertex> tasks)Restores the latest checkpointed state to a set of subtasks.booleanCheckpointCoordinator. restoreSavepoint(SavepointRestoreSettings restoreSettings, Map<JobVertexID,ExecutionJobVertex> tasks, ClassLoader userClassLoader)Restore the state with given savepoint.Constructor parameters in org.apache.flink.runtime.checkpoint with type arguments of type ExecutionJobVertex Constructor Description CheckpointCoordinator(org.apache.flink.api.common.JobID job, CheckpointCoordinatorConfiguration chkConfig, Collection<OperatorCoordinatorCheckpointContext> coordinatorsToCheckpoint, CheckpointIDCounter checkpointIDCounter, CompletedCheckpointStore completedCheckpointStore, CheckpointStorage checkpointStorage, Executor executor, CheckpointsCleaner checkpointsCleaner, org.apache.flink.util.concurrent.ScheduledExecutor timer, CheckpointFailureManager failureManager, CheckpointPlanCalculator checkpointPlanCalculator, org.apache.flink.util.clock.Clock clock, CheckpointStatsTracker statsTracker, BiFunction<Set<ExecutionJobVertex>,Map<OperatorID,OperatorState>,VertexFinishedStateChecker> vertexFinishedStateCheckerFactory)DefaultCheckpointPlanCalculator(org.apache.flink.api.common.JobID jobId, CheckpointPlanCalculatorContext context, Iterable<ExecutionJobVertex> jobVerticesInTopologyOrderIterable, boolean allowCheckpointsAfterTasksFinished)StateAssignmentOperation(long restoreCheckpointId, Set<ExecutionJobVertex> tasks, Map<OperatorID,OperatorState> operatorStates, boolean allowNonRestoredState)VertexFinishedStateChecker(Set<ExecutionJobVertex> vertices, Map<OperatorID,OperatorState> operatorStates) -
Uses of ExecutionJobVertex in org.apache.flink.runtime.executiongraph
Subclasses of ExecutionJobVertex in org.apache.flink.runtime.executiongraph Modifier and Type Class Description classSpeculativeExecutionJobVertexThe ExecutionJobVertex which supports speculative execution.Methods in org.apache.flink.runtime.executiongraph that return ExecutionJobVertex Modifier and Type Method Description ExecutionJobVertexDefaultExecutionGraph. getJobVertex(JobVertexID id)ExecutionJobVertexExecutionGraph. getJobVertex(JobVertexID id)ExecutionJobVertexExecutionVertex. getJobVertex()ExecutionJobVertexInternalExecutionGraphAccessor. getJobVertex(JobVertexID id)ExecutionJobVertexIntermediateResult. getProducer()Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type ExecutionJobVertex Modifier and Type Method Description Map<JobVertexID,ExecutionJobVertex>DefaultExecutionGraph. getAllVertices()Map<JobVertexID,ExecutionJobVertex>ExecutionGraph. getAllVertices()Iterable<ExecutionJobVertex>DefaultExecutionGraph. getVerticesTopologically()Iterable<ExecutionJobVertex>ExecutionGraph. getVerticesTopologically()Methods in org.apache.flink.runtime.executiongraph with parameters of type ExecutionJobVertex Modifier and Type Method Description static Map<IntermediateDataSetID,JobVertexInputInfo>VertexInputInfoComputationUtils. computeVertexInputInfos(ExecutionJobVertex ejv, Function<IntermediateDataSetID,IntermediateResult> intermediateResultRetriever)protected ExecutionVertexExecutionJobVertex. createExecutionVertex(ExecutionJobVertex jobVertex, int subTaskIndex, IntermediateResult[] producedDataSets, Duration timeout, long createTimestamp, int executionHistorySizeLimit, int initialAttemptCount)protected ExecutionVertexSpeculativeExecutionJobVertex. createExecutionVertex(ExecutionJobVertex jobVertex, int subTaskIndex, IntermediateResult[] producedDataSets, Duration timeout, long createTimestamp, int executionHistorySizeLimit, int initialAttemptCount)voidDefaultExecutionGraph. initializeJobVertex(ExecutionJobVertex ejv, long createTimestamp, Map<IntermediateDataSetID,JobVertexInputInfo> jobVertexInputInfos)default voidExecutionGraph. initializeJobVertex(ExecutionJobVertex ejv, long createTimestamp)voidExecutionGraph. initializeJobVertex(ExecutionJobVertex ejv, long createTimestamp, Map<IntermediateDataSetID,JobVertexInputInfo> jobVertexInputInfos)Initialize the given execution job vertex, mainly includes creating execution vertices according to the parallelism, and connecting to the predecessors.Method parameters in org.apache.flink.runtime.executiongraph with type arguments of type ExecutionJobVertex Modifier and Type Method Description voidDefaultExecutionGraph. notifyNewlyInitializedJobVertices(List<ExecutionJobVertex> vertices)voidExecutionGraph. notifyNewlyInitializedJobVertices(List<ExecutionJobVertex> vertices)Notify that some job vertices have been newly initialized, execution graph will try to update scheduling topology.Constructors in org.apache.flink.runtime.executiongraph with parameters of type ExecutionJobVertex Constructor Description ArchivedExecutionJobVertex(ExecutionJobVertex jobVertex)ExecutionVertex(ExecutionJobVertex jobVertex, int subTaskIndex, IntermediateResult[] producedDataSets, Duration timeout, long createTimestamp, int executionHistorySizeLimit, int initialAttemptCount)Creates an ExecutionVertex.IntermediateResult(IntermediateDataSet intermediateDataSet, ExecutionJobVertex producer, int numParallelProducers, ResultPartitionType resultType, ExecutionPlanSchedulingContext executionPlanSchedulingContext)SpeculativeExecutionVertex(ExecutionJobVertex jobVertex, int subTaskIndex, IntermediateResult[] producedDataSets, Duration timeout, long createTimestamp, int executionHistorySizeLimit, int initialAttemptCount) -
Uses of ExecutionJobVertex in org.apache.flink.runtime.operators.coordination
Methods in org.apache.flink.runtime.operators.coordination with parameters of type ExecutionJobVertex Modifier and Type Method Description static OperatorCoordinatorHolderOperatorCoordinatorHolder. create(org.apache.flink.util.SerializedValue<OperatorCoordinator.Provider> serializedProvider, ExecutionJobVertex jobVertex, ClassLoader classLoader, CoordinatorStore coordinatorStore, boolean supportsConcurrentExecutionAttempts, TaskInformation taskInformation, JobManagerJobMetricGroup metricGroup) -
Uses of ExecutionJobVertex in org.apache.flink.runtime.query
Constructor parameters in org.apache.flink.runtime.query with type arguments of type ExecutionJobVertex Constructor Description KvStateLocationRegistry(org.apache.flink.api.common.JobID jobId, Map<JobVertexID,ExecutionJobVertex> jobVertices)Creates the registry for the job. -
Uses of ExecutionJobVertex in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return ExecutionJobVertex Modifier and Type Method Description ExecutionJobVertexSchedulerBase. getExecutionJobVertex(JobVertexID jobVertexId)Method parameters in org.apache.flink.runtime.scheduler with type arguments of type ExecutionJobVertex Modifier and Type Method Description static voidSsgNetworkMemoryCalculationUtils. enrichNetworkMemory(SlotSharingGroup ssg, Function<JobVertexID,ExecutionJobVertex> ejvs, ShuffleMaster<?> shuffleMaster)Calculates network memory requirement ofExecutionJobVertexand updateResourceProfileof corresponding slot sharing group. -
Uses of ExecutionJobVertex in org.apache.flink.runtime.scheduler.adapter
Method parameters in org.apache.flink.runtime.scheduler.adapter with type arguments of type ExecutionJobVertex Modifier and Type Method Description voidDefaultExecutionTopology. notifyExecutionGraphUpdatedWithInitializedJobVertices(DefaultExecutionGraph executionGraph, List<ExecutionJobVertex> newlyInitializedJobVertices) -
Uses of ExecutionJobVertex in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type ExecutionJobVertex Modifier and Type Method Description voidBatchJobRecoveryContext. initializeJobVertex(ExecutionJobVertex jobVertex, int parallelism, Map<IntermediateDataSetID,JobVertexInputInfo> jobVertexInputInfos, long createTimestamp)Initializes a given job vertex with the specified parallelism and input information.Method parameters in org.apache.flink.runtime.scheduler.adaptivebatch with type arguments of type ExecutionJobVertex Modifier and Type Method Description voidBatchJobRecoveryContext. updateTopology(List<ExecutionJobVertex> newlyInitializedJobVertices)Updates the job topology with new job vertices that were initialized.
-