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/04/01 18:53:58 UTC

Build failed in Jenkins: beam_PreCommit_Python_Cron #2582

See <https://builds.apache.org/job/beam_PreCommit_Python_Cron/2582/display/redirect?page=changes>

Changes:

[zyichi] Update BigQuery source in bigquery_tornadoes example

[rohde.samuel] Add dependency comment in streaming cache

[ehudm] [BEAM-1894] Remove obsolete EagerRunner test


------------------------------------------
[...truncated 478.02 KB...]
  File "/usr/lib/python3.6/threading.py", line 864, in run
    self._target(*self._args, **self._kwargs)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/local_job_service.py", line 265, in _run_job
    self._pipeline_proto)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 190, in run_via_runner_api
    return self.run_stages(stage_context, stages)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 337, in run_stages
    bundle_context_manager,
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 552, in _run_stage
    result, splits = bundle_manager.process_bundle(data_input, data_output)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 1008, in process_bundle
    for result, split_result in executor.map(execute, part_inputs):
  File "/usr/lib/python3.6/concurrent/futures/_base.py", line 586, in result_iterator
    yield fs.pop().result()
  File "/usr/lib/python3.6/concurrent/futures/_base.py", line 432, in result
    return self.__get_result()
  File "/usr/lib/python3.6/concurrent/futures/_base.py", line 384, in __get_result
    raise self._exception
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/utils/thread_pool_executor.py", line 44, in run
    self._future.set_result(self._fn(*self._fn_args, **self._fn_kwargs))
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 1005, in execute
    return bundle_manager.process_bundle(part_map, expected_outputs)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 919, in process_bundle
    result_future = self._worker_handler.control_conn.push(process_bundle_req)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/worker_handlers.py", line 340, in push
    response = self.worker.do_instruction(request)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py", line 416, in do_instruction
    getattr(request, request_type), request.instruction_id)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py", line 451, in process_bundle
    bundle_processor.process_bundle(instruction_id))
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py", line 842, in process_bundle
    input_op_by_transform_id[data.transform_id].process_encoded(data.data)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py", line 217, in process_encoded
    self.output(decoded_value)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 333, in output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 196, in receive
    self.consumer.process(windowed_value)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 780, in process
    delayed_application = self.dofn_runner.process_with_sized_restriction(o)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 968, in process_with_sized_restriction
    watermark_estimator=watermark_estimator)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 710, in invoke_process
    windowed_value, additional_args, additional_kwargs)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 812, in _invoke_process_per_window
    self.threadsafe_restriction_tracker.check_done()
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/sdf_utils.py", line 115, in check_done
    return self._restriction_tracker.check_done()
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/io/restriction_trackers.py", line 101, in check_done
    self._range.stop))
ValueError: OffsetRestrictionTracker is not done since work in range [0, 6) has not been claimed.

..................s.............s.......Exception in thread Thread-1255:
Traceback (most recent call last):
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 954, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 725, in invoke_process
    windowed_value, additional_args, additional_kwargs)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 807, in _invoke_process_per_window
    self.process_method(*args_for_process),
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/transforms/core.py", line 1447, in <lambda>
    wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/testing/util.py", line 202, in _equal
    raise BeamAssertException(msg)
