ArchivedExecutionGraph(org.apache.flink.api.common.JobID jobID,
String jobName,
Map<JobVertexID,ArchivedExecutionJobVertex> tasks,
List<ArchivedExecutionJobVertex> verticesInCreationOrder,
long[] stateTimestamps,
JobStatus state,
String failureCause,
String jsonPlan,
StringifiedAccumulatorResult[] archivedUserAccumulators,
Map<String,org.apache.flink.util.SerializedValue<Object>> serializedUserAccumulators,
org.apache.flink.api.common.ArchivedExecutionConfig executionConfig,
boolean isStoppable,
JobCheckpointingSettings jobCheckpointingSettings,
CheckpointStatsSnapshot checkpointStatsSnapshot) |
ArchivedExecutionGraph(org.apache.flink.api.common.JobID jobID,
String jobName,
Map<JobVertexID,ArchivedExecutionJobVertex> tasks,
List<ArchivedExecutionJobVertex> verticesInCreationOrder,
long[] stateTimestamps,
JobStatus state,
String failureCause,
String jsonPlan,
StringifiedAccumulatorResult[] archivedUserAccumulators,
Map<String,org.apache.flink.util.SerializedValue<Object>> serializedUserAccumulators,
org.apache.flink.api.common.ArchivedExecutionConfig executionConfig,
boolean isStoppable,
JobCheckpointingSettings jobCheckpointingSettings,
CheckpointStatsSnapshot checkpointStatsSnapshot) |