You are viewing a plain text version of this content. The canonical link for it is here.
Posted to github@beam.apache.org by GitBox <gi...@apache.org> on 2022/06/04 15:29:42 UTC

[GitHub] [beam] damccorm opened a new issue, #20124: BeamZetaSqlCalcRel$CalcFn.processElement Unsupported Beam fieldType: LOGICAL_TYPE

damccorm opened a new issue, #20124:
URL: https://github.com/apache/beam/issues/20124

   eight failures in shard 6, eight failures in shard 7, eight failures in shard 8, ten failures in shard 9, five failures in shard 10, four failures in shard 11, six failures in shard 12, two failures in shard 16, six failures in shard 31, three failures in shard 42, two failures in shard 43, eight failures in shard 44, two failures in shard 50
   ```
   
   org.apache.beam.sdk.Pipeline$PipelineExecutionException: java.lang.UnsupportedOperationException: Unsupported
   Beam fieldType: LOGICAL_TYPE
   	at org.apache.beam.runners.direct.DirectRunner$DirectPipelineResult.waitUntilFinish(DirectRunner.java:348)
   	at
   org.apache.beam.runners.direct.DirectRunner$DirectPipelineResult.waitUntilFinish(DirectRunner.java:318)
   	at
   org.apache.beam.runners.direct.DirectRunner.run(DirectRunner.java:213)
   	at org.apache.beam.runners.direct.DirectRunner.run(DirectRunner.java:67)
   	at
   org.apache.beam.sdk.Pipeline.run(Pipeline.java:317)
   	at org.apache.beam.sdk.Pipeline.run(Pipeline.java:303)
   	at
   org.apache.beam.sdk.extensions.sql.impl.rel.BeamEnumerableConverter.runCollector(BeamEnumerableConverter.java:201)
   	at
   org.apache.beam.sdk.extensions.sql.impl.rel.BeamEnumerableConverter.collectRows(BeamEnumerableConverter.java:218)
   	at
   org.apache.beam.sdk.extensions.sql.impl.rel.BeamEnumerableConverter.toRowList(BeamEnumerableConverter.java:150)
   	at
   org.apache.beam.sdk.extensions.sql.impl.rel.BeamEnumerableConverter.toRowList(BeamEnumerableConverter.java:127)
   	at
   cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl.executeQuery(ExecuteQueryServiceServer.java:329)
   	at
   com.google.zetasql.testing.SqlComplianceServiceGrpc$MethodHandlers.invoke(SqlComplianceServiceGrpc.java:423)
   	at
   com.google.zetasql.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:171)
   	at
   com.google.zetasql.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:283)
   	at
   com.google.zetasql.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:711)
   	at
   com.google.zetasql.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
   	at com.google.zetasql.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
   	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)
   Caused by: java.lang.UnsupportedOperationException: Unsupported
   Beam fieldType: LOGICAL_TYPE
   	at org.apache.beam.sdk.extensions.sql.zetasql.ZetaSqlUtils.zetaSqlValueToJavaObject(ZetaSqlUtils.java:221)
   	at
   org.apache.beam.sdk.extensions.sql.zetasql.BeamZetaSqlCalcRel$CalcFn.processElement(BeamZetaSqlCalcRel.java:193)
   
   ```
   
   ```
   
   Apr 01, 2020 6:00:21 PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl executeQuery
   INFO:
   Processing Sql statement: SELECT CAST(@p0 AS DATE) AS ColA
   Apr 01, 2020 6:03:59 PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl
   executeQuery
   INFO: Processing Sql statement: SELECT DISTINCT val.DATE
   from (select DATE"2014-01-01"
   DATE union all
         select cast(NULL as date) union all
         select DATE"2014-01-02" union all
   
        select DATE"2014-01-01" union all
         select cast(NULL as date)) val
   Apr 01, 2020 6:10:09 PM
   cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl executeQuery
   INFO: Processing
   Sql statement: SELECT COALESCE(NULL, DATE '2014-12-18')
   Apr 01, 2020 6:03:26 PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl
   executeQuery
   INFO: Processing Sql statement: SELECT CAST(null AS TIME),
          CAST('12:34:56.123456'
   AS TIME),
          CAST(CAST(null AS TIME) AS STRING),
          CAST(CAST('12:34:56.123456' AS TIME) AS
   STRING),
          CAST(TIME '12:34:56.123456' AS STRING),
          CAST(CAST(TIME '12:34:56.123456' AS
   STRING) AS TIME)
   Apr 01, 2020 5:59:59 PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl
   executeQuery
   INFO: Processing Sql statement: SELECT SAFE_CAST(@p0 AS DATE) AS ColA
   Apr 01, 2020 6:07:07
   PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl executeQuery
   INFO: Processing
   Sql statement: SELECT
       CAST(CAST(TIME "00:00:00" as STRING) as TIME),
       CAST(CAST(TIME "23:59:59.999999"
   as STRING) as TIME),
       CAST(CAST(TIME "01:02:03.123456" as STRING) as TIME),
       CAST(CAST(TIME
   "01:02:03.12345" as STRING) as TIME),
       CAST(CAST(TIME "01:02:03.120000" as STRING) as TIME),
    
     CAST(CAST(TIME "01:02:3" as STRING) as TIME),
       CAST(CAST(TIME "01:2:03" as STRING) as TIME),
   
      CAST(CAST(TIME "1:02:03" as STRING) as TIME),
       #Leap second cases
       CAST(CAST(TIME "23:59:60"
   as STRING) as TIME),
       CAST(CAST(TIME "12:59:60" as STRING) as TIME),
       CAST(CAST(TIME "12:59:60.123456"
   as STRING) as TIME),
   
       CAST(CAST("00:00:00" as TIME) as STRING),
       CAST(CAST("23:59:59.999999"
   as TIME) as STRING),
       CAST(CAST("01:02:03.123456" as TIME) as STRING),
       CAST(CAST("01:02:03.12345"
   as TIME) as STRING),
       CAST(CAST("01:02:03.120000" as TIME) as STRING),
       CAST(CAST("01:02:3"
   as TIME) as STRING),
       CAST(CAST("01:2:03" as TIME) as STRING),
       CAST(CAST("1:02:03" as TIME)
   as STRING),
       #Leap second cases
       CAST(CAST("23:59:60" as TIME) as STRING),
       CAST(CAST("12:59:60"
   as TIME) as STRING),
       CAST(CAST("12:59:60.123456" as TIME) as STRING)
   Apr 01, 2020 6:07:11 PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl
   executeQuery
   INFO: Processing Sql statement: SELECT
       CAST(TIMESTAMP "0001-01-01 00:00:00" as TIME),
   
      CAST(TIMESTAMP "9999-12-31 15:59:59.999999" as TIME),
       CAST(TIMESTAMP "2006-01-02" as TIME),
   
      # Leap second cases
       CAST(TIMESTAMP "2015-11-06 23:59:60" as TIME),
       CAST(TIMESTAMP "2015-11-06
   12:59:60" as TIME),
       CAST(TIMESTAMP "2015-11-06 12:59:60.123456" as TIME)
   Apr 01, 2020 6:07:12
   PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl executeQuery
   INFO: Processing
   Sql statement: SELECT
       CAST(str_time_col_2 as TIME) as time_col_3,
       CAST(time_col_2 as STRING)
   as str_time_col_3
   FROM (
   SELECT
       CAST(str_time_col as TIME) as time_col_2,
       CAST(time_col
   as STRING) as str_time_col_2
   FROM (
   SELECT
       "12:34:56.123456" as str_time_col,
       TIME "12:34:56.123456"
   as time_col
   ))
   Apr 01, 2020 6:07:14 PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl
   executeQuery
   INFO: Processing Sql statement: SELECT
       CAST(DATETIME "0001-01-01 08:00:00" as TIME),
   
      CAST(DATETIME "0001-01-01 11:22:33.123456" as TIME),
       CAST(DATETIME "9999-12-31 13:59:59.999999"
   as TIME),
       CAST(DATETIME "2006-01-02" as TIME),
       # Leap second cases
       CAST(DATETIME "2015-11-06
   23:59:60" as TIME),
       CAST(DATETIME "2015-11-06 12:59:60" as TIME),
       CAST(DATETIME "2015-11-06
   12:59:60.123456" as TIME)
   Apr 01, 2020 6:05:02 PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl
   executeQuery
   INFO: Processing Sql statement: SELECT DATE "2014-07-18" date_val
   Apr 01, 2020 6:05:10
   PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl executeQuery
   INFO: Processing
   Sql statement: SELECT [DATE "2014-07-23", NULL, DATE "2014-07-18", NULL] date_val
   Apr 01, 2020 6:00:02
   PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl executeQuery
   INFO: Processing
   Sql statement: SELECT If(@p0, @p1, @p2) AS ColA
   Apr 01, 2020 6:00:17 PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl
   executeQuery
   INFO: Processing Sql statement: SELECT IfNull(@p0, @p1) AS ColA
   Apr 01, 2020 6:00:49
   PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl executeQuery
   INFO: Processing
   Sql statement: SELECT Coalesce(@p0, @p1) AS ColA
   Apr 01, 2020 6:01:27 PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl
   executeQuery
   INFO: Processing Sql statement: SELECT ARRAY<DATE>["1984-08-02", "2000-01-01", "2014-09-11"];
   Apr
   01, 2020 6:01:35 PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl executeQuery
   INFO:
   Processing Sql statement: SELECT ARRAY<DATE>["1984-08-02", NULL, "2014-09-11"];
   
   ```
   
   
   Imported from Jira [BEAM-9518](https://issues.apache.org/jira/browse/BEAM-9518). Original Jira may contain additional context.
   Reported by: apilloud.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org