@Internal
public interface Executor
Transformation
s generated by the Planner
.
This uncouples the TableEnvironment
from any given runtime.
Note that not every table program calls createPipeline(List, ReadableConfig, String)
or execute(Pipeline)
. When bridging to DataStream API, this interface serves as a
communication layer to the final pipeline executor via StreamExecutionEnvironment
.
ExecutorFactory
Modifier and Type | Method and Description |
---|---|
org.apache.flink.api.dag.Pipeline |
createPipeline(List<org.apache.flink.api.dag.Transformation<?>> transformations,
org.apache.flink.configuration.ReadableConfig tableConfiguration,
String defaultJobName)
Translates the given transformations to a
Pipeline . |
org.apache.flink.api.common.JobExecutionResult |
execute(org.apache.flink.api.dag.Pipeline pipeline)
Executes the given pipeline.
|
org.apache.flink.core.execution.JobClient |
executeAsync(org.apache.flink.api.dag.Pipeline pipeline)
Executes the given pipeline asynchronously.
|
org.apache.flink.configuration.ReadableConfig |
getConfiguration()
Gives read-only access to the configuration of the executor.
|
boolean |
isCheckpointingEnabled()
Checks whether checkpointing is enabled.
|
org.apache.flink.configuration.ReadableConfig getConfiguration()
org.apache.flink.api.dag.Pipeline createPipeline(List<org.apache.flink.api.dag.Transformation<?>> transformations, org.apache.flink.configuration.ReadableConfig tableConfiguration, @Nullable String defaultJobName)
Pipeline
.transformations
- list of transformationstableConfiguration
- table-specific configuration optionsdefaultJobName
- default job name if not specified via PipelineOptions.NAME
org.apache.flink.api.common.JobExecutionResult execute(org.apache.flink.api.dag.Pipeline pipeline) throws Exception
pipeline
- the pipeline to executeException
- which occurs during job execution.org.apache.flink.core.execution.JobClient executeAsync(org.apache.flink.api.dag.Pipeline pipeline) throws Exception
pipeline
- the pipeline to executeJobClient
that can be used to communicate with the submitted job, completed
on submission succeeded.Exception
- which occurs during job execution.boolean isCheckpointingEnabled()
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.