Modifier and Type | Method and Description |
---|---|
JobListeningContext |
ClusterClient.connectToJob(JobID jobID)
Reattaches to a running job with the given job id.
|
JobExecutionResult |
ClusterClient.retrieveJob(JobID jobID)
Reattaches to a running from the supplied job id.
|
Modifier and Type | Class and Description |
---|---|
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 JobExecutionResult |
JobClient.awaitJobResult(JobListeningContext listeningContext)
Given a JobListeningContext, awaits the result of the job execution that this context is bound to
|
static JobExecutionResult |
JobClient.submitJobAndWait(akka.actor.ActorSystem actorSystem,
Configuration config,
HighAvailabilityServices highAvailabilityServices,
JobGraph jobGraph,
scala.concurrent.duration.FiniteDuration timeout,
boolean sysoutLogUpdates,
ClassLoader classLoader)
Sends a [[JobGraph]] to the JobClient actor specified by jobClient which submits it then to
the JobManager.
|
static void |
JobClient.submitJobDetached(JobManagerGateway jobManagerGateway,
Configuration config,
JobGraph jobGraph,
Time timeout,
ClassLoader classLoader)
Submits a job in detached mode.
|
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)
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,
int parallelismForAutoMax,
BlobWriter blobWriter,
Time allocationTimeout,
org.slf4j.Logger log)
Deprecated.
|
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–2019 The Apache Software Foundation. All rights reserved.