apache_beam.testing.util.BeamAssertException: Failed assert: ['a'] == ['a', 'b'], unexpected elements ['b']

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "/usr/lib/python3.6/threading.py", line 916, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.6/threading.py", line 864, in run
    self._target(*self._args, **self._kwargs)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/local_job_service.py", line 265, in _run_job
    self._pipeline_proto)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 190, in run_via_runner_api
    return self.run_stages(stage_context, stages)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 337, in run_stages
    bundle_context_manager,
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 552, in _run_stage
    result, splits = bundle_manager.process_bundle(data_input, data_output)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 1008, in process_bundle
    for result, split_result in executor.map(execute, part_inputs):
  File "/usr/lib/python3.6/concurrent/futures/_base.py", line 586, in result_iterator
    yield fs.pop().result()
  File "/usr/lib/python3.6/concurrent/futures/_base.py", line 432, in result
    return self.__get_result()
  File "/usr/lib/python3.6/concurrent/futures/_base.py", line 384, in __get_result
    raise self._exception
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/utils/thread_pool_executor.py", line 44, in run
    self._future.set_result(self._fn(*self._fn_args, **self._fn_kwargs))
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 1005, in execute
    return bundle_manager.process_bundle(part_map, expected_outputs)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner.py", line 919, in process_bundle
    result_future = self._worker_handler.control_conn.push(process_bundle_req)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/worker_handlers.py", line 340, in push
    response = self.worker.do_instruction(request)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py", line 416, in do_instruction
    getattr(request, request_type), request.instruction_id)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/sdk_worker.py", line 451, in process_bundle
    bundle_processor.process_bundle(instruction_id))
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py", line 842, in process_bundle
    input_op_by_transform_id[data.transform_id].process_encoded(data.data)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/bundle_processor.py", line 217, in process_encoded
    self.output(decoded_value)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 333, in output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 196, in receive
    self.consumer.process(windowed_value)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 689, in process
    delayed_application = self.dofn_runner.process(o)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 956, in process
    self._reraise_augmented(exn)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 954, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 725, in invoke_process
    windowed_value, additional_args, additional_kwargs)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 808, in _invoke_process_per_window
    self.threadsafe_watermark_estimator)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 1114, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 196, in receive
    self.consumer.process(windowed_value)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 689, in process
    delayed_application = self.dofn_runner.process(o)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 956, in process
    self._reraise_augmented(exn)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 954, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 552, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 1114, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 196, in receive
    self.consumer.process(windowed_value)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/worker/operations.py", line 689, in process
    delayed_application = self.dofn_runner.process(o)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 956, in process
    self._reraise_augmented(exn)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 1037, in _reraise_augmented
    raise_with_traceback(new_exn)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/target/.tox-py36-cloud/py36-cloud/lib/python3.6/site-packages/future/utils/__init__.py", line 419, in raise_with_traceback
    raise exc.with_traceback(traceback)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 954, in process
    return self.do_fn_invoker.invoke_process(windowed_value)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 725, in invoke_process
    windowed_value, additional_args, additional_kwargs)
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/runners/common.py", line 807, in _invoke_process_per_window
    self.process_method(*args_for_process),
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/transforms/core.py", line 1447, in <lambda>
    wrapper = lambda x, *args, **kwargs: [fn(x, *args, **kwargs)]
  File "/home/jenkins/jenkins-slave/workspace/beam_PreCommit_Python_Cron/src/sdks/python/test-suites/tox/py36/build/srcs/sdks/python/apache_beam/testing/util.py", line 202, in _equal
    raise BeamAssertException(msg)
apache_beam.testing.util.BeamAssertException: Failed assert: ['a'] == ['a', 'b'], unexpected elements ['b'] [while running 'assert_that/Match']

..........
> Task :sdks:python:test-suites:dataflow:py37:preCommitIT
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:31.687Z: JOB_MESSAGE_DETAILED: Checking permissions granted to controller Service Account.

