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:37:14 UTC

[GitHub] [beam] damccorm opened a new issue, #20164: BeamRelNode with different pipeline options

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

   Two paths in a rel node tree have different values for pipeline options, this is causing an assert to fail. Needs investigation.
   
   two failures in shard 37
   ```
   
   INFO: Processing Sql statement: SELECT t1.id, t2.id
   FROM (SELECT 1 as id) t1 FULL JOIN (SELECT id
   FROM R WHERE FALSE) t2
   ON t1.id = t2.id
   May 21, 2020 1:40:06 PM cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl
   executeQuery
   SEVERE: null
   java.lang.AssertionError
   	at org.apache.beam.sdk.extensions.sql.impl.rel.BeamRelNode.getPipelineOptions(BeamRelNode.java:63)
   	at
   org.apache.beam.sdk.extensions.sql.impl.rel.BeamRelNode.getPipelineOptions(BeamRelNode.java:61)
   	at
   org.apache.beam.sdk.extensions.sql.impl.rel.BeamEnumerableConverter.toRowList(BeamEnumerableConverter.java:127)
   	at
   cloud.dataflow.sql.ExecuteQueryServiceServer$SqlComplianceServiceImpl.executeQuery(ExecuteQueryServiceServer.java:262)
   	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)
    
   ```
   
   
   Imported from Jira [BEAM-10062](https://issues.apache.org/jira/browse/BEAM-10062). 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