You are viewing a plain text version of this content. The canonical link for it is here.
Posted to github@beam.apache.org by GitBox <gi...@apache.org> on 2022/06/05 00:18:57 UTC

[GitHub] [beam] damccorm opened a new issue, #21545: [SpannerIO.readChangeStream] Fix Flaky Spanner Change Stream Tests

damccorm opened a new issue, #21545:
URL: https://github.com/apache/beam/issues/21545

   SpannerChangeStreamOrderedWithinKeyIT and 
   
   SpannerChangeStreamOrderedWithinKeyGloballyIT were disabled, because they were flaky.
   
    
   
   Here we should fix / re-enable them
   
   Imported from Jira [BEAM-14195](https://issues.apache.org/jira/browse/BEAM-14195). Original Jira may contain additional context.
   Reported by: thiagotnunes.


-- 
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.apache.org

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


[GitHub] [beam] Abacn commented on issue #21545: [SpannerIO.readChangeStream] Fix Flaky Spanner Change Stream Tests

Posted by "Abacn (via GitHub)" <gi...@apache.org>.
Abacn commented on issue #21545:
URL: https://github.com/apache/beam/issues/21545#issuecomment-1624299311

   another occurrance: https://ci-beam.apache.org/job/beam_PostCommit_Java_DataflowV2_PR/196/testReport/junit/org.apache.beam.sdk.io.gcp.spanner.changestreams.it/SpannerChangeStreamOrderedWithinKeyIT/testOrderedWithinKey/
   
   ```
   Error Message
   java.lang.RuntimeException: generic::unknown: org.apache.beam.sdk.util.UserCodeException: java.lang.IllegalStateException: Initial partition not found in metadata table.
   	at org.apache.beam.sdk.util.UserCodeException.wrap(UserCodeException.java:39)
   	at org.apache.beam.sdk.io.gcp.spanner.changestreams.dofn.InitializeDoFn$DoFnInvoker.invokeProcessElement(Unknown Source)
   	at org.apache.beam.fn.harness.FnApiDoFnRunner.processElementForParDo(FnApiDoFnRunner.java:799)
   	at org.apache.beam.fn.harness.data.PCollectionConsumerRegistry$MultiplexingMetricTrackingFnDataReceiver.accept(PCollectionConsumerRegistry.java:420)
   	at org.apache.beam.fn.harness.data.PCollectionConsumerRegistry$MultiplexingMetricTrackingFnDataReceiver.accept(PCollectionConsumerRegistry.java:348)
   	at org.apache.beam.fn.harness.BeamFnDataReadRunner.forwardElementToConsumer(BeamFnDataReadRunner.java:213)
   	at org.apache.beam.sdk.fn.data.BeamFnDataInboundObserver.multiplexElements(BeamFnDataInboundObserver.java:158)
   	at org.apache.beam.fn.harness.control.ProcessBundleHandler.processBundle(ProcessBundleHandler.java:537)
   	at org.apache.beam.fn.harness.control.BeamFnControlClient.delegateOnInstructionRequestType(BeamFnControlClient.java:150)
   	at org.apache.beam.fn.harness.control.BeamFnControlClient$InboundObserver.lambda$onNext$0(BeamFnControlClient.java:115)
   	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
   	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
   	at org.apache.beam.sdk.util.UnboundedScheduledExecutorService$ScheduledFutureTask.run(UnboundedScheduledExecutorService.java:163)
   	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:750)
   Caused by: java.lang.IllegalStateException: Initial partition not found in metadata table.
   	at org.apache.beam.sdk.io.gcp.spanner.changestreams.dofn.InitializeDoFn.lambda$processElement$0(InitializeDoFn.java:74)
   	at java.util.Optional.orElseThrow(Optional.java:290)
   	at org.apache.beam.sdk.io.gcp.spanner.changestreams.dofn.InitializeDoFn.processElement(InitializeDoFn.java:73)
   
   ```
   
   


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