You are viewing a plain text version of this content. The canonical link for it is here.
Posted to builds@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2021/10/20 20:09:20 UTC

Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8532

See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8532/display/redirect>

Changes:


------------------------------------------
[...truncated 20.15 MB...]
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15900']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:19.204Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15942: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15932']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15942: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15932']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.899Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-20_11_41_36-4681363164731049808.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.920Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.920Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.920Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.920Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.921Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.921Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.921Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.921Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.921Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.922Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.922Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.922Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.923Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.923Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.923Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:24.923Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:25.004Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:25.050Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-20T19:56:25.098Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-20_11_41_36-4681363164731049808 is in state JOB_STATE_CANCELLING
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py36-xdist.xml> -
============== 1 failed, 29 passed, 3 skipped in 5285.22 seconds ===============

> Task :sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 8m 45s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/p3kvuqah3brlk

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Jenkins build is back to normal : beam_PostCommit_Py_VR_Dataflow #8561

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8561/display/redirect?page=changes>


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8560

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8560/display/redirect?page=changes>

Changes:

[relax] support json

[Andrew Pilloud] [BEAM-13118] Don't force push to master

[noreply] Merge pull request #15731: [BEAM-13067]  Mark GroupIntoBatches output as


------------------------------------------
[...truncated 20.05 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15783']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:06.544Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15827: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15823']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15827: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15823']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.436Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-27_11_47_30-6315732531014595250.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.459Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.459Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.460Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.460Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.460Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.460Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.460Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.461Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.461Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.461Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.461Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.461Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.462Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.462Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.462Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.462Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.578Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.656Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T20:02:10.680Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-27_11_47_30-6315732531014595250 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5307.07 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 14m 40s
92 actionable tasks: 66 executed, 26 from cache

Publishing build scan...
https://gradle.com/s/x6fjil7r5tnje

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8559

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8559/display/redirect?page=changes>

Changes:

[mmack] [BEAM-8958] Use AWS credentials provider with BasicKinesisProvider (AWS


------------------------------------------
[...truncated 20.14 MB...]
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15896']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.681Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-27_05_41_28-17211155000630242574.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.709Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.709Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.710Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.710Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.710Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.710Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.729Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.729Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.729Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.729Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.729Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.729Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.729Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.729Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.730Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.730Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.855Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.907Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:15.944Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T13:56:16.949Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15942: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15936']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15942: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15936']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-27_05_41_28-17211155000630242574 is in state JOB_STATE_CANCELLING
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py37-xdist.xml> -
============== 1 failed, 29 passed, 3 skipped in 5363.32 seconds ===============

> Task :sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 9m 58s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/tunhpujh2gkzs

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8558

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8558/display/redirect?page=changes>

Changes:

[heejong] [BEAM-12978] Customizable dependency for Java external transform

[heejong] add ConfigT param to getDependencies method


------------------------------------------
[...truncated 20.16 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15988']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.287Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-27_00_00_42-6433819882592616925.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.307Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.307Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.307Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.307Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.307Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.307Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.307Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.307Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.307Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.308Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.308Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.308Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.308Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.308Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.308Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.308Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.458Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.504Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:33.535Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T08:15:34.558Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -16032: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16028']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -16032: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16028']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-27_00_00_42-6433819882592616925 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5250.76 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 27m 15s
92 actionable tasks: 76 executed, 16 from cache

Publishing build scan...
https://gradle.com/s/wcmwmanxrpzlc

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8557

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8557/display/redirect?page=changes>

Changes:

[baeminbo] [BEAM-6721] Set numShards dynamically for TextIO.write()

[melissapa] [BEAM-11758] Update basics page: Splittable DoFn

