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

Occasional ClassCastException in ParDoTranslatorTest.testAssertionFailure

Details

    Description

      A postcommit build failed:

      https://builds.apache.org/job/beam_PostCommit_Java_MavenInstall/org.apache.beam$beam-runners-apex/5326/testReport/junit/org.apache.beam.runners.apex.translation/ParDoTranslatorTest/testAssertionFailure/

      because the following exception happened instead of the expected PAssert assertion failure exception:

      85212 [1/PAssert$2/GroupGlobally/Create.Values:ApexReadUnboundedInputOperator] INFO  com.datatorrent.stram.StramLocalCluster  - container-10 msg: Stopped running due to an exception. java.lang.ClassCastException: java.lang.String cannot be cast to org.apache.beam.sdk.values.KV
      	at org.apache.beam.sdk.coders.KvCoder.encode(KvCoder.java:36)
      	at org.apache.beam.sdk.util.WindowedValue$FullWindowedValueCoder.encode(WindowedValue.java:652)
      	at org.apache.beam.sdk.util.WindowedValue$FullWindowedValueCoder.encode(WindowedValue.java:599)
      	at org.apache.beam.runners.apex.translation.utils.ApexStreamTuple$ApexStreamTupleCoder.encode(ApexStreamTuple.java:179)
      	at org.apache.beam.runners.apex.translation.utils.ApexStreamTuple$ApexStreamTupleCoder.encode(ApexStreamTuple.java:152)
      	at org.apache.beam.runners.apex.translation.utils.CoderAdapterStreamCodec.toByteArray(CoderAdapterStreamCodec.java:61)
      	at com.datatorrent.stram.stream.BufferServerPublisher.put(BufferServerPublisher.java:140)
      	at com.datatorrent.api.DefaultOutputPort.emit(DefaultOutputPort.java:59)
      	at org.apache.beam.runners.apex.translation.operators.ApexReadUnboundedInputOperator.emitTuples(ApexReadUnboundedInputOperator.java:157)
      	at com.datatorrent.stram.engine.InputNode.run(InputNode.java:124)
      	at com.datatorrent.stram.engine.StreamingContainer$2.run(StreamingContainer.java:1428)
      

      I wasn't able to reproduce this issue by running the test locally >100 times, but it looks alarming nevertheless.

      Attachments

        Activity

          People

            Unassigned Unassigned
            jkff Eugene Kirpichov
            Votes:
            0 Vote for this issue
            Watchers:
            4 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved: