Uses of Class
org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
-
Uses of ArchivedExecutionGraph in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return ArchivedExecutionGraph Modifier and Type Method Description static ArchivedExecutionGraph
ArchivedExecutionGraph. createFrom(ExecutionGraph executionGraph)
Create aArchivedExecutionGraph
from the givenExecutionGraph
.static ArchivedExecutionGraph
ArchivedExecutionGraph. createFrom(ExecutionGraph executionGraph, org.apache.flink.api.common.JobStatus statusOverride)
Create aArchivedExecutionGraph
from the givenExecutionGraph
.static ArchivedExecutionGraph
ArchivedExecutionGraph. createSparseArchivedExecutionGraph(org.apache.flink.api.common.JobID jobId, String jobName, org.apache.flink.api.common.JobStatus jobStatus, JobType jobType, Throwable throwable, JobCheckpointingSettings checkpointingSettings, long initializationTimestamp)
Create a sparse ArchivedExecutionGraph for a job.static ArchivedExecutionGraph
ArchivedExecutionGraph. createSparseArchivedExecutionGraphWithJobVertices(org.apache.flink.api.common.JobID jobId, String jobName, org.apache.flink.api.common.JobStatus jobStatus, JobType jobType, Throwable throwable, JobCheckpointingSettings checkpointingSettings, long initializationTimestamp, Iterable<JobVertex> jobVertices, VertexParallelismStore initialParallelismStore)
-
Uses of ArchivedExecutionGraph in org.apache.flink.runtime.jobmaster
Constructor parameters in org.apache.flink.runtime.jobmaster with type arguments of type ArchivedExecutionGraph Constructor Description DefaultJobMasterServiceProcess(org.apache.flink.api.common.JobID jobId, UUID leaderSessionId, JobMasterServiceFactory jobMasterServiceFactory, Function<Throwable,ArchivedExecutionGraph> failedArchivedExecutionGraphFactory)
-
Uses of ArchivedExecutionGraph in org.apache.flink.runtime.jobmaster.factories
Methods in org.apache.flink.runtime.jobmaster.factories that return ArchivedExecutionGraph Modifier and Type Method Description ArchivedExecutionGraph
DefaultJobMasterServiceProcessFactory. createArchivedExecutionGraph(org.apache.flink.api.common.JobStatus jobStatus, Throwable cause)
ArchivedExecutionGraph
JobMasterServiceProcessFactory. createArchivedExecutionGraph(org.apache.flink.api.common.JobStatus jobStatus, Throwable cause)
Creates anArchivedExecutionGraph
for the job for which this factory createsJobMasterServiceProcess
with the given jobStatus and failure cause. -
Uses of ArchivedExecutionGraph in org.apache.flink.runtime.minicluster
Methods in org.apache.flink.runtime.minicluster that return types with arguments of type ArchivedExecutionGraph Modifier and Type Method Description CompletableFuture<ArchivedExecutionGraph>
MiniCluster. getArchivedExecutionGraph(org.apache.flink.api.common.JobID jobId)
-
Uses of ArchivedExecutionGraph in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return ArchivedExecutionGraph Modifier and Type Method Description ArchivedExecutionGraph
ExecutionGraphInfo. getArchivedExecutionGraph()
Constructors in org.apache.flink.runtime.scheduler with parameters of type ArchivedExecutionGraph Constructor Description ExecutionGraphInfo(ArchivedExecutionGraph executionGraph)
ExecutionGraphInfo(ArchivedExecutionGraph executionGraph, Iterable<RootExceptionHistoryEntry> exceptionHistory)
-
Uses of ArchivedExecutionGraph in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive that return ArchivedExecutionGraph Modifier and Type Method Description ArchivedExecutionGraph
AdaptiveScheduler. getArchivedExecutionGraph(org.apache.flink.api.common.JobStatus jobStatus, Throwable cause)
Methods in org.apache.flink.runtime.scheduler.adaptive with parameters of type ArchivedExecutionGraph Modifier and Type Method Description void
AdaptiveScheduler. goToFinished(ArchivedExecutionGraph archivedExecutionGraph)
void
StateTransitions.ToFinished. goToFinished(ArchivedExecutionGraph archivedExecutionGraph)
Transitions into theFinished
state.void
AdaptiveScheduler. onFinished(ArchivedExecutionGraph archivedExecutionGraph)
-
Uses of ArchivedExecutionGraph in org.apache.flink.runtime.webmonitor
Methods in org.apache.flink.runtime.webmonitor that return types with arguments of type ArchivedExecutionGraph Modifier and Type Method Description default CompletableFuture<ArchivedExecutionGraph>
RestfulGateway. requestJob(org.apache.flink.api.common.JobID jobId, Duration timeout)
Requests theArchivedExecutionGraph
for the given jobId.
-