> Task :sdks:python:test-suites:tox:py2:testPy2Cloud
...s.s..................................................ss......... [ 42%]
..............s........
> Task :sdks:python:test-suites:dataflow:py2:preCommitIT
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:27.458Z: JOB_MESSAGE_BASIC: Finished operation group/Read+group/GroupByWindow+count+format+write/Write/WriteImpl/WriteBundles/WriteBundles+write/Write/WriteImpl/Pair+write/Write/WriteImpl/WindowInto(WindowIntoFn)+write/Write/WriteImpl/GroupByKey/Reify+write/Write/WriteImpl/GroupByKey/Write
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:27.542Z: JOB_MESSAGE_BASIC: Executing operation write/Write/WriteImpl/GroupByKey/Close
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:27.606Z: JOB_MESSAGE_BASIC: Finished operation write/Write/WriteImpl/GroupByKey/Close
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:27.677Z: JOB_MESSAGE_BASIC: Executing operation write/Write/WriteImpl/GroupByKey/Read+write/Write/WriteImpl/GroupByKey/GroupByWindow+write/Write/WriteImpl/Extract
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:28.586Z: JOB_MESSAGE_DETAILED: Checking permissions granted to controller Service Account.
WARNING:apache_beam.runners.dataflow.dataflow_runner:Timing out on waiting for job 2020-04-01_11_39_25-1073712127897561694 after 360 seconds
DEBUG:google.auth.transport._http_client:Making request: GET http://169.254.169.254
DEBUG:google.auth.transport._http_client:Making request: GET http://metadata.google.internal/computeMetadata/v1/project/project-id
DEBUG:google.auth.transport.requests:Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/default/?recursive=true
DEBUG:urllib3.connectionpool:Starting new HTTP connection (1): metadata.google.internal:80
DEBUG:urllib3.connectionpool:http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/default/?recursive=true HTTP/1.1" 200 144
DEBUG:google.auth.transport.requests:Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token
DEBUG:urllib3.connectionpool:http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token HTTP/1.1" 200 192
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:38.440Z: JOB_MESSAGE_BASIC: Finished operation write/Write/WriteImpl/GroupByKey/Read+write/Write/WriteImpl/GroupByKey/GroupByWindow+write/Write/WriteImpl/Extract
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:38.520Z: JOB_MESSAGE_DEBUG: Value "write/Write/WriteImpl/Extract.out" materialized.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:38.627Z: JOB_MESSAGE_BASIC: Executing operation write/Write/WriteImpl/FinalizeWrite/_UnpickledSideInput(Extract.out.0)
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:38.697Z: JOB_MESSAGE_BASIC: Executing operation write/Write/WriteImpl/PreFinalize/_UnpickledSideInput(Extract.out.0)
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:38.733Z: JOB_MESSAGE_BASIC: Finished operation write/Write/WriteImpl/FinalizeWrite/_UnpickledSideInput(Extract.out.0)
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:38.784Z: JOB_MESSAGE_BASIC: Finished operation write/Write/WriteImpl/PreFinalize/_UnpickledSideInput(Extract.out.0)
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:38.849Z: JOB_MESSAGE_DEBUG: Value "write/Write/WriteImpl/FinalizeWrite/_UnpickledSideInput(Extract.out.0).output" materialized.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:38.875Z: JOB_MESSAGE_DEBUG: Value "write/Write/WriteImpl/PreFinalize/_UnpickledSideInput(Extract.out.0).output" materialized.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:38.959Z: JOB_MESSAGE_BASIC: Executing operation write/Write/WriteImpl/PreFinalize/PreFinalize
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:43.084Z: JOB_MESSAGE_BASIC: Finished operation write/Write/WriteImpl/PreFinalize/PreFinalize
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:43.159Z: JOB_MESSAGE_DEBUG: Value "write/Write/WriteImpl/PreFinalize.out" materialized.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:43.232Z: JOB_MESSAGE_BASIC: Executing operation write/Write/WriteImpl/FinalizeWrite/_UnpickledSideInput(PreFinalize.out.0)
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:43.283Z: JOB_MESSAGE_BASIC: Finished operation write/Write/WriteImpl/FinalizeWrite/_UnpickledSideInput(PreFinalize.out.0)
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:43.366Z: JOB_MESSAGE_DEBUG: Value "write/Write/WriteImpl/FinalizeWrite/_UnpickledSideInput(PreFinalize.out.0).output" materialized.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:43.458Z: JOB_MESSAGE_BASIC: Executing operation write/Write/WriteImpl/FinalizeWrite/FinalizeWrite
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:45.911Z: JOB_MESSAGE_BASIC: Finished operation write/Write/WriteImpl/FinalizeWrite/FinalizeWrite
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:45.992Z: JOB_MESSAGE_DEBUG: Executing success step success24
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:46.130Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:46.192Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-04-01T18:45:46.227Z: JOB_MESSAGE_BASIC: Stopping worker pool...