[noreply] Change sql.Options to an interface under sqlx. (#15790)

[melissapa] Address review feedback

[noreply] [BEAM-4149] Ensure that we always provide and require the worker id.

[noreply] [BEAM-13098] Fix translation of repeated TableRow fields (#15779)


------------------------------------------
[...truncated 20.05 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15864']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-27T02:10:34.350Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15908: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15898']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15908: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15898']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-26_17_55_52-17811697331907041987 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5269.17 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 22m 48s
92 actionable tasks: 74 executed, 18 from cache

Publishing build scan...
https://gradle.com/s/f7co423q7vtbe

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8556

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8556/display/redirect?page=changes>

Changes:

[Alexey Romanenko] [BEAM-13104] ParquetIO: SplitReadFn must read the whole block


------------------------------------------
[...truncated 20.01 MB...]
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15836']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:26.051Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15876: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15872']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15876: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15872']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:33.987Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-26_11_43_14-10323044001209397574.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.013Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.013Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.013Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.014Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.014Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.014Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.014Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.015Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.015Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.015Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.015Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.015Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.016Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.016Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.016Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.016Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.140Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.196Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T19:57:34.229Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-26_11_43_14-10323044001209397574 is in state JOB_STATE_CANCELLING
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py36-xdist.xml> -
============== 1 failed, 29 passed, 3 skipped in 5359.93 seconds ===============

> Task :sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 9m 47s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/rbfpam76apph6

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8555

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8555/display/redirect?page=changes>

Changes:

[noreply] Merge pull request #15744 from [BEAM-13072][Playground] Executor builder


------------------------------------------
[...truncated 19.98 MB...]
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15902: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15892']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T13:58:10.428Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15938: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15928']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15938: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15928']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-26_05_43_34-9500257538654918447 is in state JOB_STATE_CANCELLING
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py36-xdist.xml> -
============== 1 failed, 29 passed, 3 skipped in 5278.87 seconds ===============

> Task :sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 10m 15s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/fuqhzrhzgykgc

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8554

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8554/display/redirect>

Changes:


------------------------------------------
[...truncated 20.18 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15988']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.813Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-25_23_40_53-17336676974679870102.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.836Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.836Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.836Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.837Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.837Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.838Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.839Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.839Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.840Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.841Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.841Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.842Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.842Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.842Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.843Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.843Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:44.944Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:45.005Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:45.033Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T07:55:45.995Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -16032: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16026']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -16032: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16026']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-25_23_40_53-17336676974679870102 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5259.35 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 7m 41s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/n2txlgatnskhs

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8553

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8553/display/redirect?page=changes>

Changes:

[Luke Cwik] [BEAM-12522] Enable side inputs on all splittable DoFn execution time

[aydar.zaynutdinov] [BEAM-13062][Playground]

[ilya.kozyrev] Add environment_service.go and structures for beam sdk, network envs,

[aydar.zaynutdinov] [BEAM-13062][Playground]

[noreply] Merge pull request #15714 from [BEAM-13005] [Playground] Implement local

[noreply] Merge pull request #15770 from [BEAM-13095][Playground] Using working

[noreply] [BEAM-11758] Update basics page: Aggregation, Runner, UDF, Schema

[noreply] Merge pull request #15783 from [BEAM-13048] [Playground] Add shortcuts

[Luke Cwik] [BEAM-8543] Fix test filtering for Dataflow Runner V2 to exclude


------------------------------------------
[...truncated 20.12 MB...]
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15987']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.661Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -16027: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16017']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -16027: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16017']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.716Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-25_17_52_16-16779229886284317410.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.742Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.742Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.742Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.742Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.742Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.742Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.742Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.742Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.743Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.744Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.745Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.745Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.746Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.746Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.746Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.746Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.847Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.905Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-26T02:07:05.924Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-25_17_52_16-16779229886284317410 is in state JOB_STATE_CANCELLING
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py36-xdist.xml> -
============== 1 failed, 29 passed, 3 skipped in 5266.32 seconds ===============

> Task :sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 19m 2s
92 actionable tasks: 71 executed, 21 from cache

Publishing build scan...
https://gradle.com/s/7ndjdntm6eswu

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8552

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8552/display/redirect?page=changes>

Changes:

[noreply] Merge pull request #15772 from [BEAM-13032] [Playground] Implement the


------------------------------------------
[...truncated 20.13 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16001']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.671Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-25_11_41_27-8728346575300244527.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.693Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.693Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.693Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.693Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.693Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.697Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.697Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.697Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.697Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.698Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.698Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.699Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.699Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.699Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.699Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.700Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.826Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.895Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:17.932Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T19:56:18.787Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -16045: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16037']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -16045: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16037']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-25_11_41_27-8728346575300244527 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5276.29 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 8m 30s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/d3evejepsjoou

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8551

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8551/display/redirect>

Changes:


------------------------------------------
[...truncated 20.13 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15977']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.717Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-25_05_40_49-5081566904065321977.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.742Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.742Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.742Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.742Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.742Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.742Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.743Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.743Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.743Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.743Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.744Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.744Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.744Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.744Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.744Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.744Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.822Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.876Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:39.907Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T13:55:40.400Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -16023: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16013']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -16023: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16013']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-25_05_40_49-5081566904065321977 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5271.16 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 7m 48s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/wv6ccxe6cktem

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8550

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8550/display/redirect?page=changes>

Changes:

