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 2023/01/27 10:37:56 UTC

Build failed in Jenkins: beam_PreCommit_Python_Runners_Cron #91

See <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/91/display/redirect>

Changes:


------------------------------------------
[...truncated 1.30 MB...]
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/portability/local_job_service.py",> line 296, in _run_job
      self.result = self._invoke_runner()
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/portability/local_job_service.py",> line 319, in _invoke_runner
      provision_info=self._provision_info).run_via_runner_api(
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py",> line 222, in run_via_runner_api
      return self.run_stages(stage_context, stages)
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py",> line 453, in run_stages
      bundle_results = self._execute_bundle(
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py",> line 781, in _execute_bundle
      self._run_bundle(
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py",> line 1010, in _run_bundle
      result, splits = bundle_manager.process_bundle(
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py",> line 1346, in process_bundle
      result_future = self._worker_handler.control_conn.push(process_bundle_req)
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/worker_handlers.py",> line 379, in push
      response = self.worker.do_instruction(request)
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 596, in do_instruction
      return getattr(self, request_type)(
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 634, in process_bundle
      bundle_processor.process_bundle(instruction_id))
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 1003, in process_bundle
      input_op_by_transform_id[element.transform_id].process_encoded(
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 227, in process_encoded
      self.output(decoded_value)
    File "apache_beam/runners/worker/operations.py", line 526, in apache_beam.runners.worker.operations.Operation.output
      def output(self, windowed_value, output_index=0):
    File "apache_beam/runners/worker/operations.py", line 528, in apache_beam.runners.worker.operations.Operation.output
      _cast_to_receiver(self.receivers[output_index]).receive(windowed_value)
    File "apache_beam/runners/worker/operations.py", line 237, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
      def receive(self, windowed_value):
    File "apache_beam/runners/worker/operations.py", line 240, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
      self.consumer.process(windowed_value)
    File "apache_beam/runners/worker/operations.py", line 907, in apache_beam.runners.worker.operations.DoOperation.process
      with self.scoped_process_state:
    File "apache_beam/runners/worker/operations.py", line 908, in apache_beam.runners.worker.operations.DoOperation.process
      delayed_applications = self.dofn_runner.process(o)
    File "apache_beam/runners/common.py", line 1419, in apache_beam.runners.common.DoFnRunner.process
      self._reraise_augmented(exn)
    File "apache_beam/runners/common.py", line 1491, in apache_beam.runners.common.DoFnRunner._reraise_augmented
      raise exn
    File "apache_beam/runners/common.py", line 1417, in apache_beam.runners.common.DoFnRunner.process
      return self.do_fn_invoker.invoke_process(windowed_value)
    File "apache_beam/runners/common.py", line 623, in apache_beam.runners.common.SimpleInvoker.invoke_process
      self.output_handler.handle_process_outputs(
    File "apache_beam/runners/common.py", line 1581, in apache_beam.runners.common._OutputHandler.handle_process_outputs
      self._write_value_to_tag(tag, windowed_value, watermark_estimator)
    File "apache_beam/runners/common.py", line 1694, in apache_beam.runners.common._OutputHandler._write_value_to_tag
      self.main_receivers.receive(windowed_value)
    File "apache_beam/runners/worker/operations.py", line 240, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
      self.consumer.process(windowed_value)
    File "apache_beam/runners/worker/operations.py", line 907, in apache_beam.runners.worker.operations.DoOperation.process
      with self.scoped_process_state:
    File "apache_beam/runners/worker/operations.py", line 908, in apache_beam.runners.worker.operations.DoOperation.process
      delayed_applications = self.dofn_runner.process(o)
    File "apache_beam/runners/common.py", line 1419, in apache_beam.runners.common.DoFnRunner.process
      self._reraise_augmented(exn)
    File "apache_beam/runners/common.py", line 1491, in apache_beam.runners.common.DoFnRunner._reraise_augmented
      raise exn
    File "apache_beam/runners/common.py", line 1417, in apache_beam.runners.common.DoFnRunner.process
      return self.do_fn_invoker.invoke_process(windowed_value)
    File "apache_beam/runners/common.py", line 623, in apache_beam.runners.common.SimpleInvoker.invoke_process
      self.output_handler.handle_process_outputs(
    File "apache_beam/runners/common.py", line 1581, in apache_beam.runners.common._OutputHandler.handle_process_outputs
      self._write_value_to_tag(tag, windowed_value, watermark_estimator)
    File "apache_beam/runners/common.py", line 1694, in apache_beam.runners.common._OutputHandler._write_value_to_tag
      self.main_receivers.receive(windowed_value)
    File "apache_beam/runners/worker/operations.py", line 240, in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
      self.consumer.process(windowed_value)
    File "apache_beam/runners/worker/operations.py", line 907, in apache_beam.runners.worker.operations.DoOperation.process
      with self.scoped_process_state:
    File "apache_beam/runners/worker/operations.py", line 908, in apache_beam.runners.worker.operations.DoOperation.process
      delayed_applications = self.dofn_runner.process(o)
    File "apache_beam/runners/common.py", line 1419, in apache_beam.runners.common.DoFnRunner.process
      self._reraise_augmented(exn)
    File "apache_beam/runners/common.py", line 1507, in apache_beam.runners.common.DoFnRunner._reraise_augmented
      raise new_exn.with_traceback(tb)
    File "apache_beam/runners/common.py", line 1417, in apache_beam.runners.common.DoFnRunner.process
      return self.do_fn_invoker.invoke_process(windowed_value)
    File "apache_beam/runners/common.py", line 624, in apache_beam.runners.common.SimpleInvoker.invoke_process
      windowed_value, self.process_method(windowed_value.value))
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/transforms/core.py",> line -1, in <lambda>
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 1160, in first
      self.assertIn('StageC', message)
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line 1228, in second
      def test_callbacks_with_exception(self):
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py",> line -1, in third
  ValueError: This error is expected and does not indicate a test failure. [while running 'Map(first)']
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/runners/portability/fn_api_runner/fn_runner_test.py::FnApiRunnerTestWithGrpcAndMultiWorkers::test_flatten
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-cython/py310-cython/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/worker/data_plane.py",> line 671, in <lambda>
      target=lambda: self._read_inputs(elements_iterator),
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/worker/data_plane.py",> line 654, in _read_inputs
      for elements in elements_iterator:
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-cython/py310-cython/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-cython/py310-cython/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.UNAVAILABLE
  	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:39949: Failed to connect to remote host: Connection refused"
  	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:39949: Failed to connect to remote host: Connection refused {grpc_status:14, created_time:"2023-01-27T10:36:38.176363578+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/runners/worker/worker_status_test.py::FnApiWorkerStatusHandlerTest::test_generate_error
apache_beam/runners/worker/worker_status_test.py::FnApiWorkerStatusHandlerTest::test_send_status_response
apache_beam/runners/worker/worker_status_test.py::FnApiWorkerStatusHandlerTest::test_send_status_response
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/apache_beam/runners/worker/worker_status_test.py>:48: DeprecationWarning: notifyAll() is deprecated, use notify_all() instead
    self.finished.notifyAll()

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cython.xml> -
========== 1165 passed, 768 skipped, 41 warnings in 287.33s (0:04:47) ==========

> Task :sdks:python:test-suites:tox:py37:testPy37Cython
.....s............s......s...s..................s.s....s..... [ 93%]
..............ss...s...s................................................ [ 96%]
......................................................Exception in thread fn_api_status_handler:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/runners/worker/worker_status.py",> line 177, in <lambda>
    target=lambda: self._serve(), name='fn_api_status_handler')
  File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/apache_beam/runners/worker/worker_status.py",> line 198, in _serve
    for request in self._status_stub.WorkerStatus(self._get_responses()):
  File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/target/.tox-py37-cython/py37-cython/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/target/.tox-py37-cython/py37-cython/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "Cancelling all calls"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40943 {grpc_message:"Cancelling all calls", grpc_status:14, created_time:"2023-01-27T10:37:44.546230065+00:00"}"
>

.....              [100%]
=============================== warnings summary ===============================
target/.tox-py37-cython/py37-cython/lib/python3.7/site-packages/hdfs/config.py:15
target/.tox-py37-cython/py37-cython/lib/python3.7/site-packages/hdfs/config.py:15
target/.tox-py37-cython/py37-cython/lib/python3.7/site-packages/hdfs/config.py:15
target/.tox-py37-cython/py37-cython/lib/python3.7/site-packages/hdfs/config.py:15
target/.tox-py37-cython/py37-cython/lib/python3.7/site-packages/hdfs/config.py:15
target/.tox-py37-cython/py37-cython/lib/python3.7/site-packages/hdfs/config.py:15
target/.tox-py37-cython/py37-cython/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/target/.tox-py37-cython/py37-cython/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/pytest_py37-cython.xml> -
========== 1165 passed, 768 skipped, 7 warnings in 292.01s (0:04:52) ===========

> Task :sdks:python:test-suites:tox:py310:testPy310Cython
============================= test session starts ==============================
platform linux -- Python 3.10.2, pytest-7.2.1, pluggy-1.0.0
cachedir: target/.tox-py310-cython/py310-cython/.pytest_cache
rootdir: <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python,> configfile: pytest.ini
plugins: hypothesis-6.65.2, xdist-2.5.0, timeout-2.1.0, forked-1.4.0, requests-mock-1.10.0
timeout: 600.0s
timeout method: signal
timeout func_only: False
collected 1935 items / 1932 deselected / 1 skipped / 3 selected

apache_beam/runners/dataflow/dataflow_exercise_streaming_metrics_pipeline_test.py s [ 33%]
                                                                         [ 33%]
apache_beam/runners/portability/stager_test.py ..                        [100%]

=============================== warnings summary ===============================
target/.tox-py310-cython/py310-cython/lib/python3.10/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-cython/py310-cython/lib/python3.10/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib and slated for removal in Python 3.12; see the module's documentation for alternative uses
    from imp import load_source

target/.tox-py310-cython/py310-cython/lib/python3.10/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/target/.tox-py310-cython/py310-cython/lib/python3.10/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/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cython_no_xdist.xml> -
========== 2 passed, 2 skipped, 1932 deselected, 2 warnings in 1.82s ===========
py310-cython run-test-post: commands[0] | bash <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py310/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
  py310-cython: commands succeeded
  congratulations :)

> Task :sdks:python:test-suites:tox:py37:testPy37Cython
============================= test session starts ==============================
platform linux -- Python 3.7.12, pytest-7.2.1, pluggy-1.0.0
cachedir: target/.tox-py37-cython/py37-cython/.pytest_cache
rootdir: <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python,> configfile: pytest.ini
plugins: hypothesis-6.65.2, xdist-2.5.0, timeout-2.1.0, forked-1.4.0, requests-mock-1.10.0
timeout: 600.0s
timeout method: signal
timeout func_only: False
collected 1935 items / 1932 deselected / 1 skipped / 3 selected

apache_beam/runners/dataflow/dataflow_exercise_streaming_metrics_pipeline_test.py s [ 33%]
                                                                         [ 33%]
apache_beam/runners/portability/stager_test.py ..                        [100%]

=============================== warnings summary ===============================
target/.tox-py37-cython/py37-cython/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/target/.tox-py37-cython/py37-cython/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/pytest_py37-cython_no_xdist.xml> -
=========== 2 passed, 2 skipped, 1932 deselected, 1 warning in 1.87s ===========
py37-cython run-test-post: commands[0] | bash <https://ci-beam.apache.org/job/beam_PreCommit_Python_Runners_Cron/ws/src/sdks/python/test-suites/tox/py37/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
  py37-cython: commands succeeded
  congratulations :)

> Task :sdks:python:test-suites:tox:py37:preCommitPy37

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:py310:testPy310Cloud'.
> 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.

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

BUILD FAILED in 22m 27s
23 actionable tasks: 17 executed, 4 from cache, 2 up-to-date

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

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_PreCommit_Python_Runners_Cron #92

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


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