> Task :sdks:python:test-suites:tox:py37:testPy37Cloud
..........s...................................... [ 59%]
...
> Task :sdks:python:test-suites:tox:py35:testPy35Cloud
..... [ 57%]
.s.s.s..ssss.....................................sss......sFATAL: command execution failed
hudson.remoting.ChannelClosedException: Channel "unknown": Remote call on JNLP4-connect connection from 84.68.226.35.bc.googleusercontent.com/35.226.68.84:35580 failed. The channel is closing down or has closed down
	at hudson.remoting.Channel.call(Channel.java:950)
	at hudson.remoting.RemoteInvocationHandler.invoke(RemoteInvocationHandler.java:283)
	at com.sun.proxy.$Proxy140.isAlive(Unknown Source)
	at hudson.Launcher$RemoteLauncher$ProcImpl.isAlive(Launcher.java:1150)
	at hudson.Launcher$RemoteLauncher$ProcImpl.join(Launcher.java:1142)
	at hudson.Launcher$ProcStarter.join(Launcher.java:470)
	at hudson.plugins.gradle.Gradle.perform(Gradle.java:317)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:741)
	at hudson.model.Build$BuildExecution.build(Build.java:206)
	at hudson.model.Build$BuildExecution.doRun(Build.java:163)
	at hudson.model.AbstractBuild$AbstractBuildExecution.run(AbstractBuild.java:504)
	at hudson.model.Run.execute(Run.java:1815)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
	at hudson.model.ResourceController.execute(ResourceController.java:97)
	at hudson.model.Executor.run(Executor.java:429)
Caused by: java.nio.channels.ClosedChannelException
	at org.jenkinsci.remoting.protocol.impl.ChannelApplicationLayer.onReadClosed(ChannelApplicationLayer.java:209)
	at org.jenkinsci.remoting.protocol.ApplicationLayer.onRecvClosed(ApplicationLayer.java:222)
	at org.jenkinsci.remoting.protocol.ProtocolStack$Ptr.onRecvClosed(ProtocolStack.java:816)
	at org.jenkinsci.remoting.protocol.FilterLayer.onRecvClosed(FilterLayer.java:287)
	at org.jenkinsci.remoting.protocol.impl.SSLEngineFilterLayer.onRecvClosed(SSLEngineFilterLayer.java:181)
	at org.jenkinsci.remoting.protocol.impl.SSLEngineFilterLayer.switchToNoSecure(SSLEngineFilterLayer.java:283)
	at org.jenkinsci.remoting.protocol.impl.SSLEngineFilterLayer.processWrite(SSLEngineFilterLayer.java:503)
	at org.jenkinsci.remoting.protocol.impl.SSLEngineFilterLayer.processQueuedWrites(SSLEngineFilterLayer.java:248)
	at org.jenkinsci.remoting.protocol.impl.SSLEngineFilterLayer.doSend(SSLEngineFilterLayer.java:200)
	at org.jenkinsci.remoting.protocol.impl.SSLEngineFilterLayer.doCloseSend(SSLEngineFilterLayer.java:213)
	at org.jenkinsci.remoting.protocol.ProtocolStack$Ptr.doCloseSend(ProtocolStack.java:784)
	at org.jenkinsci.remoting.protocol.ApplicationLayer.doCloseWrite(ApplicationLayer.java:173)
	at org.jenkinsci.remoting.protocol.impl.ChannelApplicationLayer$ByteBufferCommandTransport.closeWrite(ChannelApplicationLayer.java:314)
	at hudson.remoting.Channel.close(Channel.java:1452)
	at hudson.remoting.Channel.close(Channel.java:1405)
	at hudson.slaves.SlaveComputer.closeChannel(SlaveComputer.java:847)
	at hudson.slaves.SlaveComputer.access$800(SlaveComputer.java:108)
	at hudson.slaves.SlaveComputer$3.run(SlaveComputer.java:756)
	at jenkins.util.ContextResettingExecutorService$1.run(ContextResettingExecutorService.java:28)
	at jenkins.security.ImpersonatingExecutorService$1.run(ImpersonatingExecutorService.java:59)
	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
	at java.lang.Thread.run(Thread.java:748)
Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
ERROR: apache-beam-jenkins-8 is offline; cannot locate JDK 1.8 (latest)

