Uploaded image for project: 'Zeppelin'
  1. Zeppelin
  2. ZEPPELIN-5194

SET statements always fail with flink.ssql interpreter

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Closed
    • Major
    • Resolution: Not A Problem
    • 0.9.0
    • None
    • flink, Interpreters
    • None

    Description

      When executing SET statements in a flink.ssql paragraph, for example:

      SET 'table.dynamic-table-options.enabled' = 'true';
      SET 'table.sql-dialect' = 'hive';
      SET 'table.exec.async-lookup.buffer-capacity' = '200';
      SET 'table.optimizer.agg-phase-strategy' = 'TWO_PHASE';
      

      All of them will eventually fail with following exception, regardless of the Flink version we use:

      Fail to run sql command: SET 'xxx' = 'yyy'
      java.io.IOException: 'xxx' is not a valid table/sql config, please check link: https://ci.apache.org/projects/flink/flink-docs-release-1.10/dev/table/config.html
      	at org.apache.zeppelin.flink.FlinkSqlInterrpeter.callSet(FlinkSqlInterrpeter.java:506)
      	at org.apache.zeppelin.flink.FlinkSqlInterrpeter.callCommand(FlinkSqlInterrpeter.java:260)
      	at org.apache.zeppelin.flink.FlinkSqlInterrpeter.runSqlList(FlinkSqlInterrpeter.java:151)
      	at org.apache.zeppelin.flink.FlinkSqlInterrpeter.internalInterpret(FlinkSqlInterrpeter.java:111)
      	at org.apache.zeppelin.interpreter.AbstractInterpreter.interpret(AbstractInterpreter.java:47)
      	at org.apache.zeppelin.interpreter.LazyOpenInterpreter.interpret(LazyOpenInterpreter.java:110)
      	at org.apache.zeppelin.interpreter.remote.RemoteInterpreterServer$InterpretJob.jobRun(RemoteInterpreterServer.java:852)
      	at org.apache.zeppelin.interpreter.remote.RemoteInterpreterServer$InterpretJob.jobRun(RemoteInterpreterServer.java:744)
      	at org.apache.zeppelin.scheduler.Job.run(Job.java:172)
      	at org.apache.zeppelin.scheduler.AbstractScheduler.runJob(AbstractScheduler.java:132)
      	at org.apache.zeppelin.scheduler.ParallelScheduler.lambda$runJobInScheduler$0(ParallelScheduler.java:46)
      	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
      	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
      	at java.lang.Thread.run(Thread.java:748)
      

      However, the `FlinkShim`s are properly loaded according to interpreter logs.

       

      Attachments

        Activity

          People

            Unassigned Unassigned
            lmagics Q Kang
            Votes:
            0 Vote for this issue
            Watchers:
            1 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved: