See: Description
Interface | Description |
---|---|
FlinkPipelineOptions |
Options which can be used to configure the Flink Runner.
|
FlinkPortablePipelineTranslator<T extends FlinkPortablePipelineTranslator.TranslationContext> |
Interface for portable Flink translators.
|
FlinkPortablePipelineTranslator.Executor |
A handle used to execute a translated pipeline.
|
FlinkPortablePipelineTranslator.TranslationContext |
The context used for pipeline translation.
|
FlinkStateBackendFactory |
Constructs a StateBackend to use from flink pipeline options.
|
Class | Description |
---|---|
FlinkBatchPortablePipelineTranslator |
A translator that translates bounded portable pipelines into executable Flink pipelines.
|
FlinkBatchPortablePipelineTranslator.BatchTranslationContext |
Batch translation context.
|
FlinkBatchPortablePipelineTranslator.IsFlinkNativeTransform |
Predicate to determine whether a URN is a Flink native transform.
|
FlinkDetachedRunnerResult |
Result of a detached execution of a
Pipeline with Flink. |
FlinkExecutionEnvironments |
Utilities for Flink execution environments.
|
FlinkJobInvoker |
Job Invoker for the
FlinkRunner . |
FlinkJobServerDriver |
Driver program that starts a job server for the Flink runner.
|
FlinkJobServerDriver.FlinkServerConfiguration |
Flink runner-specific Configuration for the jobServer.
|
FlinkMiniClusterEntryPoint |
Entry point for starting an embedded Flink cluster.
|
FlinkPipelineRunner |
Runs a Pipeline on Flink via
FlinkRunner . |
FlinkPortableClientEntryPoint |
Flink job entry point to launch a Beam pipeline by executing an external SDK driver program.
|
FlinkPortableRunnerResult |
Result of executing a portable
Pipeline with Flink. |
FlinkRunner |
A
PipelineRunner 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. |
FlinkRunnerRegistrar |
AutoService registrar - will register FlinkRunner and FlinkOptions as possible pipeline runner
services.
|
FlinkRunnerRegistrar.Options |
Pipeline options registrar.
|
FlinkRunnerRegistrar.Runner |
Pipeline runner registrar.
|
FlinkRunnerResult |
Result of executing a
Pipeline with Flink. |
FlinkStreamingPortablePipelineTranslator |
Translate an unbounded portable pipeline representation into a Flink pipeline representation.
|
FlinkStreamingPortablePipelineTranslator.IsFlinkNativeTransform |
Predicate to determine whether a URN is a Flink native transform.
|
FlinkStreamingPortablePipelineTranslator.StreamingTranslationContext |
Streaming translation context.
|
TestFlinkRunner |
Test Flink runner.
|