Package org.apache.flink.core.execution
Interface PipelineExecutor
-
- All Known Subinterfaces:
CacheSupportedPipelineExecutor
- All Known Implementing Classes:
AbstractSessionClusterExecutor
,EmbeddedExecutor
,KubernetesSessionClusterExecutor
,LocalExecutor
,RemoteExecutor
,YarnSessionClusterExecutor
@Internal public interface PipelineExecutor
The entity responsible for executing aPipeline
, i.e. a user job.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description CompletableFuture<JobClient>
execute(Pipeline pipeline, Configuration configuration, ClassLoader userCodeClassloader)
-
-
-
Method Detail
-
execute
CompletableFuture<JobClient> execute(Pipeline pipeline, Configuration configuration, ClassLoader userCodeClassloader) throws Exception
Executes aPipeline
based on the provided configuration and returns aJobClient
which allows to interact with the job being executed, e.g. cancel it or take a savepoint.ATTENTION: The caller is responsible for managing the lifecycle of the returned
JobClient
. This means that e.g.close()
should be called explicitly at the call-site.- Parameters:
pipeline
- thePipeline
to executeconfiguration
- theConfiguration
with the required execution parametersuserCodeClassloader
- theClassLoader
to deserialize usercode- Returns:
- a
CompletableFuture
with theJobClient
corresponding to the pipeline. - Throws:
Exception
-
-