You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@beam.apache.org by "Scott Wegner (JIRA)" <ji...@apache.org> on 2019/01/03 16:59:00 UTC

[jira] [Commented] (BEAM-6355) [beam_PostRelease_NightlySnapshot] [runQuickstartJavaDataflow] ExceptionInInitializerError

    [ https://issues.apache.org/jira/browse/BEAM-6355?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel&focusedCommentId=16733222#comment-16733222 ] 

Scott Wegner commented on BEAM-6355:
------------------------------------

This only seems to be failing in the beam_PostRelease_NightlySnapshot suite; so perhaps there's a problem with the artifacts we're publishing?

The suite was previously failing due to BEAM-6249, but this is now fixed.

 

[~boyuanz] can you help investigate?

> [beam_PostRelease_NightlySnapshot] [runQuickstartJavaDataflow] ExceptionInInitializerError
> ------------------------------------------------------------------------------------------
>
>                 Key: BEAM-6355
>                 URL: https://issues.apache.org/jira/browse/BEAM-6355
>             Project: Beam
>          Issue Type: Bug
>          Components: runner-dataflow, test-failures
>            Reporter: Scott Wegner
>            Assignee: Boyuan Zhang
>            Priority: Major
>              Labels: currently-failing
>
> _Use this form to file an issue for test failure:_
>  * [Jenkins Job|https://builds.apache.org/job/beam_PostRelease_NightlySnapshot/480/]
>  * [Dataflow Job|https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-01-03_03_07_12-9648275706628895259?project=apache-beam-testing&folder&organizationId=433637338589]
>  * [Test source code|https://github.com/apache/beam/blob/master/release/src/main/groovy/quickstart-java-dataflow.groovy]
> Initial investigation:
> It appears the Dataflow job failed during worker initialization. From the [stackdriver logs|https://console.cloud.google.com/logs/viewer?resource=dataflow_step%2Fjob_id%2F2019-01-03_03_07_12-9648275706628895259&logName=projects%2Fapache-beam-testing%2Flogs%2Fdataflow.googleapis.com%252Fworker&interval=NO_LIMIT&project=apache-beam-testing&folder&organizationId=433637338589&minLogLevel=500&expandAll=false&timestamp=2019-01-03T16:52:14.643000000Z&customFacets=&limitCustomFacetWidth=true&scrollTimestamp=2019-01-03T11:08:49.882000000Z], I see:
> {code}
> 019-01-03 03:08:27.770 PST
> Uncaught exception occurred during work unit execution. This will be retried.
> Expand all | Collapse all {
>  insertId:  "3832125194122580497:879173:0:62501"  
>  jsonPayload: {
>   exception:  "java.lang.ExceptionInInitializerError
> 	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory$2.typedApply(IntrinsicMapTaskExecutorFactory.java:344)
> 	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory$2.typedApply(IntrinsicMapTaskExecutorFactory.java:338)
> 	at org.apache.beam.runners.dataflow.worker.graph.Networks$TypeSafeNodeFunction.apply(Networks.java:63)
> 	at org.apache.beam.runners.dataflow.worker.graph.Networks$TypeSafeNodeFunction.apply(Networks.java:50)
> 	at org.apache.beam.runners.dataflow.worker.graph.Networks.replaceDirectedNetworkNodes(Networks.java:87)
> 	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory.create(IntrinsicMapTaskExecutorFactory.java:120)
> 	at org.apache.beam.runners.dataflow.worker.BatchDataflowWorker.doWork(BatchDataflowWorker.java:337)
> 	at org.apache.beam.runners.dataflow.worker.BatchDataflowWorker.getAndPerformWork(BatchDataflowWorker.java:291)
> 	at org.apache.beam.runners.dataflow.worker.DataflowBatchWorkerHarness$WorkerThread.doWork(DataflowBatchWorkerHarness.java:135)
> 	at org.apache.beam.runners.dataflow.worker.DataflowBatchWorkerHarness$WorkerThread.call(DataflowBatchWorkerHarness.java:115)
> 	at org.apache.beam.runners.dataflow.worker.DataflowBatchWorkerHarness$WorkerThread.call(DataflowBatchWorkerHarness.java:102)
> 	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142)
> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:617)
> 	at java.lang.Thread.run(Thread.java:745)
> Caused by: java.lang.IllegalArgumentException: Multiple entries with same key: kind:varint=org.apache.beam.runners.dataflow.util.CloudObjectTranslators$8@f4dd50c and kind:varint=org.apache.beam.runners.dataflow.worker.RunnerHarnessCoderCloudObjectTranslatorRegistrar$1@ae1551d
> 	at org.apache.beam.repackaged.beam_runners_google_cloud_dataflow_java.com.google.common.collect.ImmutableMap.checkNoConflict(ImmutableMap.java:136)
> 	at org.apache.beam.repackaged.beam_runners_google_cloud_dataflow_java.com.google.common.collect.RegularImmutableMap.checkNoConflictInKeyBucket(RegularImmutableMap.java:100)
> 	at org.apache.beam.repackaged.beam_runners_google_cloud_dataflow_java.com.google.common.collect.RegularImmutableMap.fromEntryArray(RegularImmutableMap.java:86)
> 	at org.apache.beam.repackaged.beam_runners_google_cloud_dataflow_java.com.google.common.collect.ImmutableMap$Builder.build(ImmutableMap.java:300)
> 	at org.apache.beam.runners.dataflow.util.CloudObjects.populateCloudObjectTranslators(CloudObjects.java:60)
> 	at org.apache.beam.runners.dataflow.util.CloudObjects.<clinit>(CloudObjects.java:39)
> 	... 15 more
> "   
>   job:  "2019-01-03_03_07_12-9648275706628895259"   
>   logger:  "org.apache.beam.runners.dataflow.worker.WorkItemStatusClient"   
>   message:  "Uncaught exception occurred during work unit execution. This will be retried."   
>   stage:  "s02"   
>   thread:  "25"   
>   work:  "3351302260861052159"   
>   worker:  "wordcount-jenkins-0103110-01030307-jdht-harness-xgxv"   
>  }
>  labels: {...}  
>  logName:  "projects/apache-beam-testing/logs/dataflow.googleapis.com%2Fworker"  
>  receiveTimestamp:  "2019-01-03T11:08:32.923408376Z"  
>  resource: {...}  
>  severity:  "ERROR"  
>  timestamp:  "2019-01-03T11:08:27.770Z"  
> }
> {code}
> ----
> _After you've filled out the above details, please [assign the issue to an individual|https://beam.apache.org/contribute/postcommits-guides/index.html#find_specialist]. Assignee should [treat test failures as high-priority|https://beam.apache.org/contribute/postcommits-policies/#assigned-failing-test], helping to fix the issue or find a more appropriate owner. See [Apache Beam Post-Commit Policies|https://beam.apache.org/contribute/postcommits-policies]._



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)