Class AbstractJobClusterExecutor<ClusterID,ClientFactory extends ClusterClientFactory<ClusterID>>
- java.lang.Object
-
- org.apache.flink.client.deployment.executors.AbstractJobClusterExecutor<ClusterID,ClientFactory>
-
- Type Parameters:
ClusterID
- the type of the id of the cluster.ClientFactory
- the type of theClusterClientFactory
used to create/retrieve a client to the target cluster.
- All Implemented Interfaces:
PipelineExecutor
- Direct Known Subclasses:
YarnJobClusterExecutor
@Internal @Deprecated public class AbstractJobClusterExecutor<ClusterID,ClientFactory extends ClusterClientFactory<ClusterID>> extends Object implements PipelineExecutor
Deprecated.An abstractPipelineExecutor
used to executepipelines
on dedicated (per-job) clusters.
-
-
Constructor Summary
Constructors Constructor Description AbstractJobClusterExecutor(ClientFactory clusterClientFactory)
Deprecated.
-
Method Summary
All Methods Instance Methods Concrete Methods Deprecated Methods Modifier and Type Method Description CompletableFuture<JobClient>
execute(Pipeline pipeline, Configuration configuration, ClassLoader userCodeClassloader)
Deprecated.
-
-
-
Constructor Detail
-
AbstractJobClusterExecutor
public AbstractJobClusterExecutor(@Nonnull ClientFactory clusterClientFactory)
Deprecated.
-
-
Method Detail
-
execute
public CompletableFuture<JobClient> execute(@Nonnull Pipeline pipeline, @Nonnull Configuration configuration, @Nonnull ClassLoader userCodeClassloader) throws Exception
Deprecated.Description copied from interface:PipelineExecutor
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.- Specified by:
execute
in interfacePipelineExecutor
- 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
-
-