---------------------------------------------------------------------
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_Cron #2586

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PreCommit_Python_Cron/2586/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_PreCommit_Python_Cron #2585

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PreCommit_Python_Cron/2585/display/redirect>

Changes:


------------------------------------------
[...truncated 1.23 MB...]
    result = pf.PipelineFragment(list(pcolls), user_pipeline.options).run()

apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py>:1240: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(DebugOptions).experiments.remove('beam_fn_api')

apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py>:1260: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(DebugOptions).experiments.remove('beam_fn_api')

apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py>:1287: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(DebugOptions).experiments.remove('beam_fn_api')

target/.tox-py27-cython/py27-cython/lib/python2.7/site-packages/hamcrest/library/collection/issequence_containinginorder.py:95
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/target/.tox-py27-cython/py27-cython/lib/python2.7/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/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/trigger_test.py>:974: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(StandardOptions).streaming = True

apache_beam/transforms/combiners.py:186
apache_beam/transforms/combiners.py:186
apache_beam/transforms/combiners.py:186
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/combiners.py>:186: DeprecationWarning: Compare not available in Python 3, use key instead.
    DeprecationWarning)

apache_beam/transforms/combiners.py:275
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/combiners.py>:275: DeprecationWarning: Compare not available in Python 3, use key instead.
    DeprecationWarning)

apache_beam/transforms/util_test.py:651
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/util_test.py>:651: FutureWarning: GroupIntoBatches is experimental.
    | util.GroupIntoBatches(GroupIntoBatchesTest.BATCH_SIZE)

apache_beam/transforms/util.py:763
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/util.py>:763: UserWarning: Use of GroupIntoBatches transform requires State/Timer support from the runner
    'Use of GroupIntoBatches transform requires State/Timer '

apache_beam/transforms/ptransform_test.py:717
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/ptransform_test.py>:717: BeamDeprecationWarning: RemoveDuplicates is deprecated since 2.12. Use Distinct instead.
    result = pcoll.apply(beam.RemoveDuplicates())

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/pytest_py27-cython.xml> -
=========== 2551 passed, 575 skipped, 220 warnings in 573.80 seconds ===========
============================= test session starts ==============================
platform linux2 -- Python 2.7.12, pytest-4.6.9, py-1.8.1, pluggy-0.13.1
cachedir: target/.tox-py27-cython/py27-cython/.pytest_cache
rootdir: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python,> inifile: pytest.ini
plugins: requests-mock-1.7.0, forked-1.1.3, xdist-1.31.0, timeout-1.3.4
timeout: 600.0s
timeout method: signal
timeout func_only: False
collected 3183 items / 3125 deselected / 4 skipped / 54 selected

apache_beam/coders/fast_coders_test.py ............................      [ 48%]
apache_beam/coders/slow_coders_test.py ............................      [ 96%]
apache_beam/io/gcp/tests/bigquery_matcher_test.py s                      [ 98%]
apache_beam/runners/portability/stager_test.py .                         [100%]

=============================== warnings summary ===============================
apache_beam/__init__.py:82
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/__init__.py>:82: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
    'You are using Apache Beam with Python 2. '

