public class ArchivedExecutionGraph extends Object implements AccessExecutionGraph, Serializable
ExecutionGraph
.Constructor and Description |
---|
ArchivedExecutionGraph(JobID jobID,
String jobName,
Map<JobVertexID,ArchivedExecutionJobVertex> tasks,
List<ArchivedExecutionJobVertex> verticesInCreationOrder,
long[] stateTimestamps,
JobStatus state,
JobType jobType,
ErrorInfo failureCause,
String jsonPlan,
StringifiedAccumulatorResult[] archivedUserAccumulators,
Map<String,SerializedValue<OptionalFailure<Object>>> serializedUserAccumulators,
ArchivedExecutionConfig executionConfig,
boolean isStoppable,
CheckpointCoordinatorConfiguration jobCheckpointingConfiguration,
CheckpointStatsSnapshot checkpointStatsSnapshot,
String stateBackendName,
String checkpointStorageName,
TernaryBoolean stateChangelogEnabled,
String changelogStorageName) |
Modifier and Type | Method and Description |
---|---|
static ArchivedExecutionGraph |
createFrom(ExecutionGraph executionGraph)
Create a
ArchivedExecutionGraph from the given ExecutionGraph . |
static ArchivedExecutionGraph |
createFrom(ExecutionGraph executionGraph,
JobStatus statusOverride)
Create a
ArchivedExecutionGraph from the given ExecutionGraph . |
static ArchivedExecutionGraph |
createSparseArchivedExecutionGraph(JobID jobId,
String jobName,
JobStatus jobStatus,
JobType jobType,
Throwable throwable,
JobCheckpointingSettings checkpointingSettings,
long initializationTimestamp)
Create a sparse ArchivedExecutionGraph for a job.
|
static ArchivedExecutionGraph |
createSparseArchivedExecutionGraphWithJobVertices(JobID jobId,
String jobName,
JobStatus jobStatus,
JobType jobType,
Throwable throwable,
JobCheckpointingSettings checkpointingSettings,
long initializationTimestamp,
Iterable<JobVertex> jobVertices,
VertexParallelismStore initialParallelismStore) |
StringifiedAccumulatorResult[] |
getAccumulatorResultsStringified()
Returns the aggregated user-defined accumulators as strings.
|
Map<String,SerializedValue<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.
|
ArchivedExecutionConfig |
getArchivedExecutionConfig()
Returns the
ArchivedExecutionConfig for this execution graph. |
Optional<String> |
getChangelogStorageName()
Returns the changelog storage name for this ExecutionGraph.
|
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. |
Optional<String> |
getCheckpointStorageName()
Returns the checkpoint storage name for this ExecutionGraph.
|
ErrorInfo |
getFailureInfo()
Returns the exception that caused the job to fail.
|
JobID |
getJobID()
Returns the
JobID for this execution graph. |
String |
getJobName()
Returns the job name for the execution graph.
|
JobType |
getJobType()
Returns the
JobType for this execution graph. |
ArchivedExecutionJobVertex |
getJobVertex(JobVertexID id)
Returns the job vertex for the given
JobVertexID . |
String |
getJsonPlan()
Returns the job plan as a JSON string.
|
JobStatus |
getState()
Returns the current
JobStatus for this execution graph. |
Optional<String> |
getStateBackendName()
Returns the state backend name for this ExecutionGraph.
|
long |
getStatusTimestamp(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.
|
TernaryBoolean |
isChangelogStateBackendEnabled()
Returns whether the state changelog is enabled for this ExecutionGraph.
|
boolean |
isStoppable()
Returns whether the job for this execution graph is stoppable.
|
public ArchivedExecutionGraph(JobID jobID, String jobName, Map<JobVertexID,ArchivedExecutionJobVertex> tasks, List<ArchivedExecutionJobVertex> verticesInCreationOrder, long[] stateTimestamps, JobStatus state, @Nullable JobType jobType, @Nullable ErrorInfo failureCause, String jsonPlan, StringifiedAccumulatorResult[] archivedUserAccumulators, Map<String,SerializedValue<OptionalFailure<Object>>> serializedUserAccumulators, ArchivedExecutionConfig executionConfig, boolean isStoppable, @Nullable CheckpointCoordinatorConfiguration jobCheckpointingConfiguration, @Nullable CheckpointStatsSnapshot checkpointStatsSnapshot, @Nullable String stateBackendName, @Nullable String checkpointStorageName, @Nullable TernaryBoolean stateChangelogEnabled, @Nullable String changelogStorageName)
public String getJsonPlan()
AccessExecutionGraph
getJsonPlan
in interface AccessExecutionGraph
public JobID getJobID()
AccessExecutionGraph
JobID
for this execution graph.getJobID
in interface AccessExecutionGraph
public String getJobName()
AccessExecutionGraph
getJobName
in interface AccessExecutionGraph
public JobStatus getState()
AccessExecutionGraph
JobStatus
for this execution graph.getState
in interface AccessExecutionGraph
getState
in interface JobStatusProvider
public JobType getJobType()
AccessExecutionGraph
JobType
for this execution graph.getJobType
in interface AccessExecutionGraph
@Nullable public ErrorInfo getFailureInfo()
AccessExecutionGraph
getFailureInfo
in interface AccessExecutionGraph
public ArchivedExecutionJobVertex getJobVertex(JobVertexID id)
AccessExecutionGraph
JobVertexID
.getJobVertex
in interface AccessExecutionGraph
id
- id of job vertex to be returnednull
public Map<JobVertexID,AccessExecutionJobVertex> getAllVertices()
AccessExecutionGraph
getAllVertices
in interface AccessExecutionGraph
public Iterable<ArchivedExecutionJobVertex> getVerticesTopologically()
AccessExecutionGraph
getVerticesTopologically
in interface AccessExecutionGraph
public Iterable<ArchivedExecutionVertex> getAllExecutionVertices()
AccessExecutionGraph
getAllExecutionVertices
in interface AccessExecutionGraph
public long getStatusTimestamp(JobStatus status)
AccessExecutionGraph
JobStatus
.getStatusTimestamp
in interface AccessExecutionGraph
getStatusTimestamp
in interface JobStatusProvider
status
- status for which the timestamp should be returnedpublic CheckpointCoordinatorConfiguration getCheckpointCoordinatorConfiguration()
AccessExecutionGraph
CheckpointCoordinatorConfiguration
or null
if checkpointing
is disabled.getCheckpointCoordinatorConfiguration
in interface AccessExecutionGraph
public CheckpointStatsSnapshot getCheckpointStatsSnapshot()
AccessExecutionGraph
null
if checkpointing is
disabled.getCheckpointStatsSnapshot
in interface AccessExecutionGraph
public ArchivedExecutionConfig getArchivedExecutionConfig()
AccessExecutionGraph
ArchivedExecutionConfig
for this execution graph.getArchivedExecutionConfig
in interface AccessExecutionGraph
public boolean isStoppable()
AccessExecutionGraph
isStoppable
in interface AccessExecutionGraph
public StringifiedAccumulatorResult[] getAccumulatorResultsStringified()
AccessExecutionGraph
getAccumulatorResultsStringified
in interface AccessExecutionGraph
public Map<String,SerializedValue<OptionalFailure<Object>>> getAccumulatorsSerialized()
AccessExecutionGraph
getAccumulatorsSerialized
in interface AccessExecutionGraph
public Optional<String> getStateBackendName()
AccessExecutionGraph
getStateBackendName
in interface AccessExecutionGraph
public Optional<String> getCheckpointStorageName()
AccessExecutionGraph
getCheckpointStorageName
in interface AccessExecutionGraph
public TernaryBoolean isChangelogStateBackendEnabled()
AccessExecutionGraph
isChangelogStateBackendEnabled
in interface AccessExecutionGraph
public Optional<String> getChangelogStorageName()
AccessExecutionGraph
getChangelogStorageName
in interface AccessExecutionGraph
public static ArchivedExecutionGraph createFrom(ExecutionGraph executionGraph)
ArchivedExecutionGraph
from the given ExecutionGraph
.executionGraph
- to create the ArchivedExecutionGraph frompublic static ArchivedExecutionGraph createFrom(ExecutionGraph executionGraph, @Nullable JobStatus statusOverride)
ArchivedExecutionGraph
from the given ExecutionGraph
.executionGraph
- to create the ArchivedExecutionGraph fromstatusOverride
- optionally overrides the JobStatus of the ExecutionGraph with a
non-globally-terminal state and clears timestamps of globally-terminal statespublic static ArchivedExecutionGraph createSparseArchivedExecutionGraph(JobID jobId, String jobName, JobStatus jobStatus, @Nullable JobType jobType, @Nullable Throwable throwable, @Nullable JobCheckpointingSettings checkpointingSettings, long initializationTimestamp)
public static ArchivedExecutionGraph createSparseArchivedExecutionGraphWithJobVertices(JobID jobId, String jobName, JobStatus jobStatus, JobType jobType, @Nullable Throwable throwable, @Nullable JobCheckpointingSettings checkpointingSettings, long initializationTimestamp, Iterable<JobVertex> jobVertices, VertexParallelismStore initialParallelismStore)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.