Interface AccessExecutionGraph
-
- All Superinterfaces:
JobStatusProvider
- All Known Subinterfaces:
ExecutionGraph
- All Known Implementing Classes:
ArchivedExecutionGraph,DefaultExecutionGraph
public interface AccessExecutionGraph extends JobStatusProvider
Common interface for the runtimeDefaultExecutionGraphandArchivedExecutionGraph.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description 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<? extends AccessExecutionVertex>getAllExecutionVertices()Returns an iterable containing all execution vertices for this execution graph.Map<JobVertexID,? extends AccessExecutionJobVertex>getAllVertices()Returns a map containing all job vertices for this execution graph.org.apache.flink.api.common.ArchivedExecutionConfiggetArchivedExecutionConfig()Returns theArchivedExecutionConfigfor this execution graph.Optional<String>getChangelogStorageName()Returns the changelog storage name for this ExecutionGraph.CheckpointCoordinatorConfigurationgetCheckpointCoordinatorConfiguration()Returns theCheckpointCoordinatorConfigurationornullif checkpointing is disabled.CheckpointStatsSnapshotgetCheckpointStatsSnapshot()Returns a snapshot of the checkpoint statistics ornullif checkpointing is disabled.Optional<String>getCheckpointStorageName()Returns the checkpoint storage name for this ExecutionGraph.ErrorInfogetFailureInfo()Returns the exception that caused the job to fail.org.apache.flink.api.common.JobIDgetJobID()Returns theJobIDfor this execution graph.StringgetJobName()Returns the job name for the execution graph.JobTypegetJobType()Returns theJobTypefor this execution graph.AccessExecutionJobVertexgetJobVertex(JobVertexID id)Returns the job vertex for the givenJobVertexID.StringgetJsonPlan()Returns the job plan as a JSON string.org.apache.flink.api.common.JobStatusgetState()Returns the currentJobStatusfor this execution graph.Optional<String>getStateBackendName()Returns the state backend name for this ExecutionGraph.longgetStatusTimestamp(org.apache.flink.api.common.JobStatus status)Returns the timestamp for the givenJobStatus.Iterable<? extends AccessExecutionJobVertex>getVerticesTopologically()Returns an iterable containing all job vertices for this execution graph in the order they were created.org.apache.flink.util.TernaryBooleanisChangelogStateBackendEnabled()Returns whether the state changelog is enabled for this ExecutionGraph.booleanisStoppable()Returns whether the job for this execution graph is stoppable.
-
-
-
Method Detail
-
getJsonPlan
String getJsonPlan()
Returns the job plan as a JSON string.- Returns:
- job plan as a JSON string
-
getJobID
org.apache.flink.api.common.JobID getJobID()
Returns theJobIDfor this execution graph.- Returns:
- job ID for this execution graph
-
getJobName
String getJobName()
Returns the job name for the execution graph.- Returns:
- job name for this execution graph
-
getState
org.apache.flink.api.common.JobStatus getState()
Returns the currentJobStatusfor this execution graph.- Specified by:
getStatein interfaceJobStatusProvider- Returns:
- job status for this execution graph
-
getJobType
@Nullable JobType getJobType()
Returns theJobTypefor this execution graph.- Returns:
- job type for this execution graph. It may be null when an exception occurs.
-
getFailureInfo
@Nullable ErrorInfo getFailureInfo()
Returns the exception that caused the job to fail. This is the first root exception that was not recoverable and triggered job failure.- Returns:
- failure causing exception, or null
-
getJobVertex
@Nullable AccessExecutionJobVertex getJobVertex(JobVertexID id)
Returns the job vertex for the givenJobVertexID.- Parameters:
id- id of job vertex to be returned- Returns:
- job vertex for the given id, or
null
-
getAllVertices
Map<JobVertexID,? extends AccessExecutionJobVertex> getAllVertices()
Returns a map containing all job vertices for this execution graph.- Returns:
- map containing all job vertices for this execution graph
-
getVerticesTopologically
Iterable<? extends AccessExecutionJobVertex> getVerticesTopologically()
Returns an iterable containing all job vertices for this execution graph in the order they were created.- Returns:
- iterable containing all job vertices for this execution graph in the order they were created
-
getAllExecutionVertices
Iterable<? extends AccessExecutionVertex> getAllExecutionVertices()
Returns an iterable containing all execution vertices for this execution graph.- Returns:
- iterable containing all execution vertices for this execution graph
-
getStatusTimestamp
long getStatusTimestamp(org.apache.flink.api.common.JobStatus status)
Returns the timestamp for the givenJobStatus.- Specified by:
getStatusTimestampin interfaceJobStatusProvider- Parameters:
status- status for which the timestamp should be returned- Returns:
- timestamp for the given job status
-
getCheckpointCoordinatorConfiguration
@Nullable CheckpointCoordinatorConfiguration getCheckpointCoordinatorConfiguration()
Returns theCheckpointCoordinatorConfigurationornullif checkpointing is disabled.- Returns:
- JobCheckpointingConfiguration for this execution graph
-
getCheckpointStatsSnapshot
@Nullable CheckpointStatsSnapshot getCheckpointStatsSnapshot()
Returns a snapshot of the checkpoint statistics ornullif checkpointing is disabled.- Returns:
- Snapshot of the checkpoint statistics for this execution graph
-
getArchivedExecutionConfig
@Nullable org.apache.flink.api.common.ArchivedExecutionConfig getArchivedExecutionConfig()
Returns theArchivedExecutionConfigfor this execution graph.- Returns:
- execution config summary for this execution graph, or null in case of errors
-
isStoppable
boolean isStoppable()
Returns whether the job for this execution graph is stoppable.- Returns:
- true, if all sources tasks are stoppable, false otherwise
-
getAccumulatorResultsStringified
StringifiedAccumulatorResult[] getAccumulatorResultsStringified()
Returns the aggregated user-defined accumulators as strings.- Returns:
- aggregated user-defined accumulators as strings.
-
getAccumulatorsSerialized
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.- Returns:
- map containing serialized values of user-defined accumulators
-
getStateBackendName
Optional<String> getStateBackendName()
Returns the state backend name for this ExecutionGraph.- Returns:
- The state backend name, or an empty Optional in the case of batch jobs
-
getCheckpointStorageName
Optional<String> getCheckpointStorageName()
Returns the checkpoint storage name for this ExecutionGraph.- Returns:
- The checkpoint storage name, or an empty Optional in the case of batch jobs
-
isChangelogStateBackendEnabled
org.apache.flink.util.TernaryBoolean isChangelogStateBackendEnabled()
Returns whether the state changelog is enabled for this ExecutionGraph.- Returns:
- true, if state changelog enabled, false otherwise.
-
-