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/18 19:25:11 UTC

Build failed in Jenkins: beam_PreCommit_Python_Coverage_Cron #24

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

Changes:

[evanderwal] Add withDefaultHeaders to connection configuration for ElasticsearchIO

[evanderwal] Address PR comments, run spotless

[evanderwal] Fix copy/paste error in Javadoc, add example for usage of

[noreply] Add explicit error for PEP 585 type hints (#24986)

[noreply] Updated Python Container Dependencies (#25042)

[noreply] [ToB][Frontend] Display hints and solutions (#25020)

[noreply] upgrade clickhouse jdbc driver 0.3.2-patch10 (#24424)

[noreply] Added documentation for SingleStoreIO (#24377)

[noreply] Adding watermark support to DebeziumIO transform (#24757)

[John Casey] Moving to 2.46.0-SNAPSHOT on master branch.

[noreply] Fix error message (add proper spacing) (#25050)

[noreply] Remove trailing whitespace from blog to fix precommit (#25055)

[noreply] improve some errors from DoFnSignature (#25001)

[noreply] Bump torch (#24977)


------------------------------------------
[...truncated 381.58 KB...]
apache_beam/runners/interactive/display/pcoll_visualization_test.py::PCollectionVisualizationTest::test_dynamic_plotting_return_handle
apache_beam/runners/interactive/display/pcoll_visualization_test.py::PCollectionVisualizationTest::test_one_shot_visualization_not_return_handle
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/facets_overview/base_generic_feature_statistics_generator.py>:211: DeprecationWarning: np.asscalar(a) is deprecated since NumPy v1.16, use a.item() instead
    featstats.std_dev = np.asscalar(np.std(nums))

apache_beam/runners/interactive/display/pcoll_visualization_test.py::PCollectionVisualizationTest::test_dynamic_plotting_return_handle
apache_beam/runners/interactive/display/pcoll_visualization_test.py::PCollectionVisualizationTest::test_one_shot_visualization_not_return_handle
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/facets_overview/base_generic_feature_statistics_generator.py>:212: DeprecationWarning: np.asscalar(a) is deprecated since NumPy v1.16, use a.item() instead
    featstats.mean = np.asscalar(np.mean(nums))

apache_beam/runners/interactive/display/pcoll_visualization_test.py::PCollectionVisualizationTest::test_dynamic_plotting_return_handle
apache_beam/runners/interactive/display/pcoll_visualization_test.py::PCollectionVisualizationTest::test_one_shot_visualization_not_return_handle
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/facets_overview/base_generic_feature_statistics_generator.py>:213: DeprecationWarning: np.asscalar(a) is deprecated since NumPy v1.16, use a.item() instead
    featstats.min = np.asscalar(np.min(nums))

apache_beam/runners/interactive/display/pcoll_visualization_test.py::PCollectionVisualizationTest::test_dynamic_plotting_return_handle
apache_beam/runners/interactive/display/pcoll_visualization_test.py::PCollectionVisualizationTest::test_one_shot_visualization_not_return_handle
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/facets_overview/base_generic_feature_statistics_generator.py>:214: DeprecationWarning: np.asscalar(a) is deprecated since NumPy v1.16, use a.item() instead
    featstats.max = np.asscalar(np.max(nums))

apache_beam/runners/interactive/display/pcoll_visualization_test.py::PCollectionVisualizationTest::test_dynamic_plotting_return_handle
apache_beam/runners/interactive/display/pcoll_visualization_test.py::PCollectionVisualizationTest::test_one_shot_visualization_not_return_handle
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/facets_overview/base_generic_feature_statistics_generator.py>:215: DeprecationWarning: np.asscalar(a) is deprecated since NumPy v1.16, use a.item() instead
    featstats.median = np.asscalar(np.median(nums))

apache_beam/runners/interactive/display/pcoll_visualization_test.py: 20 warnings
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/facets_overview/base_generic_feature_statistics_generator.py>:235: DeprecationWarning: np.asscalar(a) is deprecated since NumPy v1.16, use a.item() instead
    sample_count=np.asscalar(counts[bucket_count]))

apache_beam/runners/portability/portable_runner_test.py::PortableRunnerTestWithLocalDocker::test_sdf_with_check_done_failed
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread Thread-1546
  
  Traceback (most recent call last):
    File "/usr/lib/python3.8/threading.py", line 932, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.8/threading.py", line 870, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/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_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/runners/portability/local_job_service.py",> line 318, in _invoke_runner
      return fn_runner.FnApiRunner(
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/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_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/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_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/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_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/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_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/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_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/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_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/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_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/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_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/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_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 227, in process_encoded
      self.output(decoded_value)
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 528, in output
      _cast_to_receiver(self.receivers[output_index]).receive(windowed_value)
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 240, in receive
      self.consumer.process(windowed_value)
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/runners/worker/operations.py",> line 1030, in process
      delayed_applications = self.dofn_runner.process_with_sized_restriction(
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 1432, in process_with_sized_restriction
      return self.do_fn_invoker.invoke_process(
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 817, in invoke_process
      residual = self._invoke_process_per_window(
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/runners/common.py",> line 988, in _invoke_process_per_window
      self.threadsafe_restriction_tracker.check_done()
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/runners/sdf_utils.py",> line 111, in check_done
      return self._restriction_tracker.check_done()
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/io/restriction_trackers.py",> line 93, in check_done
      raise ValueError(
  ValueError: OffsetRestrictionTracker is not done since work in range [0, 6) has not been claimed.
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/runners/interactive/sql/utils_test.py::OptionsFormTest::test_dataflow_options_form
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/jupyter_client/connect.py>:28: DeprecationWarning: Jupyter is migrating its paths to use standard platformdirs
  given by the platformdirs library.  To remove this warning and
  see the appropriate new directories, set the environment variable
  `JUPYTER_PLATFORM_DIRS=1` and then run `jupyter --paths`.
  The use of platformdirs will be the default in `jupyter_core` v6
    from jupyter_core.paths import jupyter_data_dir, jupyter_runtime_dir, secure_write

apache_beam/runners/interactive/sql/utils_test.py::OptionsFormTest::test_dataflow_options_form
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/jupyter_client/session.py>:37: DeprecationWarning: zmq.eventloop.ioloop is deprecated in pyzmq 17. pyzmq now works with default tornado and asyncio eventloops.
    from zmq.eventloop.ioloop import IOLoop

apache_beam/transforms/combiners_test.py::CombineTest::test_combining_with_accumulation_mode_and_fanout
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/hamcrest/library/collection/issequence_containinginorder.py>:95: DeprecationWarning: deprecated - use contains_exactly(*items)
    warnings.warn("deprecated - use contains_exactly(*items)", DeprecationWarning)

apache_beam/transforms/ptransform_test.py::PTransformTypeCheckTestCase::test_to_list_runtime_check_satisfied
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread fn_api_status_handler
  
  Traceback (most recent call last):
    File "/usr/lib/python3.8/threading.py", line 932, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.8/threading.py", line 870, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/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_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/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_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/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:45095 {created_time:"2023-01-18T19:13:11.418556431+00:00", grpc_status:14, grpc_message:"Cancelling all calls"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/transforms/util_test.py::GroupIntoBatchesTest::test_buffering_timer_in_fixed_window_streaming
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/transforms/util_test.py>:928: FutureWarning: GroupIntoBatches is experimental.
    | util.GroupIntoBatches(

apache_beam/transforms/util_test.py::GroupIntoBatchesTest::test_buffering_timer_in_global_window_streaming
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/transforms/util_test.py>:982: FutureWarning: GroupIntoBatches is experimental.
    | util.GroupIntoBatches(

apache_beam/transforms/util_test.py::GroupIntoBatchesTest::test_in_global_window
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/transforms/util_test.py>:878: FutureWarning: GroupIntoBatches is experimental.
    | util.GroupIntoBatches(GroupIntoBatchesTest.BATCH_SIZE)

apache_beam/transforms/util_test.py::GroupIntoBatchesTest::test_runner_api
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/transforms/util_test.py>:1037: FutureWarning: GroupIntoBatches is experimental.
    util.GroupIntoBatches(batch_size, duration),

apache_beam/transforms/util_test.py::GroupIntoBatchesTest::test_runner_api
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/transforms/util_test.py>:1040: FutureWarning: GroupIntoBatches is experimental.
    util.GroupIntoBatches(batch_size),

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/pytest_py38-cloudcoverage.xml> -

---------- coverage: platform linux, python 3.8.10-final-0 -----------
Coverage XML written to file coverage.xml

=========================== short test summary info ============================
FAILED apache_beam/runners/portability/portable_runner_test.py::PortableRunnerTestWithSubprocesses::test_pardo_state_with_custom_key_coder - grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.DEADLINE_EXCEEDED
	details = "Deadline Exceeded"
	debug_error_string = "UNKNOWN:Error received from peer ipv4:127.0.0.1:52871 {grpc_message:"Deadline Exceeded", grpc_status:4, created_time:"2023-01-18T19:16:13.241153086+00:00"}"
>
=== 1 failed, 5965 passed, 758 skipped, 1428 warnings in 1281.50s (0:21:21) ====
============================= test session starts ==============================
platform linux -- Python 3.8.10, pytest-7.2.1, pluggy-1.0.0
cachedir: target/.tox-py38-cloudcoverage/py38-cloudcoverage/.pytest_cache
rootdir: <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python,> configfile: pytest.ini
plugins: xdist-2.5.0, timeout-2.1.0, cov-3.0.0, forked-1.4.0, requests-mock-1.10.0, hypothesis-6.62.1
timeout: 600.0s
timeout method: signal
timeout func_only: False
collected 6801 items / 6718 deselected / 6 skipped / 83 selected

apache_beam/coders/fast_coders_test.py ................................. [ 39%]
...                                                                      [ 43%]
apache_beam/coders/slow_coders_test.py ................................. [ 83%]
...                                                                      [ 86%]
apache_beam/examples/complete/autocomplete_it_test.py s                  [ 87%]
apache_beam/examples/complete/estimate_pi_it_test.py s                   [ 89%]
apache_beam/examples/complete/top_wikipedia_sessions_it_test.py s        [ 90%]
apache_beam/examples/complete/game/hourly_team_score_it_test.py s        [ 91%]
apache_beam/examples/complete/game/user_score_it_test.py s               [ 92%]
apache_beam/examples/cookbook/bigquery_side_input_it_test.py s           [ 93%]
apache_beam/examples/cookbook/coders_it_test.py s                        [ 95%]
apache_beam/runners/dataflow/dataflow_exercise_streaming_metrics_pipeline_test.py s [ 96%]
                                                                         [ 96%]
apache_beam/runners/portability/stager_test.py ..                        [ 98%]
apache_beam/transforms/userstate_test.py .                               [100%]

=============================== warnings summary ===============================
target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/pytest_cov/plugin.py:256
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/pytest_cov/plugin.py>:256: PytestDeprecationWarning: The hookimpl CovPlugin.pytest_configure_node uses old-style configuration options (marks or attributes).
  Please use the pytest.hookimpl(optionalhook=True) decorator instead
   to configure the hooks.
   See https://docs.pytest.org/en/latest/deprecations.html#configuring-hook-specs-impls-using-markers
    def pytest_configure_node(self, node):

target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/pytest_cov/plugin.py:265
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/pytest_cov/plugin.py>:265: PytestDeprecationWarning: The hookimpl CovPlugin.pytest_testnodedown uses old-style configuration options (marks or attributes).
  Please use the pytest.hookimpl(optionalhook=True) decorator instead
   to configure the hooks.
   See https://docs.pytest.org/en/latest/deprecations.html#configuring-hook-specs-impls-using-markers
    def pytest_testnodedown(self, node, error):

target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/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

target/.tox-py38-cloudcoverage/py38-cloudcoverage/lib/python3.8/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/target/.tox-py38-cloudcoverage/py38-cloudcoverage/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):

apache_beam/typehints/pandas_type_compatibility_test.py:67
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:67: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    }).set_index(pd.Int64Index(range(123, 223), name='an_index')),

apache_beam/typehints/pandas_type_compatibility_test.py:90
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:90: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    pd.Int64Index(range(123, 223), name='an_index'),

apache_beam/typehints/pandas_type_compatibility_test.py:91
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:91: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    pd.Int64Index(range(475, 575), name='another_index'),

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/pytest_py38-cloudcoverage_no_xdist.xml> -

---------- coverage: platform linux, python 3.8.10-final-0 -----------
Coverage XML written to file coverage.xml

==== 75 passed, 14 skipped, 6718 deselected, 7 warnings in 89.28s (0:01:29) ====
ERROR: InvocationError for command <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/scripts/run_pytest.sh> py38-cloudcoverage '' '--cov-report=xml --cov=. --cov-append' (exited with code 1)
py38-cloudcoverage run-test-post: commands[0] | bash <https://ci-beam.apache.org/job/beam_PreCommit_Python_Coverage_Cron/ws/src/sdks/python/test-suites/tox/py38/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
ERROR:   py38-cloudcoverage: commands failed

> Task :sdks:python:test-suites:tox:py38:testPy38CloudCoverage FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:py38:testPy38CloudCoverage'.
> 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 26m 49s
14 actionable tasks: 8 executed, 4 from cache, 2 up-to-date

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

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_Coverage_Cron #25

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


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