Uploaded image for project: 'Flink'
  1. Flink
  2. FLINK-35602 [Umbrella] Test Flink Release 1.20
  3. FLINK-35665

Release Testing: FLIP-441: Show the JobType and remove Execution Mode on Flink WebUI

    XMLWordPrintableJSON

Details

    • Sub-task
    • Status: Open
    • Blocker
    • Resolution: Unresolved
    • None
    • 1.20.0
    • Runtime / Web Frontend
    • None

    Description

      Test suggestion:

       

      1. Using this following job to check the jobType

      import org.apache.flink.api.common.RuntimeExecutionMode;
      import org.apache.flink.api.common.eventtime.WatermarkStrategy;
      import org.apache.flink.api.common.functions.MapFunction;
      import org.apache.flink.api.common.typeinfo.Types;
      import org.apache.flink.api.connector.source.util.ratelimit.RateLimiterStrategy;
      import org.apache.flink.configuration.Configuration;
      import org.apache.flink.configuration.RestOptions;
      import org.apache.flink.connector.datagen.source.DataGeneratorSource;
      import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
      
      /** Test for showing job type in Flink WebUI. */
      public class JobTypeDemo {
          public static void main(String[] args) throws Exception {
              Configuration conf = new Configuration();
              StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment(conf);
      
              env.setRuntimeMode(RuntimeExecutionMode.STREAMING);
      //                env.setRuntimeMode(RuntimeExecutionMode.BATCH);
      //                env.setRuntimeMode(RuntimeExecutionMode.AUTOMATIC);
      
              DataGeneratorSource<Long> generatorSource =
                      new DataGeneratorSource<>(
                              value -> value,
                              600,
                              RateLimiterStrategy.perSecond(10),
                              Types.LONG);
              env.fromSource(generatorSource, WatermarkStrategy.noWatermarks(), "Data Generator")
                      .map((MapFunction<Long, Long>) value -> value)
                      .name("Map___1")
                      .print();
              env.execute(JobTypeDemo.class.getSimpleName());
          }
      } 

      2. Start it and check if the jobType is Streaming in Flink web UI.

       

      3. Applying the env.setRuntimeMode(RuntimeExecutionMode.BATCH);, and check if the jobType is Batch in Flink web UI.

      4. Applying the env.setRuntimeMode(RuntimeExecutionMode.AUTOMATIC);, and check if the jobType is Batch in Flink web UI.

      Attachments

        Activity

          People

            Unassigned Unassigned
            fanrui Rui Fan
            Votes:
            0 Vote for this issue
            Watchers:
            2 Start watching this issue

            Dates

              Created:
              Updated: