Uploaded image for project: 'Flink'
  1. Flink
  2. FLINK-19204

Improve warning during a Table.execute()

    XMLWordPrintableJSON

Details

    Description

      When running a table program locally that uses `Table.execute().collect` the logs contain a warning in most of the runs. Logs should not contain a warning by default, because this is very confusing. At the first glance, it looks like something went wrong even though the program finished successfully.

      2020-09-11 14:03:27,714 WARN  org.apache.flink.streaming.api.operators.collect.CollectResultFetcher [] - Failed to get job status so we assume that the job has terminated. Some data might be lost.
      java.lang.IllegalStateException: MiniCluster is not yet running or has already been shut down.
      	at org.apache.flink.util.Preconditions.checkState(Preconditions.java:195) ~[classes/:?]
      	at org.apache.flink.runtime.minicluster.MiniCluster.getDispatcherGatewayFuture(MiniCluster.java:707) ~[classes/:?]
      	at org.apache.flink.runtime.minicluster.MiniCluster.runDispatcherCommand(MiniCluster.java:621) ~[classes/:?]
      	at org.apache.flink.runtime.minicluster.MiniCluster.getJobStatus(MiniCluster.java:587) ~[classes/:?]
      	at org.apache.flink.client.program.PerJobMiniClusterFactory$PerJobMiniClusterJobClient.getJobStatus(PerJobMiniClusterFactory.java:167) ~[classes/:?]
      	at org.apache.flink.streaming.api.operators.collect.CollectResultFetcher.isJobTerminated(CollectResultFetcher.java:199) [classes/:?]
      	at org.apache.flink.streaming.api.operators.collect.CollectResultFetcher.next(CollectResultFetcher.java:123) [classes/:?]
      	at org.apache.flink.streaming.api.operators.collect.CollectResultIterator.nextResultFromFetcher(CollectResultIterator.java:103) [classes/:?]
      	at org.apache.flink.streaming.api.operators.collect.CollectResultIterator.hasNext(CollectResultIterator.java:77) [classes/:?]
      	at org.apache.flink.table.planner.sinks.SelectTableSinkBase$RowIteratorWrapper.hasNext(SelectTableSinkBase.java:115) [classes/:?]
      	at org.apache.flink.table.api.internal.TableResultImpl$CloseableRowIteratorWrapper.hasNext(TableResultImpl.java:355) [classes/:?]
      	at org.apache.flink.table.utils.PrintUtils.printAsTableauForm(PrintUtils.java:155) [classes/:?]
      	at org.apache.flink.table.api.internal.TableResultImpl.print(TableResultImpl.java:149) [classes/:?]
      	at org.apache.flink.table.examples.scala.basics.GettingStartedExample$.main(GettingStartedExample.scala:90) [classes/:?]
      	at org.apache.flink.table.examples.scala.basics.GettingStartedExample.main(GettingStartedExample.scala) [classes/:?]
      

      Attachments

        Activity

          People

            Unassigned Unassigned
            twalthr Timo Walther
            Votes:
            0 Vote for this issue
            Watchers:
            5 Start watching this issue

            Dates

              Created:
              Updated: