Uses of Interface
org.apache.flink.streaming.api.graph.ExecutionPlan
-
-
Uses of ExecutionPlan in org.apache.flink.runtime.client
Methods in org.apache.flink.runtime.client with parameters of type ExecutionPlan Modifier and Type Method Description static void
ClientUtils. extractAndUploadExecutionPlanFiles(ExecutionPlan executionPlan, org.apache.flink.util.function.SupplierWithException<BlobClient,IOException> clientSupplier)
Extracts all files required for the execution from the givenExecutionPlan
and uploads them using theBlobClient
from the givenSupplier
.static void
ClientUtils. uploadExecutionPlanFiles(ExecutionPlan executionPlan, Collection<org.apache.flink.core.fs.Path> userJars, Collection<org.apache.flink.api.java.tuple.Tuple2<String,org.apache.flink.core.fs.Path>> userArtifacts, org.apache.flink.util.function.SupplierWithException<BlobClient,IOException> clientSupplier)
Uploads the given jars and artifacts required for the execution of the givenExecutionPlan
using theBlobClient
from the givenSupplier
. -
Uses of ExecutionPlan in org.apache.flink.runtime.dispatcher
Methods in org.apache.flink.runtime.dispatcher with parameters of type ExecutionPlan Modifier and Type Method Description JobManagerRunner
JobManagerRunnerFactory. createJobManagerRunner(ExecutionPlan executionPlan, org.apache.flink.configuration.Configuration configuration, org.apache.flink.runtime.rpc.RpcService rpcService, HighAvailabilityServices highAvailabilityServices, HeartbeatServices heartbeatServices, JobManagerSharedServices jobManagerServices, JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, long initializationTimestamp)
JobManagerRunner
JobMasterServiceLeadershipRunnerFactory. createJobManagerRunner(ExecutionPlan executionPlan, org.apache.flink.configuration.Configuration configuration, org.apache.flink.runtime.rpc.RpcService rpcService, HighAvailabilityServices highAvailabilityServices, HeartbeatServices heartbeatServices, JobManagerSharedServices jobManagerServices, JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, long initializationTimestamp)
CompletableFuture<Acknowledge>
Dispatcher. submitJob(ExecutionPlan executionPlan, Duration timeout)
CompletableFuture<Acknowledge>
DispatcherGateway. submitJob(ExecutionPlan executionPlan, Duration timeout)
Submit a job to the dispatcher.Method parameters in org.apache.flink.runtime.dispatcher with type arguments of type ExecutionPlan Modifier and Type Method Description Dispatcher
DispatcherFactory. createDispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<ExecutionPlan> recoveredJobs, Collection<JobResult> recoveredDirtyJobResults, DispatcherBootstrapFactory dispatcherBootstrapFactory, PartialDispatcherServicesWithJobPersistenceComponents partialDispatcherServicesWithJobPersistenceComponents)
Create aDispatcher
.StandaloneDispatcher
SessionDispatcherFactory. createDispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<ExecutionPlan> recoveredJobs, Collection<JobResult> recoveredDirtyJobResults, DispatcherBootstrapFactory dispatcherBootstrapFactory, PartialDispatcherServicesWithJobPersistenceComponents partialDispatcherServicesWithJobPersistenceComponents)
Constructor parameters in org.apache.flink.runtime.dispatcher with type arguments of type ExecutionPlan Constructor Description Dispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<ExecutionPlan> recoveredJobs, Collection<JobResult> recoveredDirtyJobs, DispatcherBootstrapFactory dispatcherBootstrapFactory, DispatcherServices dispatcherServices)
Dispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<ExecutionPlan> recoveredJobs, Collection<JobResult> recoveredDirtyJobs, DispatcherBootstrapFactory dispatcherBootstrapFactory, DispatcherServices dispatcherServices, JobManagerRunnerRegistry jobManagerRunnerRegistry, ResourceCleanerFactory resourceCleanerFactory)
StandaloneDispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<ExecutionPlan> recoveredJobs, Collection<JobResult> recoveredDirtyJobResults, DispatcherBootstrapFactory dispatcherBootstrapFactory, DispatcherServices dispatcherServices)
-
Uses of ExecutionPlan in org.apache.flink.runtime.dispatcher.runner
Method parameters in org.apache.flink.runtime.dispatcher.runner with type arguments of type ExecutionPlan Modifier and Type Method Description AbstractDispatcherLeaderProcess.DispatcherGatewayService
AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory. create(DispatcherId dispatcherId, Collection<ExecutionPlan> recoveredJobs, Collection<JobResult> recoveredDirtyJobResults, ExecutionPlanWriter executionPlanWriter, JobResultStore jobResultStore)
-
Uses of ExecutionPlan in org.apache.flink.runtime.jobgraph
Classes in org.apache.flink.runtime.jobgraph that implement ExecutionPlan Modifier and Type Class Description class
JobGraph
The JobGraph represents a Flink dataflow program, at the low level that the JobManager accepts.Methods in org.apache.flink.runtime.jobgraph with parameters of type ExecutionPlan Modifier and Type Method Description static Optional<JobResourceRequirements>
JobResourceRequirements. readFromExecutionPlan(ExecutionPlan executionPlan)
Readresource requirements
from the configuration of a givenExecutionPlan
.static void
JobResourceRequirements. writeToExecutionPlan(ExecutionPlan executionPlan, JobResourceRequirements jobResourceRequirements)
Writeresource requirements
into the configuration of a givenExecutionPlan
. -
Uses of ExecutionPlan in org.apache.flink.runtime.jobmanager
Methods in org.apache.flink.runtime.jobmanager that return ExecutionPlan Modifier and Type Method Description ExecutionPlan
DefaultExecutionPlanStore. recoverExecutionPlan(org.apache.flink.api.common.JobID jobId)
ExecutionPlan
ExecutionPlanStore. recoverExecutionPlan(org.apache.flink.api.common.JobID jobId)
ExecutionPlan
StandaloneExecutionPlanStore. recoverExecutionPlan(org.apache.flink.api.common.JobID jobId)
Methods in org.apache.flink.runtime.jobmanager with parameters of type ExecutionPlan Modifier and Type Method Description void
DefaultExecutionPlanStore. putExecutionPlan(ExecutionPlan executionPlan)
void
ExecutionPlanWriter. putExecutionPlan(ExecutionPlan executionPlan)
Adds theExecutionPlan
instance.void
StandaloneExecutionPlanStore. putExecutionPlan(ExecutionPlan jobGraph)
void
ThrowingExecutionPlanWriter. putExecutionPlan(ExecutionPlan jobGraph)
Constructor parameters in org.apache.flink.runtime.jobmanager with type arguments of type ExecutionPlan Constructor Description DefaultExecutionPlanStore(StateHandleStore<ExecutionPlan,R> stateHandleStore, ExecutionPlanStoreWatcher executionPlanStoreWatcher, ExecutionPlanStoreUtil executionPlanStoreUtil)
-
Uses of ExecutionPlan in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster with parameters of type ExecutionPlan Modifier and Type Method Description SchedulerNG
DefaultSlotPoolServiceSchedulerFactory. createScheduler(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.Configuration configuration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations)
SchedulerNG
SlotPoolServiceSchedulerFactory. createScheduler(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.Configuration configuration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations)
Creates aSchedulerNG
.Constructors in org.apache.flink.runtime.jobmaster with parameters of type ExecutionPlan Constructor Description JobMaster(org.apache.flink.runtime.rpc.RpcService rpcService, JobMasterId jobMasterId, JobMasterConfiguration jobMasterConfiguration, ResourceID resourceId, ExecutionPlan executionPlan, HighAvailabilityServices highAvailabilityService, SlotPoolServiceSchedulerFactory slotPoolServiceSchedulerFactory, JobManagerSharedServices jobManagerSharedServices, HeartbeatServices heartbeatServices, JobManagerJobMetricGroupFactory jobMetricGroupFactory, OnCompletionActions jobCompletionActions, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ClassLoader userCodeLoader, ShuffleMaster<?> shuffleMaster, PartitionTrackerFactory partitionTrackerFactory, ExecutionDeploymentTracker executionDeploymentTracker, ExecutionDeploymentReconciler.Factory executionDeploymentReconcilerFactory, BlocklistHandler.Factory blocklistHandlerFactory, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, long initializationTimestamp)
-
Uses of ExecutionPlan in org.apache.flink.runtime.jobmaster.factories
Methods in org.apache.flink.runtime.jobmaster.factories with parameters of type ExecutionPlan Modifier and Type Method Description JobManagerJobMetricGroup
DefaultJobManagerJobMetricGroupFactory. create(ExecutionPlan executionPlan)
JobManagerJobMetricGroup
JobManagerJobMetricGroupFactory. create(ExecutionPlan executionPlan)
Create a newJobManagerJobMetricGroup
.JobManagerJobMetricGroup
UnregisteredJobManagerJobMetricGroupFactory. create(ExecutionPlan executionPlan)
Constructors in org.apache.flink.runtime.jobmaster.factories with parameters of type ExecutionPlan Constructor Description DefaultJobMasterServiceFactory(Executor executor, org.apache.flink.runtime.rpc.RpcService rpcService, JobMasterConfiguration jobMasterConfiguration, ExecutionPlan executionPlan, HighAvailabilityServices haServices, SlotPoolServiceSchedulerFactory slotPoolServiceSchedulerFactory, JobManagerSharedServices jobManagerSharedServices, HeartbeatServices heartbeatServices, JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ClassLoader userCodeClassloader, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, long initializationTimestamp)
-
Uses of ExecutionPlan in org.apache.flink.runtime.minicluster
Methods in org.apache.flink.runtime.minicluster with parameters of type ExecutionPlan Modifier and Type Method Description CompletableFuture<org.apache.flink.api.common.JobSubmissionResult>
MiniCluster. submitJob(ExecutionPlan executionPlan)
-
Uses of ExecutionPlan in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler with parameters of type ExecutionPlan Modifier and Type Method Description SchedulerNG
DefaultSchedulerFactory. createInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations)
SchedulerNG
SchedulerNGFactory. createInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations)
-
Uses of ExecutionPlan in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive with parameters of type ExecutionPlan Modifier and Type Method Description SchedulerNG
AdaptiveSchedulerFactory. createInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations)
-
Uses of ExecutionPlan in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type ExecutionPlan Modifier and Type Method Description static AdaptiveExecutionHandler
AdaptiveExecutionHandlerFactory. create(ExecutionPlan executionPlan, boolean enableBatchJobRecovery, ClassLoader userClassLoader, Executor serializationExecutor)
Creates an instance ofAdaptiveExecutionHandler
based on the provided execution plan.SchedulerNG
AdaptiveBatchSchedulerFactory. createInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations)
static AdaptiveBatchScheduler
AdaptiveBatchSchedulerFactory. createScheduler(org.slf4j.Logger log, ExecutionPlan executionPlan, org.apache.flink.api.common.ExecutionConfig executionConfig, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, CheckpointsCleaner checkpointsCleaner, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations, ExecutionOperations executionOperations, ExecutionSlotAllocatorFactory allocatorFactory, RestartBackoffTimeStrategy restartBackoffTimeStrategy, org.apache.flink.util.concurrent.ScheduledExecutor delayExecutor, VertexParallelismAndInputInfosDecider vertexParallelismAndInputInfosDecider, BatchJobRecoveryHandler jobRecoveryHandler)
-
Uses of ExecutionPlan in org.apache.flink.streaming.api.graph
Classes in org.apache.flink.streaming.api.graph that implement ExecutionPlan Modifier and Type Class Description class
StreamGraph
Class representing the streaming topology.
-