Uses of Class
org.apache.flink.runtime.scheduler.ExecutionGraphInfo
-
-
Uses of ExecutionGraphInfo in org.apache.flink.runtime.dispatcher
Methods in org.apache.flink.runtime.dispatcher that return ExecutionGraphInfo Modifier and Type Method Description ExecutionGraphInfo
ExecutionGraphInfoStore. get(JobID jobId)
Get theExecutionGraphInfo
for the given job id.ExecutionGraphInfo
FileExecutionGraphInfoStore. get(JobID jobId)
ExecutionGraphInfo
MemoryExecutionGraphInfoStore. get(JobID jobId)
Methods in org.apache.flink.runtime.dispatcher that return types with arguments of type ExecutionGraphInfo Modifier and Type Method Description CompletableFuture<ExecutionGraphInfo>
Dispatcher. requestExecutionGraphInfo(JobID jobId, Duration timeout)
Methods in org.apache.flink.runtime.dispatcher with parameters of type ExecutionGraphInfo Modifier and Type Method Description CompletableFuture<Acknowledge>
HistoryServerArchivist. archiveExecutionGraph(ExecutionGraphInfo executionGraphInfo)
Archives the givenExecutionGraphInfo
on the history server.CompletableFuture<Acknowledge>
VoidHistoryServerArchivist. archiveExecutionGraph(ExecutionGraphInfo executionGraph)
protected CompletableFuture<org.apache.flink.runtime.dispatcher.Dispatcher.CleanupJobState>
Dispatcher. jobReachedTerminalState(ExecutionGraphInfo executionGraphInfo)
void
ExecutionGraphInfoStore. put(ExecutionGraphInfo executionGraphInfo)
Store the givenExecutionGraphInfo
in the store.void
FileExecutionGraphInfoStore. put(ExecutionGraphInfo executionGraphInfo)
void
MemoryExecutionGraphInfoStore. put(ExecutionGraphInfo serializableExecutionGraphInfo)
-
Uses of ExecutionGraphInfo in org.apache.flink.runtime.dispatcher.cleanup
Methods in org.apache.flink.runtime.dispatcher.cleanup that return types with arguments of type ExecutionGraphInfo Modifier and Type Method Description CompletableFuture<ExecutionGraphInfo>
CheckpointResourcesCleanupRunner. requestJob(Duration timeout)
-
Uses of ExecutionGraphInfo in org.apache.flink.runtime.jobmanager
Methods in org.apache.flink.runtime.jobmanager with parameters of type ExecutionGraphInfo Modifier and Type Method Description void
OnCompletionActions. jobReachedGloballyTerminalState(ExecutionGraphInfo executionGraphInfo)
Job reached a globally terminal state. -
Uses of ExecutionGraphInfo in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster that return ExecutionGraphInfo Modifier and Type Method Description ExecutionGraphInfo
JobManagerRunnerResult. getExecutionGraphInfo()
Methods in org.apache.flink.runtime.jobmaster that return types with arguments of type ExecutionGraphInfo Modifier and Type Method Description CompletableFuture<ExecutionGraphInfo>
JobManagerRunner. requestJob(Duration timeout)
Requests theExecutionGraphInfo
of the executed job.CompletableFuture<ExecutionGraphInfo>
JobMaster. requestJob(Duration timeout)
CompletableFuture<ExecutionGraphInfo>
JobMasterGateway. requestJob(Duration timeout)
Requests theExecutionGraphInfo
of the executed job.CompletableFuture<ExecutionGraphInfo>
JobMasterServiceLeadershipRunner. requestJob(Duration timeout)
Methods in org.apache.flink.runtime.jobmaster with parameters of type ExecutionGraphInfo Modifier and Type Method Description static JobManagerRunnerResult
JobManagerRunnerResult. forInitializationFailure(ExecutionGraphInfo executionGraphInfo, Throwable failure)
static JobManagerRunnerResult
JobManagerRunnerResult. forSuccess(ExecutionGraphInfo executionGraphInfo)
void
DefaultJobMasterServiceProcess. jobReachedGloballyTerminalState(ExecutionGraphInfo executionGraphInfo)
-
Uses of ExecutionGraphInfo in org.apache.flink.runtime.rest.handler.job
Methods in org.apache.flink.runtime.rest.handler.job with parameters of type ExecutionGraphInfo Modifier and Type Method Description Collection<ArchivedJson>
JobExceptionsHandler. archiveJsonWithPath(ExecutionGraphInfo executionGraphInfo)
Collection<ArchivedJson>
JobManagerJobConfigurationHandler. archiveJsonWithPath(ExecutionGraphInfo executionGraphInfo)
Collection<ArchivedJson>
JobManagerJobEnvironmentHandler. archiveJsonWithPath(ExecutionGraphInfo executionGraphInfo)
protected R
AbstractAccessExecutionGraphHandler. handleRequest(HandlerRequest<EmptyRequestBody> request, ExecutionGraphInfo executionGraphInfo)
protected abstract R
AbstractExecutionGraphHandler. handleRequest(HandlerRequest<EmptyRequestBody> request, ExecutionGraphInfo executionGraphInfo)
Called for each request after the correspondingExecutionGraphInfo
has been retrieved from theExecutionGraphCache
.protected JobExceptionsInfoWithHistory
JobExceptionsHandler. handleRequest(HandlerRequest<EmptyRequestBody> request, ExecutionGraphInfo executionGraph)
-
Uses of ExecutionGraphInfo in org.apache.flink.runtime.rest.handler.legacy
Methods in org.apache.flink.runtime.rest.handler.legacy that return types with arguments of type ExecutionGraphInfo Modifier and Type Method Description CompletableFuture<ExecutionGraphInfo>
DefaultExecutionGraphCache. getExecutionGraphInfo(JobID jobId, RestfulGateway restfulGateway)
CompletableFuture<ExecutionGraphInfo>
ExecutionGraphCache. getExecutionGraphInfo(JobID jobId, RestfulGateway restfulGateway)
Gets theExecutionGraphInfo
for the givenJobID
and caches it. -
Uses of ExecutionGraphInfo in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return ExecutionGraphInfo Modifier and Type Method Description ExecutionGraphInfo
SchedulerBase. requestJob()
ExecutionGraphInfo
SchedulerNG. requestJob()
-
Uses of ExecutionGraphInfo in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive that return ExecutionGraphInfo Modifier and Type Method Description ExecutionGraphInfo
AdaptiveScheduler. requestJob()
-
Uses of ExecutionGraphInfo in org.apache.flink.runtime.webmonitor
Methods in org.apache.flink.runtime.webmonitor that return types with arguments of type ExecutionGraphInfo Modifier and Type Method Description CompletableFuture<ExecutionGraphInfo>
NonLeaderRetrievalRestfulGateway. requestExecutionGraphInfo(JobID jobId, Duration timeout)
CompletableFuture<ExecutionGraphInfo>
RestfulGateway. requestExecutionGraphInfo(JobID jobId, Duration timeout)
Requests theExecutionGraphInfo
containing additional information besides theArchivedExecutionGraph
.Methods in org.apache.flink.runtime.webmonitor with parameters of type ExecutionGraphInfo Modifier and Type Method Description Collection<ArchivedJson>
WebMonitorEndpoint. archiveJsonWithPath(ExecutionGraphInfo executionGraphInfo)
-
Uses of ExecutionGraphInfo in org.apache.flink.runtime.webmonitor.history
Methods in org.apache.flink.runtime.webmonitor.history with parameters of type ExecutionGraphInfo Modifier and Type Method Description Collection<ArchivedJson>
JsonArchivist. archiveJsonWithPath(ExecutionGraphInfo executionGraphInfo)
Returns aCollection
ofArchivedJson
s containing JSON responses and their respective REST URL for a given job.default Collection<ArchivedJson>
OnlyExecutionGraphJsonArchivist. archiveJsonWithPath(ExecutionGraphInfo executionGraphInfo)
-