Package | Description |
---|---|
org.apache.flink.runtime.client | |
org.apache.flink.runtime.jobgraph.jsonplan | |
org.apache.flink.runtime.jobmanager |
Modifier and Type | Method and Description |
---|---|
static JobExecutionResult |
JobClient.submitJobAndWait(akka.actor.ActorSystem actorSystem,
LeaderRetrievalService leaderRetrievalService,
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(ActorGateway jobManagerGateway,
JobGraph jobGraph,
scala.concurrent.duration.FiniteDuration timeout,
ClassLoader classLoader)
Submits a job in detached mode.
|
static void |
JobClient.uploadJarFiles(JobGraph jobGraph,
ActorGateway jobManagerGateway,
scala.concurrent.duration.FiniteDuration timeout)
Uploads the specified jar files of the [[JobGraph]] jobGraph to the BlobServer of the
JobManager.
|
Modifier and Type | Method and Description |
---|---|
static String |
JsonPlanGenerator.generatePlan(JobGraph jg) |
Modifier and Type | Method and Description |
---|---|
JobGraph |
SubmittedJobGraph.getJobGraph()
Returns the submitted
JobGraph . |
Constructor and Description |
---|
SubmittedJobGraph(JobGraph jobGraph,
org.apache.flink.runtime.jobmanager.JobInfo jobInfo)
Creates a
SubmittedJobGraph . |
Copyright © 2014–2016 The Apache Software Foundation. All rights reserved.