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 2020/12/14 12:47:16 UTC

Build failed in Jenkins: beam_PostCommit_Python_VR_Spark #4011

See <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/4011/display/redirect?page=changes>

Changes:

[Ismaël Mejía] [BEAM-9196] Update testcontainers to 1.15.1


------------------------------------------
[...truncated 530.64 KB...]
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
    self._reraise_augmented(exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
    self.output_processor.process_outputs(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
    self.consumer.process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
    delayed_application = self.dofn_runner.process(o)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
    self._reraise_augmented(exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
    raise_with_traceback(new_exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
    raise exc.with_traceback(traceback)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
    self._invoke_process_per_window(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
    self.process_method(*args_for_process),
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
    wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
    raise BeamAssertException(msg)
apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']

------------------------------ Captured log call -------------------------------
WARNING  root:environments.py:314 Make sure that locally built Python SDK docker image has Python 3.8 interpreter.
ERROR    apache_beam.runners.worker.sdk_worker:sdk_worker.py:293 Error processing instruction 1. Original traceback is
                                                                 Traceback (most recent call last):
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                                                     self.process_method(*args_for_process),
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                                                     wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                                                     raise BeamAssertException(msg)
                                                                 apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)]
                                                                 
                                                                 During handling of the above exception, another exception occurred:
                                                                 
                                                                 Traceback (most recent call last):
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 289, in _execute
                                                                     response = task()
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 362, in <lambda>
                                                                     lambda: self.create_worker().do_instruction(request), request)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 606, in do_instruction
                                                                     return getattr(self, request_type)(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 644, in process_bundle
                                                                     bundle_processor.process_bundle(instruction_id))
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 999, in process_bundle
                                                                     input_op_by_transform_id[element.transform_id].process_encoded(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 228, in process_encoded
                                                                     self.output(decoded_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 359, in output
                                                                     cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 883, in _invoke_process_per_window
                                                                     self.output_processor.process_outputs(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                                                     self.main_receivers.receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
                                                                     self.output_processor.process_outputs(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                                                     self.main_receivers.receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
                                                                     raise_with_traceback(new_exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
                                                                     raise exc.with_traceback(traceback)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                                                     self.process_method(*args_for_process),
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                                                     wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                                                     raise BeamAssertException(msg)
                                                                 apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']
                                                                 
ERROR    root:portable_runner.py:531 java.lang.RuntimeException: Error received from SDK harness for instruction 1: Traceback (most recent call last):
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                         self.process_method(*args_for_process),
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                         wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                         raise BeamAssertException(msg)
                                     apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)]
                                     
                                     During handling of the above exception, another exception occurred:
                                     
                                     Traceback (most recent call last):
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 289, in _execute
                                         response = task()
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 362, in <lambda>
                                         lambda: self.create_worker().do_instruction(request), request)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 606, in do_instruction
                                         return getattr(self, request_type)(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 644, in process_bundle
                                         bundle_processor.process_bundle(instruction_id))
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 999, in process_bundle
                                         input_op_by_transform_id[element.transform_id].process_encoded(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 228, in process_encoded
                                         self.output(decoded_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 359, in output
                                         cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 883, in _invoke_process_per_window
                                         self.output_processor.process_outputs(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                         self.main_receivers.receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
                                         self.output_processor.process_outputs(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                         self.main_receivers.receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
                                         raise_with_traceback(new_exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
                                         raise exc.with_traceback(traceback)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                         self.process_method(*args_for_process),
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                         wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                         raise BeamAssertException(msg)
                                     apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']
=============================== warnings summary ===============================
target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/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_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/pytest_spark-runner-test.xml> -
======== 1 failed, 33 passed, 14 skipped, 1 warnings in 631.85 seconds =========
ERROR: InvocationError for command <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/pytest_validates_runner.sh> spark-runner-test apache_beam/runners/portability/spark_runner_test.py '--spark_job_server_jar=<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/runners/spark/job-server/build/libs/beam-runners-spark-job-server-2.27.0-SNAPSHOT.jar> --environment_type=LOOPBACK' (exited with code 1)
spark-runner-test run-test-post: commands[0] | bash <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
ERROR:   spark-runner-test: commands failed

> Task :sdks:python:test-suites:portable:py38:sparkCompatibilityMatrixLOOPBACK FAILED

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py36:sparkCompatibilityMatrixLOOPBACK'.
> 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.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkCompatibilityMatrixLOOPBACK'.
> 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.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py38:sparkCompatibilityMatrixLOOPBACK'.
> 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.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 46m 47s
69 actionable tasks: 62 executed, 7 from cache

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

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_Python_VR_Spark #4017

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/4017/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_Python_VR_Spark #4016

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

Changes:


------------------------------------------
[...truncated 523.12 KB...]
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
    self._reraise_augmented(exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
    self.output_processor.process_outputs(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
    self.consumer.process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
    delayed_application = self.dofn_runner.process(o)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
    self._reraise_augmented(exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
    raise_with_traceback(new_exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
    raise exc.with_traceback(traceback)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
    self._invoke_process_per_window(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
    self.process_method(*args_for_process),
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
    wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
    raise BeamAssertException(msg)
apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']

------------------------------ Captured log call -------------------------------
WARNING  root:environments.py:314 Make sure that locally built Python SDK docker image has Python 3.8 interpreter.
ERROR    apache_beam.runners.worker.sdk_worker:sdk_worker.py:293 Error processing instruction 1. Original traceback is
                                                                 Traceback (most recent call last):
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                                                     self.process_method(*args_for_process),
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                                                     wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                                                     raise BeamAssertException(msg)
                                                                 apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)]
                                                                 
                                                                 During handling of the above exception, another exception occurred:
                                                                 
                                                                 Traceback (most recent call last):
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 289, in _execute
                                                                     response = task()
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 362, in <lambda>
                                                                     lambda: self.create_worker().do_instruction(request), request)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 606, in do_instruction
                                                                     return getattr(self, request_type)(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 644, in process_bundle
                                                                     bundle_processor.process_bundle(instruction_id))
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 999, in process_bundle
                                                                     input_op_by_transform_id[element.transform_id].process_encoded(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 228, in process_encoded
                                                                     self.output(decoded_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 359, in output
                                                                     cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 883, in _invoke_process_per_window
                                                                     self.output_processor.process_outputs(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                                                     self.main_receivers.receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
                                                                     self.output_processor.process_outputs(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                                                     self.main_receivers.receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
                                                                     raise_with_traceback(new_exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
                                                                     raise exc.with_traceback(traceback)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                                                     self.process_method(*args_for_process),
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                                                     wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                                                     raise BeamAssertException(msg)
                                                                 apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']
                                                                 
ERROR    root:portable_runner.py:531 java.lang.RuntimeException: Error received from SDK harness for instruction 1: Traceback (most recent call last):
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                         self.process_method(*args_for_process),
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                         wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                         raise BeamAssertException(msg)
                                     apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)]
                                     
                                     During handling of the above exception, another exception occurred:
                                     
                                     Traceback (most recent call last):
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 289, in _execute
                                         response = task()
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 362, in <lambda>
                                         lambda: self.create_worker().do_instruction(request), request)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 606, in do_instruction
                                         return getattr(self, request_type)(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 644, in process_bundle
                                         bundle_processor.process_bundle(instruction_id))
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 999, in process_bundle
                                         input_op_by_transform_id[element.transform_id].process_encoded(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 228, in process_encoded
                                         self.output(decoded_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 359, in output
                                         cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 883, in _invoke_process_per_window
                                         self.output_processor.process_outputs(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                         self.main_receivers.receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
                                         self.output_processor.process_outputs(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                         self.main_receivers.receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
                                         raise_with_traceback(new_exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
                                         raise exc.with_traceback(traceback)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                         self.process_method(*args_for_process),
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                         wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                         raise BeamAssertException(msg)
                                     apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']
=============================== warnings summary ===============================
target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/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_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/pytest_spark-runner-test.xml> -
======== 1 failed, 33 passed, 14 skipped, 1 warnings in 670.05 seconds =========
ERROR: InvocationError for command <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/pytest_validates_runner.sh> spark-runner-test apache_beam/runners/portability/spark_runner_test.py '--spark_job_server_jar=<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/runners/spark/job-server/build/libs/beam-runners-spark-job-server-2.27.0-SNAPSHOT.jar> --environment_type=LOOPBACK' (exited with code 1)
spark-runner-test run-test-post: commands[0] | bash <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
ERROR:   spark-runner-test: commands failed

> Task :sdks:python:test-suites:portable:py38:sparkCompatibilityMatrixLOOPBACK FAILED

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py36:sparkCompatibilityMatrixLOOPBACK'.
> 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.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkCompatibilityMatrixLOOPBACK'.
> 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.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py38:sparkCompatibilityMatrixLOOPBACK'.
> 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.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 37m 14s
69 actionable tasks: 44 executed, 25 from cache

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

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_Python_VR_Spark #4015

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

Changes:

[noreply] [BEAM-11230] Fix a bug with decoding repeated fields (#13544)


------------------------------------------
[...truncated 536.44 KB...]
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
    self._reraise_augmented(exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
    self.output_processor.process_outputs(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
    self.consumer.process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
    delayed_application = self.dofn_runner.process(o)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
    self._reraise_augmented(exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
    raise_with_traceback(new_exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
    raise exc.with_traceback(traceback)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
    self._invoke_process_per_window(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
    self.process_method(*args_for_process),
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
    wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
    raise BeamAssertException(msg)
apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']

------------------------------ Captured log call -------------------------------
WARNING  root:environments.py:314 Make sure that locally built Python SDK docker image has Python 3.8 interpreter.
ERROR    apache_beam.runners.worker.sdk_worker:sdk_worker.py:293 Error processing instruction 1. Original traceback is
                                                                 Traceback (most recent call last):
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                                                     self.process_method(*args_for_process),
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                                                     wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                                                     raise BeamAssertException(msg)
                                                                 apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)]
                                                                 
                                                                 During handling of the above exception, another exception occurred:
                                                                 
                                                                 Traceback (most recent call last):
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 289, in _execute
                                                                     response = task()
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 362, in <lambda>
                                                                     lambda: self.create_worker().do_instruction(request), request)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 606, in do_instruction
                                                                     return getattr(self, request_type)(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 644, in process_bundle
                                                                     bundle_processor.process_bundle(instruction_id))
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 999, in process_bundle
                                                                     input_op_by_transform_id[element.transform_id].process_encoded(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 228, in process_encoded
                                                                     self.output(decoded_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 359, in output
                                                                     cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 883, in _invoke_process_per_window
                                                                     self.output_processor.process_outputs(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                                                     self.main_receivers.receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
                                                                     self.output_processor.process_outputs(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                                                     self.main_receivers.receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
                                                                     raise_with_traceback(new_exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
                                                                     raise exc.with_traceback(traceback)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                                                     self.process_method(*args_for_process),
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                                                     wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                                                     raise BeamAssertException(msg)
                                                                 apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']
                                                                 
ERROR    root:portable_runner.py:531 java.lang.RuntimeException: Error received from SDK harness for instruction 1: Traceback (most recent call last):
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                         self.process_method(*args_for_process),
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                         wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                         raise BeamAssertException(msg)
                                     apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)]
                                     
                                     During handling of the above exception, another exception occurred:
                                     
                                     Traceback (most recent call last):
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 289, in _execute
                                         response = task()
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 362, in <lambda>
                                         lambda: self.create_worker().do_instruction(request), request)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 606, in do_instruction
                                         return getattr(self, request_type)(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 644, in process_bundle
                                         bundle_processor.process_bundle(instruction_id))
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 999, in process_bundle
                                         input_op_by_transform_id[element.transform_id].process_encoded(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 228, in process_encoded
                                         self.output(decoded_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 359, in output
                                         cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 883, in _invoke_process_per_window
                                         self.output_processor.process_outputs(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                         self.main_receivers.receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
                                         self.output_processor.process_outputs(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                         self.main_receivers.receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
                                         raise_with_traceback(new_exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
                                         raise exc.with_traceback(traceback)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                         self.process_method(*args_for_process),
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                         wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                         raise BeamAssertException(msg)
                                     apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']
=============================== warnings summary ===============================
target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/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_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/pytest_spark-runner-test.xml> -
======== 1 failed, 33 passed, 14 skipped, 1 warnings in 1239.12 seconds ========
ERROR: InvocationError for command <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/pytest_validates_runner.sh> spark-runner-test apache_beam/runners/portability/spark_runner_test.py '--spark_job_server_jar=<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/runners/spark/job-server/build/libs/beam-runners-spark-job-server-2.27.0-SNAPSHOT.jar> --environment_type=LOOPBACK' (exited with code 1)
spark-runner-test run-test-post: commands[0] | bash <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
ERROR:   spark-runner-test: commands failed

> Task :sdks:python:test-suites:portable:py38:sparkCompatibilityMatrixLOOPBACK FAILED

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py36:sparkCompatibilityMatrixLOOPBACK'.
> 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.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkCompatibilityMatrixLOOPBACK'.
> 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.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py38:sparkCompatibilityMatrixLOOPBACK'.
> 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.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 41m 22s
69 actionable tasks: 45 executed, 24 from cache

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

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_Python_VR_Spark #4014

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

Changes:

[noreply] [BEAM-11196] Fix `None` parent when fusing >2 stages (#13549)

[noreply] [BEAM-10641] Add Combiner Packing to Dataflow (#13455)


------------------------------------------
[...truncated 532.28 KB...]
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
    self._reraise_augmented(exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
    self.output_processor.process_outputs(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
    self.consumer.process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
    delayed_application = self.dofn_runner.process(o)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
    self._reraise_augmented(exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
    raise_with_traceback(new_exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
    raise exc.with_traceback(traceback)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
    self._invoke_process_per_window(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
    self.process_method(*args_for_process),
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
    wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
    raise BeamAssertException(msg)
apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']

------------------------------ Captured log call -------------------------------
WARNING  root:environments.py:314 Make sure that locally built Python SDK docker image has Python 3.8 interpreter.
ERROR    apache_beam.runners.worker.sdk_worker:sdk_worker.py:293 Error processing instruction 1. Original traceback is
                                                                 Traceback (most recent call last):
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                                                     self.process_method(*args_for_process),
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                                                     wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                                                     raise BeamAssertException(msg)
                                                                 apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)]
                                                                 
                                                                 During handling of the above exception, another exception occurred:
                                                                 
                                                                 Traceback (most recent call last):
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 289, in _execute
                                                                     response = task()
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 362, in <lambda>
                                                                     lambda: self.create_worker().do_instruction(request), request)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 606, in do_instruction
                                                                     return getattr(self, request_type)(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 644, in process_bundle
                                                                     bundle_processor.process_bundle(instruction_id))
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 999, in process_bundle
                                                                     input_op_by_transform_id[element.transform_id].process_encoded(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 228, in process_encoded
                                                                     self.output(decoded_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 359, in output
                                                                     cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 883, in _invoke_process_per_window
                                                                     self.output_processor.process_outputs(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                                                     self.main_receivers.receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
                                                                     self.output_processor.process_outputs(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                                                     self.main_receivers.receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
                                                                     raise_with_traceback(new_exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
                                                                     raise exc.with_traceback(traceback)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                                                     self.process_method(*args_for_process),
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                                                     wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                                                     raise BeamAssertException(msg)
                                                                 apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']
                                                                 
ERROR    root:portable_runner.py:531 java.lang.RuntimeException: Error received from SDK harness for instruction 1: Traceback (most recent call last):
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                         self.process_method(*args_for_process),
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                         wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                         raise BeamAssertException(msg)
                                     apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)]
                                     
                                     During handling of the above exception, another exception occurred:
                                     
                                     Traceback (most recent call last):
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 289, in _execute
                                         response = task()
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 362, in <lambda>
                                         lambda: self.create_worker().do_instruction(request), request)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 606, in do_instruction
                                         return getattr(self, request_type)(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 644, in process_bundle
                                         bundle_processor.process_bundle(instruction_id))
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 999, in process_bundle
                                         input_op_by_transform_id[element.transform_id].process_encoded(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 228, in process_encoded
                                         self.output(decoded_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 359, in output
                                         cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 883, in _invoke_process_per_window
                                         self.output_processor.process_outputs(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                         self.main_receivers.receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
                                         self.output_processor.process_outputs(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                         self.main_receivers.receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
                                         raise_with_traceback(new_exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
                                         raise exc.with_traceback(traceback)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                         self.process_method(*args_for_process),
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                         wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                         raise BeamAssertException(msg)
                                     apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']
=============================== warnings summary ===============================
target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/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_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/pytest_spark-runner-test.xml> -
======== 1 failed, 33 passed, 14 skipped, 1 warnings in 1019.11 seconds ========
ERROR: InvocationError for command <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/pytest_validates_runner.sh> spark-runner-test apache_beam/runners/portability/spark_runner_test.py '--spark_job_server_jar=<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/runners/spark/job-server/build/libs/beam-runners-spark-job-server-2.27.0-SNAPSHOT.jar> --environment_type=LOOPBACK' (exited with code 1)
spark-runner-test run-test-post: commands[0] | bash <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
ERROR:   spark-runner-test: commands failed

> Task :sdks:python:test-suites:portable:py38:sparkCompatibilityMatrixLOOPBACK FAILED

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py36:sparkCompatibilityMatrixLOOPBACK'.
> 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.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkCompatibilityMatrixLOOPBACK'.
> 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.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py38:sparkCompatibilityMatrixLOOPBACK'.
> 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.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 39m 39s
69 actionable tasks: 45 executed, 24 from cache

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

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_Python_VR_Spark #4013

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

Changes:

[noreply] Add output type hints for GroupIntoBatches. (#13493)

[noreply] [BEAM-11444] Python IO MongoDB: mask password in display_data uri and

[noreply] Change the output type of FHIR Search from String to JsonArray (#13516)

[noreply] [BEAM-11429] User-friendly names for packed combiners (#13535)

[noreply] [Beam-11438] start-build-env.sh improve for macOS (#13545)

[noreply] [BEAM-11065] Apache Beam pipeline example to ingest from Apache Kafka to


------------------------------------------
[...truncated 542.74 KB...]
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
    self._reraise_augmented(exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
    self.output_processor.process_outputs(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
    self.consumer.process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
    delayed_application = self.dofn_runner.process(o)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
    self._reraise_augmented(exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
    raise_with_traceback(new_exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
    raise exc.with_traceback(traceback)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
    self._invoke_process_per_window(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
    self.process_method(*args_for_process),
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
    wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
    raise BeamAssertException(msg)
apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']

------------------------------ Captured log call -------------------------------
WARNING  root:environments.py:314 Make sure that locally built Python SDK docker image has Python 3.8 interpreter.
ERROR    apache_beam.runners.worker.sdk_worker:sdk_worker.py:293 Error processing instruction 1. Original traceback is
                                                                 Traceback (most recent call last):
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                                                     self.process_method(*args_for_process),
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                                                     wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                                                     raise BeamAssertException(msg)
                                                                 apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)]
                                                                 
                                                                 During handling of the above exception, another exception occurred:
                                                                 
                                                                 Traceback (most recent call last):
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 289, in _execute
                                                                     response = task()
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 362, in <lambda>
                                                                     lambda: self.create_worker().do_instruction(request), request)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 606, in do_instruction
                                                                     return getattr(self, request_type)(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 644, in process_bundle
                                                                     bundle_processor.process_bundle(instruction_id))
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 999, in process_bundle
                                                                     input_op_by_transform_id[element.transform_id].process_encoded(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 228, in process_encoded
                                                                     self.output(decoded_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 359, in output
                                                                     cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 883, in _invoke_process_per_window
                                                                     self.output_processor.process_outputs(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                                                     self.main_receivers.receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
                                                                     self.output_processor.process_outputs(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                                                     self.main_receivers.receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
                                                                     raise_with_traceback(new_exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
                                                                     raise exc.with_traceback(traceback)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                                                     self.process_method(*args_for_process),
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                                                     wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                                                     raise BeamAssertException(msg)
                                                                 apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']
                                                                 
ERROR    root:portable_runner.py:531 java.lang.RuntimeException: Error received from SDK harness for instruction 1: Traceback (most recent call last):
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                         self.process_method(*args_for_process),
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                         wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                         raise BeamAssertException(msg)
                                     apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)]
                                     
                                     During handling of the above exception, another exception occurred:
                                     
                                     Traceback (most recent call last):
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 289, in _execute
                                         response = task()
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 362, in <lambda>
                                         lambda: self.create_worker().do_instruction(request), request)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 606, in do_instruction
                                         return getattr(self, request_type)(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 644, in process_bundle
                                         bundle_processor.process_bundle(instruction_id))
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 999, in process_bundle
                                         input_op_by_transform_id[element.transform_id].process_encoded(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 228, in process_encoded
                                         self.output(decoded_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 359, in output
                                         cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 883, in _invoke_process_per_window
                                         self.output_processor.process_outputs(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                         self.main_receivers.receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
                                         self.output_processor.process_outputs(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                         self.main_receivers.receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
                                         raise_with_traceback(new_exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
                                         raise exc.with_traceback(traceback)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                         self.process_method(*args_for_process),
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                         wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                         raise BeamAssertException(msg)
                                     apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']
=============================== warnings summary ===============================
target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/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_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/pytest_spark-runner-test.xml> -
======== 1 failed, 33 passed, 14 skipped, 1 warnings in 699.38 seconds =========
ERROR: InvocationError for command <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/pytest_validates_runner.sh> spark-runner-test apache_beam/runners/portability/spark_runner_test.py '--spark_job_server_jar=<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/runners/spark/job-server/build/libs/beam-runners-spark-job-server-2.27.0-SNAPSHOT.jar> --environment_type=LOOPBACK' (exited with code 1)
spark-runner-test run-test-post: commands[0] | bash <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
ERROR:   spark-runner-test: commands failed

> Task :sdks:python:test-suites:portable:py38:sparkCompatibilityMatrixLOOPBACK FAILED

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py36:sparkCompatibilityMatrixLOOPBACK'.
> 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.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkCompatibilityMatrixLOOPBACK'.
> 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.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py38:sparkCompatibilityMatrixLOOPBACK'.
> 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.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 37m 26s
69 actionable tasks: 45 executed, 24 from cache

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

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_Python_VR_Spark #4012

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

Changes:

[noreply] [BEAM-10124] Add missing announcement from CHANGES.md (#13537)

[noreply] [BEAM-11075] Enable Go load tests for Dataflow (#13529)

[noreply] [BEAM-11338] Addendum: handle private fields in generated thrift code


------------------------------------------
[...truncated 535.04 KB...]
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
    self._reraise_augmented(exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
    self.output_processor.process_outputs(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
    self.consumer.process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
    delayed_application = self.dofn_runner.process(o)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
    self._reraise_augmented(exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
    raise_with_traceback(new_exn)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
    raise exc.with_traceback(traceback)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
    self._invoke_process_per_window(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
    self.process_method(*args_for_process),
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
    wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
    raise BeamAssertException(msg)
apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']

------------------------------ Captured log call -------------------------------
WARNING  root:environments.py:314 Make sure that locally built Python SDK docker image has Python 3.8 interpreter.
ERROR    apache_beam.runners.worker.sdk_worker:sdk_worker.py:293 Error processing instruction 1. Original traceback is
                                                                 Traceback (most recent call last):
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                                                     self.process_method(*args_for_process),
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                                                     wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                                                     raise BeamAssertException(msg)
                                                                 apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)]
                                                                 
                                                                 During handling of the above exception, another exception occurred:
                                                                 
                                                                 Traceback (most recent call last):
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 289, in _execute
                                                                     response = task()
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 362, in <lambda>
                                                                     lambda: self.create_worker().do_instruction(request), request)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 606, in do_instruction
                                                                     return getattr(self, request_type)(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 644, in process_bundle
                                                                     bundle_processor.process_bundle(instruction_id))
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 999, in process_bundle
                                                                     input_op_by_transform_id[element.transform_id].process_encoded(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 228, in process_encoded
                                                                     self.output(decoded_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 359, in output
                                                                     cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 883, in _invoke_process_per_window
                                                                     self.output_processor.process_outputs(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                                                     self.main_receivers.receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
                                                                     self.output_processor.process_outputs(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                                                     self.main_receivers.receive(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                                                     self.consumer.process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                                                     delayed_application = self.dofn_runner.process(o)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                                                     self._reraise_augmented(exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
                                                                     raise_with_traceback(new_exn)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
                                                                     raise exc.with_traceback(traceback)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                                                     return self.do_fn_invoker.invoke_process(windowed_value)
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                                                     self._invoke_process_per_window(
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                                                     self.process_method(*args_for_process),
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                                                     wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                                                   File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                                                     raise BeamAssertException(msg)
                                                                 apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']
                                                                 
ERROR    root:portable_runner.py:531 java.lang.RuntimeException: Error received from SDK harness for instruction 1: Traceback (most recent call last):
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                         self.process_method(*args_for_process),
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                         wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                         raise BeamAssertException(msg)
                                     apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)]
                                     
                                     During handling of the above exception, another exception occurred:
                                     
                                     Traceback (most recent call last):
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 289, in _execute
                                         response = task()
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 362, in <lambda>
                                         lambda: self.create_worker().do_instruction(request), request)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 606, in do_instruction
                                         return getattr(self, request_type)(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 644, in process_bundle
                                         bundle_processor.process_bundle(instruction_id))
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 999, in process_bundle
                                         input_op_by_transform_id[element.transform_id].process_encoded(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 228, in process_encoded
                                         self.output(decoded_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 359, in output
                                         cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 883, in _invoke_process_per_window
                                         self.output_processor.process_outputs(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                         self.main_receivers.receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 587, in invoke_process
                                         self.output_processor.process_outputs(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1393, in process_outputs
                                         self.main_receivers.receive(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 221, in receive
                                         self.consumer.process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 719, in process
                                         delayed_application = self.dofn_runner.process(o)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1233, in process
                                         self._reraise_augmented(exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1313, in _reraise_augmented
                                         raise_with_traceback(new_exn)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/future/utils/__init__.py",> line 446, in raise_with_traceback
                                         raise exc.with_traceback(traceback)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1231, in process
                                         return self.do_fn_invoker.invoke_process(windowed_value)
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 760, in invoke_process
                                         self._invoke_process_per_window(
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 885, in _invoke_process_per_window
                                         self.process_method(*args_for_process),
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/transforms/core.py",> line 1680, in <lambda>
                                         wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
                                       File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/apache_beam/testing/util.py",> line 197, in _equal
                                         raise BeamAssertException(msg)
                                     apache_beam.testing.util.BeamAssertException: Failed assert: [('key1', 10), ('key2', 20), ('key3', 30)] == [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], unexpected elements [('', Timestamp(10)), ('', Timestamp(20)), ('', Timestamp(30))], missing elements [('key1', 10), ('key2', 20), ('key3', 30)] [while running 'assert_that/Match']
=============================== warnings summary ===============================
target/.tox-spark-runner-test/spark-runner-test/lib/python3.8/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/target/.tox-spark-runner-test/spark-runner-test/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_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/pytest_spark-runner-test.xml> -
======== 1 failed, 33 passed, 14 skipped, 1 warnings in 805.64 seconds =========
ERROR: InvocationError for command <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/pytest_validates_runner.sh> spark-runner-test apache_beam/runners/portability/spark_runner_test.py '--spark_job_server_jar=<https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/runners/spark/job-server/build/libs/beam-runners-spark-job-server-2.27.0-SNAPSHOT.jar> --environment_type=LOOPBACK' (exited with code 1)
spark-runner-test run-test-post: commands[0] | bash <https://ci-beam.apache.org/job/beam_PostCommit_Python_VR_Spark/ws/src/sdks/python/test-suites/portable/py38/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
ERROR:   spark-runner-test: commands failed

> Task :sdks:python:test-suites:portable:py38:sparkCompatibilityMatrixLOOPBACK FAILED

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py36:sparkCompatibilityMatrixLOOPBACK'.
> 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.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkCompatibilityMatrixLOOPBACK'.
> 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.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py38:sparkCompatibilityMatrixLOOPBACK'.
> 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.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 31m 59s
69 actionable tasks: 45 executed, 24 from cache

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

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