Package org.apache.beam.runners.flink
package org.apache.beam.runners.flink
Internal implementation of the Beam runner for Apache Flink.
-
ClassDescriptionA translator that translates bounded portable pipelines into executable Flink pipelines.Batch translation context.Predicate to determine whether a URN is a Flink native transform.Transform translation interface.Result of a detached execution of a
Pipeline
with Flink.Utilities for Flink execution environments.Job Invoker for theFlinkRunner
.Driver program that starts a job server for the Flink runner.Flink runner-specific Configuration for the jobServer.Entry point for starting an embedded Flink cluster.Options which can be used to configure the Flink Runner.Maximum bundle size factory.Maximum bundle time factory.Runs a Pipeline on Flink viaFlinkRunner
.Flink job entry point to launch a Beam pipeline by executing an external SDK driver program.Interface for portable Flink translators.A handle used to execute a translated pipeline.The context used for pipeline translation.Result of executing a portablePipeline
with Flink.APipelineRunner
that executes the operations in the pipeline by first translating them to a Flink Plan and then executing them either locally or on a Flink cluster, depending on the configuration.AutoService registrar - will register FlinkRunner and FlinkOptions as possible pipeline runner services.Pipeline options registrar.Pipeline runner registrar.Result of executing aPipeline
with Flink.Constructs a StateBackend to use from flink pipeline options.Translate an unbounded portable pipeline representation into a Flink pipeline representation.Predicate to determine whether a URN is a Flink native transform.Streaming translation context.Test Flink runner.