Package | Description |
---|---|
org.apache.flink.runtime.client | |
org.apache.flink.runtime.executiongraph | |
org.apache.flink.runtime.jobmaster | |
org.apache.flink.runtime.minicluster |
Modifier and Type | Class and Description |
---|---|
class |
DuplicateJobSubmissionException
Exception which is returned upon job submission if the submitted job
is currently being executed.
|
class |
JobCancellationException
An exception which is thrown by the JobClient if a job is aborted as a result of a user
cancellation.
|
class |
JobRetrievalException
Exception used to indicate that a job couldn't be retrieved from the JobManager
|
class |
JobSubmissionException
This exception denotes an error while submitting a job to the JobManager.
|
class |
JobTimeoutException
An exception which is thrown by the JobClient if the job manager is no longer reachable.
|
Modifier and Type | Method and Description |
---|---|
static ExecutionGraph |
ExecutionGraphBuilder.buildGraph(ExecutionGraph prior,
JobGraph jobGraph,
Configuration jobManagerConfig,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
SlotProvider slotProvider,
ClassLoader classLoader,
CheckpointRecoveryFactory recoveryFactory,
Time rpcTimeout,
RestartStrategy restartStrategy,
MetricGroup metrics,
BlobWriter blobWriter,
Time allocationTimeout,
org.slf4j.Logger log,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker)
Builds the ExecutionGraph from the JobGraph.
|
static ExecutionGraph |
ExecutionGraphBuilder.buildGraph(ExecutionGraph prior,
JobGraph jobGraph,
Configuration jobManagerConfig,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
SlotProvider slotProvider,
ClassLoader classLoader,
CheckpointRecoveryFactory recoveryFactory,
Time rpcTimeout,
RestartStrategy restartStrategy,
MetricGroup metrics,
BlobWriter blobWriter,
Time allocationTimeout,
org.slf4j.Logger log,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
FailoverStrategy.Factory failoverStrategyFactory) |
Modifier and Type | Method and Description |
---|---|
JobExecutionResult |
JobResult.toJobExecutionResult(ClassLoader classLoader)
Converts the
JobResult to a JobExecutionResult . |
Modifier and Type | Method and Description |
---|---|
JobExecutionResult |
MiniCluster.executeJobBlocking(JobGraph job)
This method runs a job in blocking mode.
|
JobExecutionResult |
JobExecutor.executeJobBlocking(JobGraph jobGraph)
Run the given job and block until its execution result can be returned.
|
void |
MiniCluster.runDetached(JobGraph job)
This method executes a job in detached mode.
|
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.