Package | Description |
---|---|
org.apache.flink.runtime.jobmanager |
Modifier and Type | Method and Description |
---|---|
scala.Option<SubmittedJobGraph> |
SubmittedJobGraphStore.recoverJobGraph(org.apache.flink.api.common.JobID jobId)
Returns the
SubmittedJobGraph with the given JobID . |
scala.Option<SubmittedJobGraph> |
ZooKeeperSubmittedJobGraphStore.recoverJobGraph(org.apache.flink.api.common.JobID jobId) |
scala.Option<SubmittedJobGraph> |
StandaloneSubmittedJobGraphStore.recoverJobGraph(org.apache.flink.api.common.JobID jobId) |
List<SubmittedJobGraph> |
SubmittedJobGraphStore.recoverJobGraphs()
Returns a list of all submitted
JobGraph instances. |
List<SubmittedJobGraph> |
ZooKeeperSubmittedJobGraphStore.recoverJobGraphs() |
List<SubmittedJobGraph> |
StandaloneSubmittedJobGraphStore.recoverJobGraphs() |
Modifier and Type | Method and Description |
---|---|
void |
SubmittedJobGraphStore.putJobGraph(SubmittedJobGraph jobGraph)
Adds the
SubmittedJobGraph instance. |
void |
ZooKeeperSubmittedJobGraphStore.putJobGraph(SubmittedJobGraph jobGraph) |
void |
StandaloneSubmittedJobGraphStore.putJobGraph(SubmittedJobGraph jobGraph) |
Constructor and Description |
---|
ZooKeeperSubmittedJobGraphStore(org.apache.curator.framework.CuratorFramework client,
String currentJobsPath,
StateStorageHelper<SubmittedJobGraph> stateStorage)
Submitted job graph store backed by ZooKeeper
|
Copyright © 2014–2016 The Apache Software Foundation. All rights reserved.