Class FlinkExecutionEnvironments

java.lang.Object
org.apache.beam.runners.flink.FlinkExecutionEnvironments

public class FlinkExecutionEnvironments extends Object
Utilities for Flink execution environments.
  • Constructor Details

    • FlinkExecutionEnvironments

      public FlinkExecutionEnvironments()
  • Method Details

    • createBatchExecutionEnvironment

      public static org.apache.flink.api.java.ExecutionEnvironment createBatchExecutionEnvironment(FlinkPipelineOptions options)
      If the submitted job is a batch processing job, this method creates the adequate Flink ExecutionEnvironment depending on the user-specified options.
    • createStreamExecutionEnvironment

      public static org.apache.flink.streaming.api.environment.StreamExecutionEnvironment createStreamExecutionEnvironment(FlinkPipelineOptions options, List<String> filesToStage, @Nullable String confDir)
      If the submitted job is a stream processing job, this method creates the adequate Flink StreamExecutionEnvironment depending on the user-specified options.