[noreply] Fixing BigQueryIO request too big corner case for streaming inserts


------------------------------------------
[...truncated 20.16 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15974']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:45.854Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -16016: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16006']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -16016: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16006']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.780Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-24_23_41_58-7828702282960084643.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.803Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.803Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.803Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.803Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.803Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.803Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.803Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.804Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.805Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.805Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.805Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.805Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.806Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.806Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.806Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.806Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.898Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.948Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T07:56:48.971Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-24_23_41_58-7828702282960084643 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5252.76 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 8m 36s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/k2wxou7odozqm

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8549

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8549/display/redirect>

Changes:


------------------------------------------
[...truncated 20.17 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16027']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.569Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-24_17_42_20-1696690793327552731.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.603Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.603Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.603Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.603Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.603Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.604Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.604Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.604Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.605Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.605Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.606Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.607Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.607Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.607Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.607Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.607Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.698Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.753Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:09.786Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-25T01:57:10.191Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -16069: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16063']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -16069: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16063']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-24_17_42_20-1696690793327552731 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5255.15 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 8m 55s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/efsmwy7kpc7c4

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8548

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8548/display/redirect>

Changes:


------------------------------------------
[...truncated 20.14 MB...]
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16031']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:08.356Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -16077: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16067']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -16077: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16067']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.453Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-24_11_43_21-17822686999837145424.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.473Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.473Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.473Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.473Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.473Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.473Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.473Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.473Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.474Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.474Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.474Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.474Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.474Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.474Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.474Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.474Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.550Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.605Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T19:58:09.629Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-24_11_43_21-17822686999837145424 is in state JOB_STATE_CANCELLING
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py37-xdist.xml> -
============== 1 failed, 29 passed, 3 skipped in 5278.89 seconds ===============

> Task :sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 10m 15s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/wvot4n63ebbaa

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8547

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8547/display/redirect>

Changes:


------------------------------------------
[...truncated 20.14 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15916']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T13:56:17.494Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15956: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15946']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15956: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15946']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-24_05_41_38-3276276416611072841 is in state JOB_STATE_CANCELLING
INFO     oauth2client.transport:transport.py:183 Refreshing due to a 401 (attempt 1/2)
INFO     oauth2client.transport:transport.py:183 Refreshing due to a 401 (attempt 1/2)
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5294.21 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 8m 54s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/ykhtbrzygtglw

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8546

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8546/display/redirect>

Changes:


------------------------------------------
[...truncated 20.11 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15819']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:07.827Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15863: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15855']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15863: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15855']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.733Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-23_23_41_23-1904402097242090142.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.756Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.756Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.757Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.757Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.757Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.757Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.757Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.757Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.757Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.757Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.758Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.758Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.758Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.758Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.758Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.758Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.871Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.911Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T07:56:12.949Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-23_23_41_23-1904402097242090142 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5283.15 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 8m 23s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/u5omng3ubgdoy

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8545

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8545/display/redirect>

Changes:


------------------------------------------
[...truncated 20.20 MB...]
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15938: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15930']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-24T01:56:08.943Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15974: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15966']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15974: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15966']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-23_17_41_21-8376118636502649544 is in state JOB_STATE_CANCELLING
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py36-xdist.xml> -
============== 1 failed, 29 passed, 3 skipped in 5253.61 seconds ===============

> Task :sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 7m 59s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/3crstbvyz32sa

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8544

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8544/display/redirect>

Changes:


------------------------------------------
[...truncated 20.13 MB...]
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15911']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:04.005Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15951: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15945']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15951: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15945']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.661Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-23_11_42_21-6322213794682047065.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.683Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.683Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.684Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.684Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.684Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.685Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.685Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.685Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.685Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.686Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.686Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.686Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.686Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.687Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.687Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.687Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.777Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.830Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T19:57:07.846Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-23_11_42_21-6322213794682047065 is in state JOB_STATE_CANCELLING
INFO     oauth2client.transport:transport.py:183 Refreshing due to a 401 (attempt 1/2)
INFO     oauth2client.transport:transport.py:183 Refreshing due to a 401 (attempt 1/2)
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5296.86 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 9m 37s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/ouflgoeonlhac

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8543

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8543/display/redirect>

Changes:


------------------------------------------
[...truncated 20.17 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15966']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.416Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -16008: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16004']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -16008: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16004']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.468Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-23_05_41_19-13834932026515039922.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.493Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.493Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.493Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.493Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.493Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.493Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.494Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.494Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.494Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.494Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.494Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.495Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.495Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.495Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.495Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.495Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.656Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.711Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T13:56:09.735Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-23_05_41_19-13834932026515039922 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5243.75 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 7m 49s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/sm33udajy3znm

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8542

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8542/display/redirect>

