public class ArchivedExecutionGraph extends Object implements AccessExecutionGraph, Serializable
ExecutionGraph
.构造器和说明 |
---|
ArchivedExecutionGraph(org.apache.flink.api.common.JobID jobID,
String jobName,
Map<JobVertexID,ArchivedExecutionJobVertex> tasks,
List<ArchivedExecutionJobVertex> verticesInCreationOrder,
long[] stateTimestamps,
org.apache.flink.api.common.JobStatus state,
ErrorInfo failureCause,
String jsonPlan,
StringifiedAccumulatorResult[] archivedUserAccumulators,
Map<String,org.apache.flink.util.SerializedValue<org.apache.flink.util.OptionalFailure<Object>>> serializedUserAccumulators,
org.apache.flink.api.common.ArchivedExecutionConfig executionConfig,
boolean isStoppable,
CheckpointCoordinatorConfiguration jobCheckpointingConfiguration,
CheckpointStatsSnapshot checkpointStatsSnapshot,
String stateBackendName) |
限定符和类型 | 方法和说明 |
---|---|
static ArchivedExecutionGraph |
createFrom(ExecutionGraph executionGraph)
Create a
ArchivedExecutionGraph from the given ExecutionGraph . |
StringifiedAccumulatorResult[] |
getAccumulatorResultsStringified()
Returns the aggregated user-defined accumulators as strings.
|
Map<String,org.apache.flink.util.SerializedValue<org.apache.flink.util.OptionalFailure<Object>>> |
getAccumulatorsSerialized()
Returns a map containing the serialized values of user-defined accumulators.
|
Iterable<ArchivedExecutionVertex> |
getAllExecutionVertices()
Returns an iterable containing all execution vertices for this execution graph.
|
Map<JobVertexID,AccessExecutionJobVertex> |
getAllVertices()
Returns a map containing all job vertices for this execution graph.
|
org.apache.flink.api.common.ArchivedExecutionConfig |
getArchivedExecutionConfig()
Returns the
ArchivedExecutionConfig for this execution graph. |
CheckpointCoordinatorConfiguration |
getCheckpointCoordinatorConfiguration()
Returns the
CheckpointCoordinatorConfiguration or null if
checkpointing is disabled. |
CheckpointStatsSnapshot |
getCheckpointStatsSnapshot()
Returns a snapshot of the checkpoint statistics or
null if
checkpointing is disabled. |
ErrorInfo |
getFailureInfo()
Returns the exception that caused the job to fail.
|
org.apache.flink.api.common.JobID |
getJobID()
Returns the
JobID for this execution graph. |
String |
getJobName()
Returns the job name for the execution graph.
|
ArchivedExecutionJobVertex |
getJobVertex(JobVertexID id)
Returns the job vertex for the given
JobVertexID . |
String |
getJsonPlan()
Returns the job plan as a JSON string.
|
org.apache.flink.api.common.JobStatus |
getState()
Returns the current
JobStatus for this execution graph. |
Optional<String> |
getStateBackendName()
Returns the state backend name for this ExecutionGraph.
|
long |
getStatusTimestamp(org.apache.flink.api.common.JobStatus status)
Returns the timestamp for the given
JobStatus . |
Iterable<ArchivedExecutionJobVertex> |
getVerticesTopologically()
Returns an iterable containing all job vertices for this execution graph in the order they were created.
|
boolean |
isArchived()
Returns whether this execution graph was archived.
|
boolean |
isStoppable()
Returns whether the job for this execution graph is stoppable.
|
public ArchivedExecutionGraph(org.apache.flink.api.common.JobID jobID, String jobName, Map<JobVertexID,ArchivedExecutionJobVertex> tasks, List<ArchivedExecutionJobVertex> verticesInCreationOrder, long[] stateTimestamps, org.apache.flink.api.common.JobStatus state, @Nullable ErrorInfo failureCause, String jsonPlan, StringifiedAccumulatorResult[] archivedUserAccumulators, Map<String,org.apache.flink.util.SerializedValue<org.apache.flink.util.OptionalFailure<Object>>> serializedUserAccumulators, org.apache.flink.api.common.ArchivedExecutionConfig executionConfig, boolean isStoppable, @Nullable CheckpointCoordinatorConfiguration jobCheckpointingConfiguration, @Nullable CheckpointStatsSnapshot checkpointStatsSnapshot, @Nullable String stateBackendName)
public String getJsonPlan()
AccessExecutionGraph
getJsonPlan
在接口中 AccessExecutionGraph
public org.apache.flink.api.common.JobID getJobID()
AccessExecutionGraph
JobID
for this execution graph.getJobID
在接口中 AccessExecutionGraph
public String getJobName()
AccessExecutionGraph
getJobName
在接口中 AccessExecutionGraph
public org.apache.flink.api.common.JobStatus getState()
AccessExecutionGraph
JobStatus
for this execution graph.getState
在接口中 AccessExecutionGraph
@Nullable public ErrorInfo getFailureInfo()
AccessExecutionGraph
getFailureInfo
在接口中 AccessExecutionGraph
public ArchivedExecutionJobVertex getJobVertex(JobVertexID id)
AccessExecutionGraph
JobVertexID
.getJobVertex
在接口中 AccessExecutionGraph
id
- id of job vertex to be returnednull
public Map<JobVertexID,AccessExecutionJobVertex> getAllVertices()
AccessExecutionGraph
getAllVertices
在接口中 AccessExecutionGraph
public Iterable<ArchivedExecutionJobVertex> getVerticesTopologically()
AccessExecutionGraph
getVerticesTopologically
在接口中 AccessExecutionGraph
public Iterable<ArchivedExecutionVertex> getAllExecutionVertices()
AccessExecutionGraph
getAllExecutionVertices
在接口中 AccessExecutionGraph
public long getStatusTimestamp(org.apache.flink.api.common.JobStatus status)
AccessExecutionGraph
JobStatus
.getStatusTimestamp
在接口中 AccessExecutionGraph
status
- status for which the timestamp should be returnedpublic CheckpointCoordinatorConfiguration getCheckpointCoordinatorConfiguration()
AccessExecutionGraph
CheckpointCoordinatorConfiguration
or null
if
checkpointing is disabled.getCheckpointCoordinatorConfiguration
在接口中 AccessExecutionGraph
public CheckpointStatsSnapshot getCheckpointStatsSnapshot()
AccessExecutionGraph
null
if
checkpointing is disabled.getCheckpointStatsSnapshot
在接口中 AccessExecutionGraph
public boolean isArchived()
AccessExecutionGraph
isArchived
在接口中 AccessExecutionGraph
public org.apache.flink.api.common.ArchivedExecutionConfig getArchivedExecutionConfig()
AccessExecutionGraph
ArchivedExecutionConfig
for this execution graph.getArchivedExecutionConfig
在接口中 AccessExecutionGraph
public boolean isStoppable()
AccessExecutionGraph
isStoppable
在接口中 AccessExecutionGraph
public StringifiedAccumulatorResult[] getAccumulatorResultsStringified()
AccessExecutionGraph
getAccumulatorResultsStringified
在接口中 AccessExecutionGraph
public Map<String,org.apache.flink.util.SerializedValue<org.apache.flink.util.OptionalFailure<Object>>> getAccumulatorsSerialized()
AccessExecutionGraph
getAccumulatorsSerialized
在接口中 AccessExecutionGraph
public Optional<String> getStateBackendName()
AccessExecutionGraph
getStateBackendName
在接口中 AccessExecutionGraph
public static ArchivedExecutionGraph createFrom(ExecutionGraph executionGraph)
ArchivedExecutionGraph
from the given ExecutionGraph
.executionGraph
- to create the ArchivedExecutionGraph fromCopyright © 2014–2020 The Apache Software Foundation. All rights reserved.