public class SingleJobSubmittedJobGraphStore extends Object implements SubmittedJobGraphStore
SubmittedJobGraphStore
implementation for a single job.SubmittedJobGraphStore.SubmittedJobGraphListener
Constructor and Description |
---|
SingleJobSubmittedJobGraphStore(JobGraph jobGraph) |
Modifier and Type | Method and Description |
---|---|
Collection<org.apache.flink.api.common.JobID> |
getJobIds()
Get all job ids of submitted job graphs to the submitted job graph store.
|
void |
putJobGraph(SubmittedJobGraph jobGraph)
Adds the
SubmittedJobGraph instance. |
SubmittedJobGraph |
recoverJobGraph(org.apache.flink.api.common.JobID jobId)
|
void |
removeJobGraph(org.apache.flink.api.common.JobID jobId)
Removes the
SubmittedJobGraph with the given JobID if it exists. |
void |
start(SubmittedJobGraphStore.SubmittedJobGraphListener jobGraphListener)
Starts the
SubmittedJobGraphStore service. |
void |
stop()
Stops the
SubmittedJobGraphStore service. |
public SingleJobSubmittedJobGraphStore(JobGraph jobGraph)
public void start(SubmittedJobGraphStore.SubmittedJobGraphListener jobGraphListener) throws Exception
SubmittedJobGraphStore
SubmittedJobGraphStore
service.start
in interface SubmittedJobGraphStore
Exception
public void stop() throws Exception
SubmittedJobGraphStore
SubmittedJobGraphStore
service.stop
in interface SubmittedJobGraphStore
Exception
public SubmittedJobGraph recoverJobGraph(org.apache.flink.api.common.JobID jobId) throws Exception
SubmittedJobGraphStore
recoverJobGraph
in interface SubmittedJobGraphStore
Exception
public void putJobGraph(SubmittedJobGraph jobGraph) throws Exception
SubmittedJobGraphStore
SubmittedJobGraph
instance.
If a job graph with the same JobID
exists, it is replaced.
putJobGraph
in interface SubmittedJobGraphStore
Exception
public void removeJobGraph(org.apache.flink.api.common.JobID jobId) throws Exception
SubmittedJobGraphStore
SubmittedJobGraph
with the given JobID
if it exists.removeJobGraph
in interface SubmittedJobGraphStore
Exception
public Collection<org.apache.flink.api.common.JobID> getJobIds() throws Exception
SubmittedJobGraphStore
getJobIds
in interface SubmittedJobGraphStore
Exception
- if the operation failsCopyright © 2014–2018 The Apache Software Foundation. All rights reserved.