target/.tox-py27-cython/py27-cython/lib/python2.7/site-packages/py/_code/_assertionold.py:3
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/target/.tox-py27-cython/py27-cython/lib/python2.7/site-packages/py/_code/_assertionold.py>:3: DeprecationWarning: The compiler package is deprecated and removed in Python 3.x.
    from compiler import parse, ast, pycodegen

apache_beam/transforms/trigger_test.py:541
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/trigger_test.py>:541: YAMLLoadWarning: calling yaml.load_all() without Loader=... is deprecated, as the default Loader is unsafe. Please read https://msg.pyyaml.org/load for full details.
    for spec in yaml.load_all(open(transcript_filename)):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/pytest_py27-cython_no_xdist.xml> -
====== 57 passed, 5 skipped, 3125 deselected, 3 warnings in 8.14 seconds =======
py27-cython run-test-post: commands[0] | <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
  py27-cython: commands succeeded
  congratulations :)

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:py37:testPy37Cloud'.
> 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:tox:py35:testPy35Cloud'.
> 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:tox:py2:testPy2Cloud'.
> 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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.2.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 33m 57s
80 actionable tasks: 63 executed, 17 from cache

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

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_PreCommit_Python_Cron #2584

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PreCommit_Python_Cron/2584/display/redirect?page=changes>

Changes:

[pabloem] Revert "Merge pull request #11104 from y1chi/update_tornado_test"

[lcwik] [BEAM-9668] Disable tests till Dataflow containers are updated.

[github] [BEAM-9652] Ensure that the multipartition write sets the correct coder

[github] [BEAM-8889]add experiment flag use_grpc_for_gcs (#11183)


------------------------------------------
[...truncated 5.80 MB...]
apache_beam/runners/interactive/interactive_beam.py:386
apache_beam/runners/interactive/interactive_beam.py:386
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/interactive/interactive_beam.py>:386: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    runner, user_pipeline, user_pipeline.options)

apache_beam/runners/interactive/interactive_beam.py:409
apache_beam/runners/interactive/interactive_beam.py:409
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/interactive/interactive_beam.py>:409: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    result = pf.PipelineFragment(list(pcolls), user_pipeline.options).run()

apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py>:1240: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(DebugOptions).experiments.remove('beam_fn_api')

apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py>:1287: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(DebugOptions).experiments.remove('beam_fn_api')

apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py>:1260: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(DebugOptions).experiments.remove('beam_fn_api')

target/.tox-py27-cython/py27-cython/lib/python2.7/site-packages/hamcrest/library/collection/issequence_containinginorder.py:95
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/target/.tox-py27-cython/py27-cython/lib/python2.7/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:717
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/ptransform_test.py>:717: BeamDeprecationWarning: RemoveDuplicates is deprecated since 2.12. Use Distinct instead.
    result = pcoll.apply(beam.RemoveDuplicates())

apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/trigger_test.py>:974: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(StandardOptions).streaming = True

apache_beam/transforms/combiners.py:186
apache_beam/transforms/combiners.py:186
apache_beam/transforms/combiners.py:186
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/combiners.py>:186: DeprecationWarning: Compare not available in Python 3, use key instead.
    DeprecationWarning)

apache_beam/transforms/combiners.py:275
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/combiners.py>:275: DeprecationWarning: Compare not available in Python 3, use key instead.
    DeprecationWarning)

apache_beam/transforms/util_test.py:651
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/util_test.py>:651: FutureWarning: GroupIntoBatches is experimental.
    | util.GroupIntoBatches(GroupIntoBatchesTest.BATCH_SIZE)

