Uploaded image for project: 'Beam'
  1. Beam
  2. BEAM-10062

BeamRelNode with different pipeline options

Details

    Description

      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)
       

      Attachments

        Activity

          People

            Unassigned Unassigned
            apilloud Andrew Pilloud
            Votes:
            0 Vote for this issue
            Watchers:
            3 Start watching this issue

            Dates

              Created:
              Updated: