You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@beam.apache.org by "Brian Hulette (Jira)" <ji...@apache.org> on 2021/02/12 01:17:00 UTC

[jira] [Commented] (BEAM-11805) SpannerReadIT broken in PostCommit_Java

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

Brian Hulette commented on BEAM-11805:
--------------------------------------

I confirmed that pr/13765 is the culprit with some local tests. Running SpannerReadIT.testQuery at commit [e0ba4dc6|https://github.com/apache/beam/commit/e0ba4dc62e6af341cd4448e14ab5839a92516474] fails, running it at the preceding commit, [6e03cfd1|https://github.com/apache/beam/commit/6e03cfd1dec2ba6356061da99ea3b59caba5b0a0], passes.

I guess the BOM update pulled in a new version of the spanner client that has a bug, or is otherwise incompatible with Beam. 

> SpannerReadIT broken in PostCommit_Java
> ---------------------------------------
>
>                 Key: BEAM-11805
>                 URL: https://issues.apache.org/jira/browse/BEAM-11805
>             Project: Beam
>          Issue Type: Bug
>          Components: io-java-gcp
>            Reporter: Brian Hulette
>            Priority: P1
>
> SpannerReadIT started failing after https://github.com/apache/beam/pull/13765 went in: 
> https://ci-beam.apache.org/job/beam_PostCommit_Java/7195/
> Example log:
> {code}
> java.lang.RuntimeException: java.lang.RuntimeException: org.apache.beam.sdk.util.UserCodeException: java.lang.IllegalArgumentException: Multiple entries with same key: user-agent=Apache_Beam_Java/2.29.0-SNAPSHOT and user-agent=spanner-java/3.2.1
> 	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory$1.typedApply(IntrinsicMapTaskExecutorFactory.java:197)
> 	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory$1.typedApply(IntrinsicMapTaskExecutorFactory.java:168)
> 	at org.apache.beam.runners.dataflow.worker.graph.Networks$TypeSafeNodeFunction.apply(Networks.java:66)
> 	at org.apache.beam.runners.dataflow.worker.graph.Networks$TypeSafeNodeFunction.apply(Networks.java:53)
> 	at org.apache.beam.runners.dataflow.worker.graph.Networks.replaceDirectedNetworkNodes(Networks.java:90)
> 	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory.create(IntrinsicMapTaskExecutorFactory.java:128)
> 	at org.apache.beam.runners.dataflow.worker.BatchDataflowWorker.doWork(BatchDataflowWorker.java:361)
> 	at org.apache.beam.runners.dataflow.worker.BatchDataflowWorker.getAndPerformWork(BatchDataflowWorker.java:314)
> 	at org.apache.beam.runners.dataflow.worker.DataflowBatchWorkerHarness$WorkerThread.doWork(DataflowBatchWorkerHarness.java:140)
> 	at org.apache.beam.runners.dataflow.worker.DataflowBatchWorkerHarness$WorkerThread.call(DataflowBatchWorkerHarness.java:120)
> 	at org.apache.beam.runners.dataflow.worker.DataflowBatchWorkerHarness$WorkerThread.call(DataflowBatchWorkerHarness.java:107)
> 	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
> 	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: org.apache.beam.sdk.util.UserCodeException: java.lang.IllegalArgumentException: Multiple entries with same key: user-agent=Apache_Beam_Java/2.29.0-SNAPSHOT and user-agent=spanner-java/3.2.1
> 	at org.apache.beam.sdk.util.UserCodeException.wrap(UserCodeException.java:39)
> 	at org.apache.beam.sdk.io.gcp.spanner.CreateTransactionFn$DoFnInvoker.invokeSetup(Unknown Source)
> 	at org.apache.beam.runners.dataflow.worker.DoFnInstanceManagers$ConcurrentQueueInstanceManager.deserializeCopy(DoFnInstanceManagers.java:83)
> 	at org.apache.beam.runners.dataflow.worker.DoFnInstanceManagers$ConcurrentQueueInstanceManager.peek(DoFnInstanceManagers.java:65)
> 	at org.apache.beam.runners.dataflow.worker.UserParDoFnFactory.create(UserParDoFnFactory.java:99)
> 	at org.apache.beam.runners.dataflow.worker.DefaultParDoFnFactory.create(DefaultParDoFnFactory.java:75)
> 	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory.createParDoOperation(IntrinsicMapTaskExecutorFactory.java:267)
> 	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory.access$000(IntrinsicMapTaskExecutorFactory.java:89)
> 	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory$1.typedApply(IntrinsicMapTaskExecutorFactory.java:186)
> 	... 14 more
> Caused by: java.lang.IllegalArgumentException: Multiple entries with same key: user-agent=Apache_Beam_Java/2.29.0-SNAPSHOT and user-agent=spanner-java/3.2.1
> 	at com.google.common.collect.ImmutableMap.conflictException(ImmutableMap.java:215)
> 	at com.google.common.collect.ImmutableMap.checkNoConflict(ImmutableMap.java:209)
> 	at com.google.common.collect.RegularImmutableMap.checkNoConflictInKeyBucket(RegularImmutableMap.java:147)
> 	at com.google.common.collect.RegularImmutableMap.fromEntryArray(RegularImmutableMap.java:110)
> 	at com.google.common.collect.ImmutableMap$Builder.build(ImmutableMap.java:393)
> 	at com.google.cloud.spanner.spi.v1.GapicSpannerRpc.<init>(GapicSpannerRpc.java:320)
> 	at com.google.cloud.spanner.SpannerOptions$DefaultSpannerRpcFactory.create(SpannerOptions.java:467)
> 	at com.google.cloud.spanner.SpannerOptions$DefaultSpannerRpcFactory.create(SpannerOptions.java:462)
> 	at com.google.cloud.ServiceOptions.getRpc(ServiceOptions.java:561)
> 	at com.google.cloud.spanner.SpannerOptions.getSpannerRpcV1(SpannerOptions.java:1169)
> 	at com.google.cloud.spanner.SpannerImpl.<init>(SpannerImpl.java:134)
> 	at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:457)
> 	at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:452)
> 	at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:541)
> 	at org.apache.beam.sdk.io.gcp.spanner.SpannerAccessor.createAndConnect(SpannerAccessor.java:163)
> 	at org.apache.beam.sdk.io.gcp.spanner.SpannerAccessor.getOrCreate(SpannerAccessor.java:98)
> 	at org.apache.beam.sdk.io.gcp.spanner.CreateTransactionFn.setup(CreateTransactionFn.java:39)
> {code}



--
This message was sent by Atlassian Jira
(v8.3.4#803005)