apache_beam/transforms/util.py:763
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/util.py>:763: UserWarning: Use of GroupIntoBatches transform requires State/Timer support from the runner
    'Use of GroupIntoBatches transform requires State/Timer '

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/pytest_py27-cython.xml> -
=========== 2551 passed, 575 skipped, 220 warnings in 562.03 seconds ===========
============================= test session starts ==============================
platform linux2 -- Python 2.7.12, pytest-4.6.9, py-1.8.1, pluggy-0.13.1
cachedir: target/.tox-py27-cython/py27-cython/.pytest_cache
rootdir: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python,> inifile: pytest.ini
plugins: requests-mock-1.7.0, forked-1.1.3, xdist-1.31.0, timeout-1.3.4
timeout: 600.0s
timeout method: signal
timeout func_only: False
collected 3183 items / 3125 deselected / 4 skipped / 54 selected

apache_beam/coders/fast_coders_test.py ............................      [ 48%]
apache_beam/coders/slow_coders_test.py ............................      [ 96%]
apache_beam/io/gcp/tests/bigquery_matcher_test.py s                      [ 98%]
apache_beam/runners/portability/stager_test.py .                         [100%]

=============================== warnings summary ===============================
apache_beam/__init__.py:82
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/__init__.py>:82: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
    'You are using Apache Beam with Python 2. '

target/.tox-py27-cython/py27-cython/lib/python2.7/site-packages/py/_code/_assertionold.py:3
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/target/.tox-py27-cython/py27-cython/lib/python2.7/site-packages/py/_code/_assertionold.py>:3: DeprecationWarning: The compiler package is deprecated and removed in Python 3.x.
    from compiler import parse, ast, pycodegen

apache_beam/transforms/trigger_test.py:541
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/trigger_test.py>:541: YAMLLoadWarning: calling yaml.load_all() without Loader=... is deprecated, as the default Loader is unsafe. Please read https://msg.pyyaml.org/load for full details.
    for spec in yaml.load_all(open(transcript_filename)):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/pytest_py27-cython_no_xdist.xml> -
====== 57 passed, 5 skipped, 3125 deselected, 3 warnings in 7.42 seconds =======
py27-cython run-test-post: commands[0] | <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
  py27-cython: commands succeeded
  congratulations :)

> Task :sdks:python:test-suites:tox:py2:preCommitPy2

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:py35:testPy35Cloud'.
> 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:tox:py35:testPy35Cython'.
> 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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.2.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 32m 24s
80 actionable tasks: 62 executed, 18 from cache

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

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_PreCommit_Python_Cron #2583

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PreCommit_Python_Cron/2583/display/redirect?page=changes>

Changes:

[robertwb] [BEAM-9340] Populate requirement for timer families.

[daniel.o.programmer] [BEAM-9642] Create runtime invokers for SDF methods.


------------------------------------------
[...truncated 1.28 MB...]

apache_beam/io/fileio_test.py:589
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/fileio_test.py>:589: FutureWarning: MatchFiles is experimental.
    files = (p | beam.io.fileio.MatchFiles(FileSystems.join(dir, '*')))

apache_beam/io/fileio_test.py:596
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/fileio_test.py>:596: FutureWarning: ReadMatches is experimental.
    | beam.Map(

apache_beam/io/parquetio_test.py:374
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/parquetio_test.py>:374: FutureWarning: The parameter chunksize is deprecated for pyarrow.Table.to_batches as of 0.15, please use the parameter max_chunksize instead
    count=12000).to_batches(chunksize=1000)

apache_beam/runners/interactive/interactive_beam.py:386
apache_beam/runners/interactive/interactive_beam.py:386
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/interactive/interactive_beam.py>:386: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    runner, user_pipeline, user_pipeline.options)

apache_beam/runners/interactive/interactive_beam.py:409
apache_beam/runners/interactive/interactive_beam.py:409
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/interactive/interactive_beam.py>:409: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    result = pf.PipelineFragment(list(pcolls), user_pipeline.options).run()

apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1240
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py>:1240: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(DebugOptions).experiments.remove('beam_fn_api')

apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1260
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py>:1260: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(DebugOptions).experiments.remove('beam_fn_api')

apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:1287
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py>:1287: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(DebugOptions).experiments.remove('beam_fn_api')

target/.tox-py27-cython/py27-cython/lib/python2.7/site-packages/hamcrest/library/collection/issequence_containinginorder.py:95
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/target/.tox-py27-cython/py27-cython/lib/python2.7/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/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
apache_beam/transforms/trigger_test.py:974
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/trigger_test.py>:974: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(StandardOptions).streaming = True

apache_beam/transforms/combiners.py:186
apache_beam/transforms/combiners.py:186
apache_beam/transforms/combiners.py:186
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/combiners.py>:186: DeprecationWarning: Compare not available in Python 3, use key instead.
    DeprecationWarning)

apache_beam/transforms/combiners.py:275
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/combiners.py>:275: DeprecationWarning: Compare not available in Python 3, use key instead.
    DeprecationWarning)

apache_beam/transforms/util_test.py:651
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/util_test.py>:651: FutureWarning: GroupIntoBatches is experimental.
    | util.GroupIntoBatches(GroupIntoBatchesTest.BATCH_SIZE)

apache_beam/transforms/util.py:763
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/util.py>:763: UserWarning: Use of GroupIntoBatches transform requires State/Timer support from the runner
    'Use of GroupIntoBatches transform requires State/Timer '

apache_beam/transforms/ptransform_test.py:717
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/ptransform_test.py>:717: BeamDeprecationWarning: RemoveDuplicates is deprecated since 2.12. Use Distinct instead.
    result = pcoll.apply(beam.RemoveDuplicates())

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/pytest_py27-cython.xml> -
=========== 2551 passed, 575 skipped, 220 warnings in 610.57 seconds ===========
============================= test session starts ==============================
platform linux2 -- Python 2.7.12, pytest-4.6.9, py-1.8.1, pluggy-0.13.1
cachedir: target/.tox-py27-cython/py27-cython/.pytest_cache
rootdir: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python,> inifile: pytest.ini
plugins: requests-mock-1.7.0, forked-1.1.3, xdist-1.31.0, timeout-1.3.4
timeout: 600.0s
timeout method: signal
timeout func_only: False
collected 3183 items / 3125 deselected / 4 skipped / 54 selected

apache_beam/coders/fast_coders_test.py ............................      [ 48%]
apache_beam/coders/slow_coders_test.py ............................      [ 96%]
apache_beam/io/gcp/tests/bigquery_matcher_test.py s                      [ 98%]
apache_beam/runners/portability/stager_test.py .                         [100%]

=============================== warnings summary ===============================
apache_beam/__init__.py:82
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/__init__.py>:82: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
    'You are using Apache Beam with Python 2. '

target/.tox-py27-cython/py27-cython/lib/python2.7/site-packages/py/_code/_assertionold.py:3
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/target/.tox-py27-cython/py27-cython/lib/python2.7/site-packages/py/_code/_assertionold.py>:3: DeprecationWarning: The compiler package is deprecated and removed in Python 3.x.
    from compiler import parse, ast, pycodegen

apache_beam/transforms/trigger_test.py:541
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/trigger_test.py>:541: YAMLLoadWarning: calling yaml.load_all() without Loader=... is deprecated, as the default Loader is unsafe. Please read https://msg.pyyaml.org/load for full details.
    for spec in yaml.load_all(open(transcript_filename)):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/pytest_py27-cython_no_xdist.xml> -
====== 57 passed, 5 skipped, 3125 deselected, 3 warnings in 7.68 seconds =======
py27-cython run-test-post: commands[0] | <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
  py27-cython: commands succeeded
  congratulations :)

> Task :sdks:python:test-suites:tox:py2:preCommitPy2

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:py36:testPy36Cloud'.
> 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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.2.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 33m 47s
80 actionable tasks: 62 executed, 18 from cache

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

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