Changes:


------------------------------------------
[...truncated 20.12 MB...]
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15944: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15938']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T07:56:11.014Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15980: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15972']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15980: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15972']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-22_23_41_23-8930066644825340356 is in state JOB_STATE_CANCELLING
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py37-xdist.xml> -
============== 1 failed, 29 passed, 3 skipped in 5264.97 seconds ===============

> Task :sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 8m 6s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/x7vygxs6zqscw

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8541

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8541/display/redirect>

Changes:


------------------------------------------
[...truncated 20.10 MB...]
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15961']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:41.164Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -16007: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15999']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -16007: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15999']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.442Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-22_17_40_58-15683077360371906242.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.462Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.462Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.462Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.463Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.463Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.463Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.463Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.463Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.463Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.463Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.463Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.463Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.464Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.464Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.464Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.464Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.528Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.563Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-23T01:55:48.618Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-22_17_40_58-15683077360371906242 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5263.42 seconds =========

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 7m 45s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/3lmidzqjs3aym

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8540

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8540/display/redirect>

Changes:


------------------------------------------
[...truncated 20.15 MB...]
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15916']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:31.693Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15962: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15952']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15962: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.7/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15952']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.155Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-22_11_41_51-9641974475994219065.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.206Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.206Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.206Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.206Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.206Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.207Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.208Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.208Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.225Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.226Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.231Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.244Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.264Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.265Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.268Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.271Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.496Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T19:56:41.552Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-22_11_41_51-9641974475994219065 is in state JOB_STATE_CANCELLING
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py37-xdist.xml> -
============== 1 failed, 29 passed, 3 skipped in 5276.94 seconds ===============

> Task :sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 8m 46s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/6wy4wttgon76m

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8539

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8539/display/redirect>

Changes:


------------------------------------------
[...truncated 20.13 MB...]
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15922']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.734Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-22_05_41_30-12589277474895029159.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.755Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.755Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.756Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.756Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.756Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.756Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.757Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.757Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.757Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.758Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.758Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.758Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.758Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.758Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.758Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.767Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.872Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.942Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:20.973Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T13:56:21.519Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15966: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15962']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15966: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15962']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-22_05_41_30-12589277474895029159 is in state JOB_STATE_CANCELLING
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py36-xdist.xml> -
============== 1 failed, 29 passed, 3 skipped in 5275.54 seconds ===============

> Task :sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 8m 27s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/tbt3axzgphmlq

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8538

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8538/display/redirect?page=changes>

Changes:

[noreply] [BEAM-13015] Create a multiplexer that sends Elements based upon


------------------------------------------
[...truncated 20.14 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15950']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T07:58:43.313Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15990: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15984']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15990: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15984']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-21_23_43_56-4050273967701864564 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5240.55 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 10m 23s
92 actionable tasks: 65 executed, 27 from cache

Publishing build scan...
https://gradle.com/s/avy2h5foz3rp6

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8537

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8537/display/redirect?page=changes>

Changes:

[noreply] [BEAM-13096] Double test timeout. (#15774)

[noreply] [BEAM-13019] Add `containsInAnyOrder` with matchers to the

[Daniel Oliveira] Avoiding read-only Go module cache in Gradle config.

[noreply] [BEAM-11758] Update basics page: Pipeline, PCollection, PTransform

[noreply] Test SetState addIfAbsent with no read (#15776)

[noreply] lazy creation of source splits for export-based ReadFromBigQuery

[noreply] [BEAM-11275] Support remote package download from remote filesystems in


------------------------------------------
[...truncated 20.11 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15912']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:20.087Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15956: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15952']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15956: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15952']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.957Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-21_17_48_33-15273175647328434869.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.979Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.979Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.980Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.980Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.980Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.980Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.980Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.980Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.980Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.981Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.981Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.981Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.981Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.981Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.981Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:23.982Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:24.105Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:24.153Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-22T02:03:24.176Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-21_17_48_33-15273175647328434869 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5255.94 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 15m 15s
92 actionable tasks: 69 executed, 23 from cache

Publishing build scan...
https://gradle.com/s/ni7ne3hqjf2ty

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8536

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8536/display/redirect?page=changes>

Changes:

[noreply] Merge pull request #15761 from [BEAM-13008] Create gradle tasks for the


------------------------------------------
[...truncated 20.11 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15908']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.662Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15948: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15938']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15948: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15938']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.745Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-21_11_41_35-12985572319043065067.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.765Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.765Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.765Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.765Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.766Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.766Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.766Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.766Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.766Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.766Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.766Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.766Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.766Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.766Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.767Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.767Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.861Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.912Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T19:56:25.933Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-21_11_41_35-12985572319043065067 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5265.31 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 8m 21s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/pl7e4are4vvea

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8535

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8535/display/redirect>

Changes:


------------------------------------------
[...truncated 20.12 MB...]
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16013']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:09.477Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -16055: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16049']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -16055: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 581, in do_instruction
                                                                                 getattr(request, request_type), request.instruction_id)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 996, in process_bundle
                                                                                 element.data)
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.6/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-16049']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.180Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-21_05_41_22-16423246416259603219.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.202Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.202Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.202Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.202Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.203Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.203Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.203Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.203Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.203Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.204Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.204Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.204Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.204Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.204Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.204Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.204Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.292Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.347Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T13:56:12.376Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-21_05_41_22-16423246416259603219 is in state JOB_STATE_CANCELLING
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py36-xdist.xml> -
============== 1 failed, 29 passed, 3 skipped in 5262.44 seconds ===============

