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 ExecutionGraphInfoExecutionGraphInfoStore. get(org.apache.flink.api.common.JobID jobId)Get theExecutionGraphInfofor the given job id.ExecutionGraphInfoFileExecutionGraphInfoStore. get(org.apache.flink.api.common.JobID jobId)ExecutionGraphInfoMemoryExecutionGraphInfoStore. get(org.apache.flink.api.common.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(org.apache.flink.api.common.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 givenExecutionGraphInfoon the history server.CompletableFuture<Acknowledge>VoidHistoryServerArchivist. archiveExecutionGraph(ExecutionGraphInfo executionGraph)protected CompletableFuture<org.apache.flink.runtime.dispatcher.Dispatcher.CleanupJobState>Dispatcher. jobReachedTerminalState(ExecutionGraphInfo executionGraphInfo)voidExecutionGraphInfoStore. put(ExecutionGraphInfo executionGraphInfo)Store the givenExecutionGraphInfoin the store.voidFileExecutionGraphInfoStore. put(ExecutionGraphInfo executionGraphInfo)voidMemoryExecutionGraphInfoStore. 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 voidOnCompletionActions. 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 ExecutionGraphInfoJobManagerRunnerResult. 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 theExecutionGraphInfoof the executed job.CompletableFuture<ExecutionGraphInfo>JobMaster. requestJob(Duration timeout)CompletableFuture<ExecutionGraphInfo>JobMasterGateway. requestJob(Duration timeout)Requests theExecutionGraphInfoof 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 JobManagerRunnerResultJobManagerRunnerResult. forInitializationFailure(ExecutionGraphInfo executionGraphInfo, Throwable failure)static JobManagerRunnerResultJobManagerRunnerResult. forSuccess(ExecutionGraphInfo executionGraphInfo)voidDefaultJobMasterServiceProcess. 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 RAbstractAccessExecutionGraphHandler. handleRequest(HandlerRequest<EmptyRequestBody> request, ExecutionGraphInfo executionGraphInfo)protected abstract RAbstractExecutionGraphHandler. handleRequest(HandlerRequest<EmptyRequestBody> request, ExecutionGraphInfo executionGraphInfo)Called for each request after the correspondingExecutionGraphInfohas been retrieved from theExecutionGraphCache.protected JobExceptionsInfoWithHistoryJobExceptionsHandler. 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(org.apache.flink.api.common.JobID jobId, RestfulGateway restfulGateway)CompletableFuture<ExecutionGraphInfo>ExecutionGraphCache. getExecutionGraphInfo(org.apache.flink.api.common.JobID jobId, RestfulGateway restfulGateway)Gets theExecutionGraphInfofor the givenJobIDand 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 ExecutionGraphInfoSchedulerBase. requestJob()ExecutionGraphInfoSchedulerNG. 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 ExecutionGraphInfoAdaptiveScheduler. 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(org.apache.flink.api.common.JobID jobId, Duration timeout)CompletableFuture<ExecutionGraphInfo>RestfulGateway. requestExecutionGraphInfo(org.apache.flink.api.common.JobID jobId, Duration timeout)Requests theExecutionGraphInfocontaining 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 aCollectionofArchivedJsons containing JSON responses and their respective REST URL for a given job.default Collection<ArchivedJson>OnlyExecutionGraphJsonArchivist. archiveJsonWithPath(ExecutionGraphInfo executionGraphInfo)
-