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

Project beam_PostCommit_Java_ValidatesRunner_ULR is failing

Details

    Description

      First faliure: https://ci-beam.apache.org/job/beam_PostCommit_Java_ValidatesRunner_ULR/

      From scanning through commits on the build, https://github.com/apache/beam/pull/14226 is the most suspicious to me, others seems to me not relevant.

      org.apache.beam.sdk.transforms.ViewTest.testMapAsEntrySetSideInput
      
      Failing for the past 1 build (Since Failed#676 )
      Took 12 sec.
      Error Message
      java.lang.RuntimeException: The Runner experienced the following error during execution:
      Traceback (most recent call last):
        File "/home/jenkins/jenkins-slave/workspace/beam_PostCommit_Java_ValidatesRunner_ULR/src/sdks/python/apache_beam/runners/portability/local_job_service.py", line 275, in _run_job
          result = fn_runner.FnApiRunner(
        File "/home/jenkins/jenkins-slave/workspace/beam_PostCommit_Java_ValidatesRunner_ULR/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 204, in run_via_runner_api
          return self.run_stages(stage_context, stages)
        File "/home/jenkins/jenkins-slave/workspace/beam_PostCommit_Java_ValidatesRunner_ULR/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 368, in run_stages
          stage_results = self._run_stage(
        File "/home/jenkins/jenkins-slave/workspace/beam_PostCommit_Java_ValidatesRunner_ULR/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 559, in _run_stage
          last_result, deferred_inputs, fired_timers = self._run_bundle(
        File "/home/jenkins/jenkins-slave/workspace/beam_PostCommit_Java_ValidatesRunner_ULR/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 605, in _run_bundle
          result, splits = bundle_manager.process_bundle(
        File "/home/jenkins/jenkins-slave/workspace/beam_PostCommit_Java_ValidatesRunner_ULR/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 947, in process_bundle
          raise RuntimeError(result.error)
      RuntimeError: org.apache.beam.sdk.util.UserCodeException: java.lang.AssertionError: expected:<2> but was:<0>
      	at org.apache.beam.sdk.util.UserCodeException.wrap(UserCodeException.java:39)
      	at org.apache.beam.sdk.transforms.ViewTest$24$DoFnInvoker.invokeProcessElement(Unknown Source)
      	at org.apache.beam.fn.harness.FnApiDoFnRunner.processElementForWindowObservingParDo(FnApiDoFnRunner.java:764)
      	at org.apache.beam.fn.harness.data.PCollectionConsumerRegistry$MetricTrackingFnDataReceiver.accept(PCollectionConsumerRegistry.java:246)
      	at org.apache.beam.fn.harness.data.PCollectionConsumerRegistry$MetricTrackingFnDataReceiver.accept(PCollectionConsumerRegistry.java:200)
      	at org.apache.beam.fn.harness.FnApiDoFnRunner.outputTo(FnApiDoFnRunner.java:1681)
      	at org.apache.beam.fn.harness.FnApiDoFnRunner.access$2500(FnApiDoFnRunner.java:139)
      	at org.apache.beam.fn.harness.FnApiDoFnRunner$WindowObservingProcessBundleContext.outputWithTimestamp(FnApiDoFnRunner.java:2082)
      	at org.apache.beam.sdk.transforms.DoFnOutputReceivers$WindowedContextOutputReceiver.outputWithTimestamp(DoFnOutputReceivers.java:87)
      	at org.apache.beam.sdk.io.Read$BoundedSourceAsSDFWrapperFn.processElement(Read.java:308)
      	at org.apache.beam.sdk.io.Read$BoundedSourceAsSDFWrapperFn$DoFnInvoker.invokeProcessElement(Unknown Source)
      	at org.apache.beam.fn.harness.FnApiDoFnRunner.processElementForWindowObservingSizedElementAndRestriction(FnApiDoFnRunner.java:1049)
      	at org.apache.beam.fn.harness.FnApiDoFnRunner.access$1000(FnApiDoFnRunner.java:139)
      	at org.apache.beam.fn.harness.FnApiDoFnRunner$4.accept(FnApiDoFnRunner.java:638)
      	at org.apache.beam.fn.harness.FnApiDoFnRunner$4.accept(FnApiDoFnRunner.java:633)
      	at org.apache.beam.fn.harness.data.PCollectionConsumerRegistry$MetricTrackingFnDataReceiver.accept(PCollectionConsumerRegistry.java:246)
      	at org.apache.beam.fn.harness.data.PCollectionConsumerRegistry$MetricTrackingFnDataReceiver.accept(PCollectionConsumerRegistry.java:200)
      	at org.apache.beam.fn.harness.BeamFnDataReadRunner.forwardElementToConsumer(BeamFnDataReadRunner.java:220)
      	at org.apache.beam.sdk.fn.data.DecodingFnDataReceiver.accept(DecodingFnDataReceiver.java:43)
      	at org.apache.beam.sdk.fn.data.DecodingFnDataReceiver.accept(DecodingFnDataReceiver.java:25)
      	at org.apache.beam.fn.harness.data.QueueingBeamFnDataClient.drainAndBlock(QueueingBeamFnDataClient.java:111)
      	at org.apache.beam.fn.harness.control.ProcessBundleHandler.processBundle(ProcessBundleHandler.java:308)
      	at org.apache.beam.fn.harness.control.BeamFnControlClient.delegateOnInstructionRequestType(BeamFnControlClient.java:173)
      	at org.apache.beam.fn.harness.control.BeamFnControlClient.lambda$processInstructionRequests$0(BeamFnControlClient.java:157)
      	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.AssertionError: expected:<2> but was:<0>
      	at org.junit.Assert.fail(Assert.java:89)
      	at org.junit.Assert.failNotEquals(Assert.java:835)
      	at org.junit.Assert.assertEquals(Assert.java:647)
      	at org.junit.Assert.assertEquals(Assert.java:633)
      	at org.apache.beam.sdk.transforms.ViewTest$24.processElement(ViewTest.java:1008)
      

      Attachments

        Issue Links

          Activity

            People

              kenn Kenneth Knowles
              tvalentyn Valentyn Tymofieiev
              Votes:
              0 Vote for this issue
              Watchers:
              1 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved:

                Time Tracking

                  Estimated:
                  Original Estimate - Not Specified
                  Not Specified
                  Remaining:
                  Remaining Estimate - 0h
                  0h
                  Logged:
                  Time Spent - 1h
                  1h