You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@beam.apache.org by "ASF GitHub Bot (Jira)" <ji...@apache.org> on 2022/01/19 00:00:00 UTC

[jira] [Work logged] (BEAM-13611) CrossLanguageJdbcIOTest.test_xlang_jdbc_write failing in Python PostCommits

     [ https://issues.apache.org/jira/browse/BEAM-13611?focusedWorklogId=710989&page=com.atlassian.jira.plugin.system.issuetabpanels:worklog-tabpanel#worklog-710989 ]

ASF GitHub Bot logged work on BEAM-13611:
-----------------------------------------

                Author: ASF GitHub Bot
            Created on: 18/Jan/22 23:59
            Start Date: 18/Jan/22 23:59
    Worklog Time Spent: 10m 
      Work Description: TheNeuralBit commented on pull request #16554:
URL: https://github.com/apache/beam/pull/16554#issuecomment-1015941310


   Run Python 3.6 PostCommit


-- 
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

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


Issue Time Tracking
-------------------

    Worklog Id:     (was: 710989)
    Time Spent: 20m  (was: 10m)

> CrossLanguageJdbcIOTest.test_xlang_jdbc_write failing in Python PostCommits
> ---------------------------------------------------------------------------
>
>                 Key: BEAM-13611
>                 URL: https://issues.apache.org/jira/browse/BEAM-13611
>             Project: Beam
>          Issue Type: Bug
>          Components: test-failures
>            Reporter: Brian Hulette
>            Assignee: Pablo Estrada
>            Priority: P1
>              Labels: currently-failing
>          Time Spent: 20m
>  Remaining Estimate: 0h
>
> apache_beam.io.external.xlang_jdbcio_it_test.CrossLanguageJdbcIOTest.test_xlang_jdbc_write has been failing for a while with exception:
> {code}
> >       raise self._runtime_exception
> E       RuntimeError: Pipeline BeamApp-jenkins-0107121045-d4c26ca6_6fb3ef1a-9704-4c9b-8e6a-b01577324d10 failed in state FAILED: java.lang.RuntimeException: Error received from SDK harness for instruction 3: org.apache.beam.sdk.util.UserCodeException: org.apache.beam.sdk.coders.CoderException: cannot encode a null Iterable
> E       	at org.apache.beam.sdk.util.UserCodeException.wrap(UserCodeException.java:39)
> E       	at org.apache.beam.fn.harness.FnApiDoFnRunner.outputTo(FnApiDoFnRunner.java:1751)
> E       	at org.apache.beam.fn.harness.FnApiDoFnRunner.access$2700(FnApiDoFnRunner.java:144)
> E       	at org.apache.beam.fn.harness.FnApiDoFnRunner$FinishBundleArgumentProvider$Context.output(FnApiDoFnRunner.java:2078)
> E       	at org.apache.beam.sdk.io.jdbc.JdbcIO$1.finish(JdbcIO.java:1459)
> E       	at org.apache.beam.sdk.io.jdbc.JdbcIO$1$DoFnInvoker.invokeFinishBundle(Unknown Source)
> E       	at org.apache.beam.fn.harness.FnApiDoFnRunner.finishBundle(FnApiDoFnRunner.java:1729)
> E       	at org.apache.beam.fn.harness.data.PTransformFunctionRegistry.lambda$register$0(PTransformFunctionRegistry.java:111)
> E       	at org.apache.beam.fn.harness.control.ProcessBundleHandler.processBundle(ProcessBundleHandler.java:489)
> E       	at org.apache.beam.fn.harness.control.BeamFnControlClient.delegateOnInstructionRequestType(BeamFnControlClient.java:151)
> E       	at org.apache.beam.fn.harness.control.BeamFnControlClient$InboundObserver.lambda$onNext$0(BeamFnControlClient.java:116)
> E       	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
> E       	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
> E       	at java.lang.Thread.run(Thread.java:748)
> E       Caused by: org.apache.beam.sdk.coders.CoderException: cannot encode a null Iterable
> E       	at org.apache.beam.sdk.coders.IterableLikeCoder.registerByteSizeObserver(IterableLikeCoder.java:195)
> E       	at org.apache.beam.sdk.coders.IterableLikeCoder.registerByteSizeObserver(IterableLikeCoder.java:60)
> E       	at org.apache.beam.fn.harness.data.PCollectionConsumerRegistry$SampleByteSizeDistribution.tryUpdate(PCollectionConsumerRegistry.java:374)
> E       	at org.apache.beam.fn.harness.data.PCollectionConsumerRegistry$MetricTrackingFnDataReceiver.accept(PCollectionConsumerRegistry.java:248)
> E       	at org.apache.beam.fn.harness.data.PCollectionConsumerRegistry$MetricTrackingFnDataReceiver.accept(PCollectionConsumerRegistry.java:209)
> {code}
> First failure in Py3.8 PostCommit was [#2110|https://ci-beam.apache.org/job/beam_PostCommit_Python38/2110/testReport/junit/apache_beam.io.external.xlang_jdbcio_it_test/CrossLanguageJdbcIOTest/test_xlang_jdbc_write/] but this actually had a different error. The first failure with this exception was [#2130|https://ci-beam.apache.org/job/beam_PostCommit_Python38/2130/testReport/junit/apache_beam.io.external.xlang_jdbcio_it_test/CrossLanguageJdbcIOTest/test_xlang_jdbc_write/]



--
This message was sent by Atlassian Jira
(v8.20.1#820001)