> Task :sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 8m 10s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/e5cve3vavq77q

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8534

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8534/display/redirect?page=changes>

Changes:

[noreply] [BEAM-13082] Re-use dataWriter buffer. (#15762)


------------------------------------------
[...truncated 20.13 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15949']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T07:55:08.483Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15995: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15987']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15995: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15987']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-20_23_40_19-5159157138750928627 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5286.67 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 7m 30s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/5qmcbmklvsdgm

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_VR_Dataflow #8533

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/8533/display/redirect?page=changes>

Changes:

[noreply] Add -XX:+AlwaysActAsServerClassMachine to Java SDK container

[moritz] adhoc: Minor update to flink runner docs

[noreply] [BEAM-11087] Add default WindowMappingFn from Main to Side Input


------------------------------------------
[...truncated 20.12 MB...]
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15882']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:12.009Z: JOB_MESSAGE_ERROR: java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error received from SDK harness for instruction -15924: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15914']
                                                                             
                                                                                     java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
                                                                                     java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
                                                                                     org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:60)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.RegisterAndProcessBundleOperation.finish(RegisterAndProcessBundleOperation.java:338)
                                                                                     org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:103)
                                                                                     org.apache.beam.runners.dataflow.worker.fn.control.BeamFnMapTaskExecutor.execute(BeamFnMapTaskExecutor.java:127)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
                                                                                     org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
                                                                             Caused by: java.lang.RuntimeException: Error received from SDK harness for instruction -15924: Traceback (most recent call last):
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible
                                                                             
                                                                             During handling of the above exception, another exception occurred:
                                                                             
                                                                             Traceback (most recent call last):
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 267, in _execute
                                                                                 response = task()
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 340, in <lambda>
                                                                                 lambda: self.create_worker().do_instruction(request), request)
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 580, in do_instruction
                                                                                 return getattr(self, request_type)(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py", line 618, in process_bundle
                                                                                 bundle_processor.process_bundle(instruction_id))
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 995, in process_bundle
                                                                                 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/bundle_processor.py", line 221, in process_encoded
                                                                                 self.output(decoded_value)
                                                                               File "apache_beam/runners/worker/operations.py", line 347, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 349, in apache_beam.runners.worker.operations.Operation.output
                                                                               File "apache_beam/runners/worker/operations.py", line 216, in apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               File "apache_beam/runners/worker/operations.py", line 708, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/worker/operations.py", line 709, in apache_beam.runners.worker.operations.DoOperation.process
                                                                               File "apache_beam/runners/common.py", line 1200, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 1281, in apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               File "apache_beam/runners/common.py", line 1198, in apache_beam.runners.common.DoFnRunner.process
                                                                               File "apache_beam/runners/common.py", line 536, in apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               File "apache_beam/runners/common.py", line 1334, in apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               File "/usr/local/lib/python3.8/site-packages/apache_beam/transforms/combiners.py", line 383, in process
                                                                                 for element in reversed(bundle):
                                                                             TypeError: 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible [while running 'generatedPtransform-15914']
                                                                             
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
                                                                                     org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:255)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:765)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
                                                                                     org.apache.beam.vendor.grpc.v1p36p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
                                                                                     java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
                                                                                     java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
                                                                                     java.lang.Thread.run(Thread.java:748)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.947Z: JOB_MESSAGE_BASIC: Cancel request is committed for workflow job: 2021-10-20_17_42_23-12927791493402959923.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.977Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Create/Impulse+multiple-combines/assert-count-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-count-globally/Create/Map(decode)+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.978Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Create/Impulse+multiple-combines/assert-min-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-min-globally/Create/Map(decode)+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.978Z: JOB_MESSAGE_BASIC: Finished operation Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/ReadStream+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/MergeBuckets+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)+Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys+Create/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/KeyWithVoid+multiple-combines/largest-globally/Top(2)/ParDo(_TopPerBundle)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream+multiple-combines/min-globally/KeyWithVoid+multiple-combines/min-globally/CombinePerKey/GroupByKey/WriteStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.978Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.979Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Impulse+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/DoOnce/Map(decode)+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/InjectDefault+multiple-combines/assert-count-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-count-globally/ToVoidKey+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.980Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/GroupByKey/ReadStream+multiple-combines/largest-globally/Top(2)/GroupByKey/MergeBuckets+multiple-combines/largest-globally/Top(2)/ParDo(_MergeTopPerBundle)+multiple-combines/assert-largest-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-largest-globally/ToVoidKey+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.980Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/ReadStream+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/CombinePerKey/Combine+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/UnKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/MapToVoidKey0+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/count-globally/CombineGlobally(CountCombineFn)/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.980Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-count-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-count-globally/Group/RestoreTags+multiple-combines/assert-count-globally/Unkey+multiple-combines/assert-count-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.980Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/DoOnce/Impulse+multiple-combines/min-globally/DoOnce/FlatMap(<lambda at core.py:3222>)+multiple-combines/min-globally/DoOnce/Map(decode)+multiple-combines/min-globally/InjectDefault/InjectDefault+multiple-combines/assert-min-globally/WindowInto(WindowIntoFn)+multiple-combines/assert-min-globally/ToVoidKey+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/Tag[1]+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.982Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/CombinePerKey/GroupByKey/ReadStream+multiple-combines/min-globally/CombinePerKey/GroupByKey/MergeBuckets+multiple-combines/min-globally/CombinePerKey/Combine+multiple-combines/min-globally/UnKey+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/MapToVoidKey0+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.983Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/Values+multiple-combines/min-globally/InjectDefault/_DataflowIterableAsMultimapSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.983Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-min-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-min-globally/Group/RestoreTags+multiple-combines/assert-min-globally/Unkey+multiple-combines/assert-min-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.984Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Create/Impulse+multiple-combines/assert-largest-globally/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/assert-largest-globally/Create/Map(decode)+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/Tag[0]+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.984Z: JOB_MESSAGE_BASIC: Finished operation Create/Impulse+Create/FlatMap(<lambda at core.py:3222>)+Create/MaybeReshuffle/Reshuffle/AddRandomKeys+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)+Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.984Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/ReadStream+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/GroupByKey/MergeBuckets+multiple-combines/assert-largest-globally/Group/CoGroupByKeyImpl/MapTuple(collect_values)+multiple-combines/assert-largest-globally/Group/RestoreTags+multiple-combines/assert-largest-globally/Unkey+multiple-combines/assert-largest-globally/Match
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:13.984Z: JOB_MESSAGE_BASIC: Finished operation multiple-combines/largest-globally/Top(2)/Create/Impulse+multiple-combines/largest-globally/Top(2)/Create/FlatMap(<lambda at core.py:3222>)+multiple-combines/largest-globally/Top(2)/Create/Map(decode)+multiple-combines/largest-globally/Top(2)/GroupByKey/WriteStream
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:14.102Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:14.166Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-10-21T01:57:14.195Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-10-20_17_42_23-12927791493402959923 is in state JOB_STATE_CANCELLING
=============================== warnings summary ===============================
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/pytest_validatesRunnerStreamingTests-df-py38-xdist.xml> -
======== 1 failed, 29 passed, 3 skipped, 8 warnings in 5276.77 seconds =========

> Task :sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests FAILED

FAILURE: Build completed with 6 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 149

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerBatchTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

4: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

5: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

6: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_VR_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 181

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesRunnerStreamingTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 9m 25s
92 actionable tasks: 62 executed, 30 from cache

Publishing build scan...
https://gradle.com/s/efgeyniehnxie

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org