Uses of Class
org.apache.flink.runtime.client.JobExecutionException
-
-
Uses of JobExecutionException in org.apache.flink.runtime.client
Subclasses of JobExecutionException in org.apache.flink.runtime.client Modifier and Type Class Description classDuplicateJobSubmissionExceptionException which is returned upon job submission if the submitted job is currently being executed.classJobCancellationExceptionAn exception which is thrown by the JobClient if a job is aborted as a result of a user cancellation.classJobInitializationExceptionAn exception indicating that the job has failed in the INITIALIZING job status.classJobSubmissionExceptionThis exception denotes an error while submitting a job to the JobManager. -
Uses of JobExecutionException in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that throw JobExecutionException Modifier and Type Method Description 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 voidDefaultExecutionGraphBuilder. initJobVerticesOnMaster(Iterable<JobVertex> jobVertices, ClassLoader classLoader, org.slf4j.Logger log, VertexParallelismStore vertexParallelismStore, String jobName, org.apache.flink.api.common.JobID jobId) -
Uses of JobExecutionException in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster that throw JobExecutionException Modifier and Type Method Description org.apache.flink.api.common.JobExecutionResultJobResult. toJobExecutionResult(ClassLoader classLoader)Converts theJobResultto aJobExecutionResult. -
Uses of JobExecutionException in org.apache.flink.runtime.minicluster
Methods in org.apache.flink.runtime.minicluster that throw JobExecutionException Modifier and Type Method Description org.apache.flink.api.common.JobExecutionResultMiniCluster. executeJobBlocking(JobGraph job)This method runs a job in blocking mode.voidMiniCluster. runDetached(JobGraph job)This method executes a job in detached mode. -
Uses of JobExecutionException in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that throw JobExecutionException Modifier and Type Method Description static CheckpointIDCounterSchedulerUtils. createCheckpointIDCounterIfCheckpointingIsEnabled(JobGraph jobGraph, CheckpointRecoveryFactory checkpointRecoveryFactory)static CompletedCheckpointStoreSchedulerUtils. createCompletedCheckpointStoreIfCheckpointingIsEnabled(JobGraph jobGraph, org.apache.flink.configuration.Configuration configuration, CheckpointRecoveryFactory checkpointRecoveryFactory, Executor ioExecutor, org.slf4j.Logger log) -
Uses of JobExecutionException in org.apache.flink.runtime.scheduler.adaptive
Constructors in org.apache.flink.runtime.scheduler.adaptive that throw JobExecutionException Constructor Description AdaptiveScheduler(AdaptiveScheduler.Settings settings, JobGraph jobGraph, JobResourceRequirements jobResourceRequirements, org.apache.flink.configuration.Configuration configuration, DeclarativeSlotPool declarativeSlotPool, SlotAllocator slotAllocator, Executor ioExecutor, ClassLoader userCodeClassLoader, CheckpointsCleaner checkpointsCleaner, CheckpointRecoveryFactory checkpointRecoveryFactory, JobManagerJobMetricGroup jobManagerJobMetricGroup, RestartBackoffTimeStrategy restartBackoffTimeStrategy, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, ExecutionGraphFactory executionGraphFactory)
-