You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by "xiemeilong (Jira)" <ji...@apache.org> on 2020/04/13 06:45:00 UTC

[jira] [Created] (FLINK-17108) Exception: Cannot determine simple type name "com"

xiemeilong created FLINK-17108:
----------------------------------

             Summary: Exception: Cannot determine simple type name "com"
                 Key: FLINK-17108
                 URL: https://issues.apache.org/jira/browse/FLINK-17108
             Project: Flink
          Issue Type: Bug
          Components: Table SQL / Planner
    Affects Versions: 1.10.0
            Reporter: xiemeilong


The below code will throw exception in cluster mode , but not in local mode or when checkpoint disabled.

 
{code:java}
package com.test

import org.apache.flink.streaming.api.scala._
import org.apache.flink.table.api.EnvironmentSettings
import org.apache.flink.table.api.scala.{StreamTableEnvironment, _}
import org.apache.flink.types.Row

case class Test(int:Int)
object Main {
  def main(args: Array[String]) {
    val env = StreamExecutionEnvironment.getExecutionEnvironment
      .enableCheckpointing(32 * 1000)

    val settings = EnvironmentSettings.newInstance()
      .useBlinkPlanner()
      .inStreamingMode().build()
    val tableEnv = StreamTableEnvironment.create(env, settings)

    tableEnv.createTemporaryView("test", env.fromCollection(List(Test(1))))
    val deviceSchemaTable = tableEnv.from("test")
    deviceSchemaTable.toRetractStream[Row]
        .print()
  env.execute("test")
 }
}
{code}
 

 



--
This message was sent by Atlassian Jira
(v8.3.4#803005)