Package org.apache.beam.runners.flink
Class FlinkJobInvoker
java.lang.Object
org.apache.beam.runners.jobsubmission.JobInvoker
org.apache.beam.runners.flink.FlinkJobInvoker
Job Invoker for the
FlinkRunner
.-
Constructor Summary
ConstructorsModifierConstructorDescriptionprotected
FlinkJobInvoker
(FlinkJobServerDriver.FlinkServerConfiguration serverConfig) -
Method Summary
Modifier and TypeMethodDescriptionstatic FlinkJobInvoker
create
(FlinkJobServerDriver.FlinkServerConfiguration serverConfig) protected JobInvocation
createJobInvocation
(String invocationId, String retrievalToken, org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.util.concurrent.ListeningExecutorService executorService, org.apache.beam.model.pipeline.v1.RunnerApi.Pipeline pipeline, FlinkPipelineOptions flinkOptions, PortablePipelineRunner pipelineRunner) protected JobInvocation
invokeWithExecutor
(org.apache.beam.model.pipeline.v1.RunnerApi.Pipeline pipeline, org.apache.beam.vendor.grpc.v1p69p0.com.google.protobuf.Struct options, @Nullable String retrievalToken, org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.util.concurrent.ListeningExecutorService executorService) Start running a job, abstracting its state as aJobInvocation
instance.
-
Constructor Details
-
FlinkJobInvoker
-
-
Method Details
-
create
-
invokeWithExecutor
protected JobInvocation invokeWithExecutor(org.apache.beam.model.pipeline.v1.RunnerApi.Pipeline pipeline, org.apache.beam.vendor.grpc.v1p69p0.com.google.protobuf.Struct options, @Nullable String retrievalToken, org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.util.concurrent.ListeningExecutorService executorService) Description copied from class:JobInvoker
Start running a job, abstracting its state as aJobInvocation
instance.- Specified by:
invokeWithExecutor
in classJobInvoker
-
createJobInvocation
protected JobInvocation createJobInvocation(String invocationId, String retrievalToken, org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.util.concurrent.ListeningExecutorService executorService, org.apache.beam.model.pipeline.v1.RunnerApi.Pipeline pipeline, FlinkPipelineOptions flinkOptions, PortablePipelineRunner pipelineRunner)
-