Uses of Class
org.apache.flink.runtime.JobException
-
-
Uses of JobException in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that throw JobException Modifier and Type Method Description voidDefaultExecutionGraph. addNewJobVertices(List<JobVertex> topologicallySortedNewlyJobVertices, JobManagerJobMetricGroup jobManagerJobMetricGroup, VertexParallelismStore newVerticesParallelismStore)voidExecutionGraph. addNewJobVertices(List<JobVertex> topologicallySortedNewlyJobVertices, JobManagerJobMetricGroup jobManagerJobMetricGroup, VertexParallelismStore newVerticesParallelismStore)Adds new job vertices to the execution graph based on the provided list of topologically sorted job vertices.voidDefaultExecutionGraph. attachJobGraph(List<JobVertex> verticesToAttach, JobManagerJobMetricGroup jobManagerJobMetricGroup)voidExecutionGraph. attachJobGraph(List<JobVertex> topologicallySorted, JobManagerJobMetricGroup jobManagerJobMetricGroup)static DefaultExecutionGraphDefaultExecutionGraphBuilder. buildGraph(JobGraph jobGraph, org.apache.flink.configuration.Configuration jobManagerConfig, ScheduledExecutorService futureExecutor, Executor ioExecutor, ClassLoader classLoader, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, Duration rpcTimeout, BlobWriter blobWriter, org.slf4j.Logger log, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, ExecutionDeploymentListener executionDeploymentListener, ExecutionStateUpdateListener executionStateUpdateListener, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, CheckpointStatsTracker checkpointStatsTracker, boolean isDynamicGraph, ExecutionJobVertex.Factory executionJobVertexFactory, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, boolean nonFinishedHybridPartitionShouldBeUnknown, JobManagerJobMetricGroup jobManagerJobMetricGroup, ExecutionPlanSchedulingContext executionPlanSchedulingContext)static Map<IntermediateDataSetID,JobVertexInputInfo>VertexInputInfoComputationUtils. computeVertexInputInfos(ExecutionJobVertex ejv, Function<IntermediateDataSetID,IntermediateResult> intermediateResultRetriever)voidExecutionJobVertex. connectToPredecessors(Map<IntermediateDataSetID,IntermediateResult> intermediateDataSets)voidExecution. deploy()Deploys the execution to the previously assigned resource.voidExecutionVertex. deploy()voidExecutionVertex. deployToSlot(LogicalSlot slot)protected voidExecutionJobVertex. initialize(int executionHistorySizeLimit, Duration timeout, long createTimestamp, SubtaskAttemptNumberStore initialAttemptCounts)protected voidExecutionJobVertex. initialize(int executionHistorySizeLimit, Duration timeout, long createTimestamp, SubtaskAttemptNumberStore initialAttemptCounts, ExecutionPlanSchedulingContext executionPlanSchedulingContext)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.Constructors in org.apache.flink.runtime.executiongraph that throw JobException Constructor Description ExecutionJobVertex(InternalExecutionGraphAccessor graph, JobVertex jobVertex, VertexParallelismInformation parallelismInfo, CoordinatorStore coordinatorStore, JobManagerJobMetricGroup jobManagerJobMetricGroup)SpeculativeExecutionJobVertex(InternalExecutionGraphAccessor graph, JobVertex jobVertex, VertexParallelismInformation parallelismInfo, CoordinatorStore coordinatorStore, JobManagerJobMetricGroup jobManagerJobMetricGroup) -
Uses of JobException in org.apache.flink.runtime.jobmanager.scheduler
Subclasses of JobException in org.apache.flink.runtime.jobmanager.scheduler Modifier and Type Class Description classNoResourceAvailableExceptionIndicates resource allocation failures. -
Uses of JobException in org.apache.flink.runtime.jobmaster
Subclasses of JobException in org.apache.flink.runtime.jobmaster Modifier and Type Class Description classJobNotFinishedExceptionException indicating that a Flink job has not been finished. -
Uses of JobException in org.apache.flink.runtime.scheduler
Subclasses of JobException in org.apache.flink.runtime.scheduler Modifier and Type Class Description classClusterDatasetCorruptedExceptionIndicates some task fail to consume cluster dataset.Methods in org.apache.flink.runtime.scheduler that throw JobException Modifier and Type Method Description voidDefaultExecutionOperations. deploy(Execution execution)voidExecutionOperations. deploy(Execution execution)Deploy the execution. -
Uses of JobException in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch that throw JobException 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.
-