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

Build failed in Jenkins: beam_PostCommit_Python_Verify #6181

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

Changes:

[github] [BEAM-5442] Pass unknown SDK pipeline options to Runner (#6557)

------------------------------------------
[...truncated 1.34 MB...]
    raise RuntimeError('x')
RuntimeError: x

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 131, in _execute
    response = task()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 166, in <lambda>
    self._execute(lambda: worker.do_instruction(work), work)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 212, in do_instruction
    request.instruction_id)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 234, in process_bundle
    processor.process_bundle(instruction_id)
  File "/usr/lib/python3.5/contextlib.py", line 77, in __exit__
    self.gen.throw(type, value, traceback)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 349, in process_instruction_id
    yield
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 234, in process_bundle
    processor.process_bundle(instruction_id)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 419, in process_bundle
    ].process_encoded(data.data)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 124, in process_encoded
    self.output(decoded_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 168, in output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 269, in process
    self.output(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 168, in output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 424, in process
    self.dofn_receiver.receive(o)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 673, in receive
    self.process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 679, in process
    self._reraise_augmented(exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 677, in process
    self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 414, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 787, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 424, in process
    self.dofn_receiver.receive(o)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 673, in receive
    self.process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 679, in process
    self._reraise_augmented(exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 677, in process
    self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 414, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 787, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 424, in process
    self.dofn_receiver.receive(o)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 673, in receive
    self.process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 679, in process
    self._reraise_augmented(exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 717, in _reraise_augmented
    raise_with_traceback(new_exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3/lib/python3.5/site-packages/future/utils/__init__.py",> line 419, in raise_with_traceback
    raise exc.with_traceback(traceback)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 677, in process
    self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 414, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/core.py",> line 1068, in <lambda>
    wrapper = lambda x: [fn(x)]
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 185, in raise_error
    raise RuntimeError('x')
RuntimeError: x [while running 'StageC']


ok
test_error_traceback_includes_user_code (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: TODO
test_flatten (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_flattened_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_gbk_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_group_by_key (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_large_elements (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: Metrics not supported.
test_multimap_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_no_subtransform_composite (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: Metrics are not supported.
test_pardo_side_and_main_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_pardo_side_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_state_only (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_timers (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_unfusable_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_pardo_windowed_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_progress_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: Progress metrics not supported.
test_read (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_windowing (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_assert_that (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_combine_per_key (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_create (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_error_message_includes_stage (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_error_traceback_includes_user_code (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_flatten (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_flattened_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_gbk_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_group_by_key (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_large_elements (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_multimap_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_no_subtransform_composite (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_side_and_main_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_side_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_state_only (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_timers (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_unfusable_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_windowed_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_progress_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_read (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_windowing (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_stage_multiple_files (apache_beam.runners.portability.portable_stager_test.PortableStagerTest) ... ok
test_stage_single_file (apache_beam.runners.portability.portable_stager_test.PortableStagerTest) ... ok
test_default_resources (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_no_main_session (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_no_staging_location (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_requirements_file_not_present (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_default (apache_beam.runners.portability.stager_test.StagerTest) ... <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/portability/stager.py>:487: DeprecationWarning: The 'warn' function is deprecated, use 'warning' instead
  'of the SDK: %s', repr(e))
ok
test_sdk_location_default_with_wheels (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_http (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_directory (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_directory_not_present (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_source_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_wheel_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_remote_source_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_remote_wheel_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_setup_file_not_named_setup_dot_py (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_setup_file_not_present (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_extra_packages (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_extra_packages_invalid_file_name (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_extra_packages_missing_files (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_main_session (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_requirements_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_requirements_file_and_cache (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_setup_file (apache_beam.runners.portability.stager_test.StagerTest) ... SKIP: This test still needs to be fixed on Python 3
test_in_memory_data_channel (apache_beam.runners.worker.data_plane_test.DataChannelTest) ... ok
test_basic_record (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_exception_record (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_nested_with_per_thread_info (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_record_with_arbitrary_messages (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_record_with_format_character (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_record_with_per_thread_info (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_per_thread_attribute (apache_beam.runners.worker.logger_test.PerThreadLoggingContextTest) ... ok
test_set_when_already_defined (apache_beam.runners.worker.logger_test.PerThreadLoggingContextTest) ... ok
test_set_when_undefined (apache_beam.runners.worker.logger_test.PerThreadLoggingContextTest) ... ok
test_should_sample (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... SKIP: This test still needs to be fixed on Python 3
test_update_int (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_multiple (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_new_object (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_old_object (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_str (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_basic_counters (apache_beam.runners.worker.opcounters_test.TransformIoCounterTest) ... ok
test_parse_pipeline_options (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... ok
test_status_server (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker_main_test.py>:52: DeprecationWarning: Please use assertRegex instead.
  self.assertRegexpMatches(threaddump, '.*wrapped_method_for_test.*')
ok
test_work_count_custom_value (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker_main_test.py>:128: DeprecationWarning: Please use assertEqual instead.
  expected)
ok
test_work_count_default_value (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... ok
test_work_count_wrong_format (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... ok
test_fn_registration (apache_beam.runners.worker.sdk_worker_test.SdkWorkerTest) ... ok
test_emulated_iterable (apache_beam.runners.worker.sideinputs_test.EmulatedCollectionsTest) ... ok
test_large_iterable_values (apache_beam.runners.worker.sideinputs_test.EmulatedCollectionsTest) ... ok
test_bytes_read_are_reported (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_multiple_sources_iterator_fn (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_multiple_sources_single_reader_iterator_fn (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_single_source_iterator_fn (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_source_iterator_fn_exception (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_source_iterator_single_source_exception (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_basic_sampler (apache_beam.runners.worker.statesampler_test.StateSamplerTest) ... ok
test_sampler_transition_overhead (apache_beam.runners.worker.statesampler_test.StateSamplerTest) ... ok
test_failure_when_worker_id_exists (apache_beam.runners.worker.worker_id_interceptor_test.WorkerIdInterceptorTest) ... ok
test_worker_id_insertion (apache_beam.runners.worker.worker_id_interceptor_test.WorkerIdInterceptorTest) ... ok
test_dofn_validate_finish_bundle_error (apache_beam.runners.common_test.DoFnSignatureTest) ... ok
test_dofn_validate_process_error (apache_beam.runners.common_test.DoFnSignatureTest) ... ok
test_dofn_validate_start_bundle_error (apache_beam.runners.common_test.DoFnSignatureTest) ... ok
test_deduplication (apache_beam.runners.pipeline_context_test.PipelineContextTest) ... ok
test_serialization (apache_beam.runners.pipeline_context_test.PipelineContextTest) ... ok
test_create_runner (apache_beam.runners.runner_test.RunnerTest) ... ok
test_create_runner_shorthand (apache_beam.runners.runner_test.RunnerTest) ... ok
test_direct_runner_metrics (apache_beam.runners.runner_test.RunnerTest) ... ok
test_run_api (apache_beam.runners.runner_test.RunnerTest) ... ok
test_run_api_with_callable (apache_beam.runners.runner_test.RunnerTest) ... ok

----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 686 tests in 66.033s

OK (SKIP=148)
py3 runtests: commands[4] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
  py3: commands succeeded
  congratulations :)
:beam-sdks-python:testPython3 (Thread[Task worker for ':',5,main]) completed. Took 1 mins 21.921 secs.
:beam-sdks-python:preCommit (Thread[Task worker for ':',5,main]) started.

> Task :beam-sdks-python:preCommit
Skipping task ':beam-sdks-python:preCommit' as it has no actions.
:beam-sdks-python:preCommit (Thread[Task worker for ':',5,main]) completed. Took 0.0 secs.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/build.gradle'> line: 295

* What went wrong:
Execution failed for task ':beam-sdks-python:postCommitITTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 31m 58s
13 actionable tasks: 13 executed

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

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

Jenkins build is back to normal : beam_PostCommit_Python_Verify #6185

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


Build failed in Jenkins: beam_PostCommit_Python_Verify #6184

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

Changes:

[github] Fix website redirects, part 2

------------------------------------------
[...truncated 1.35 MB...]
    raise RuntimeError('x')
RuntimeError: x

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 131, in _execute
    response = task()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 166, in <lambda>
    self._execute(lambda: worker.do_instruction(work), work)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 212, in do_instruction
    request.instruction_id)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 234, in process_bundle
    processor.process_bundle(instruction_id)
  File "/usr/lib/python3.5/contextlib.py", line 77, in __exit__
    self.gen.throw(type, value, traceback)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 349, in process_instruction_id
    yield
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 234, in process_bundle
    processor.process_bundle(instruction_id)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 419, in process_bundle
    ].process_encoded(data.data)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 124, in process_encoded
    self.output(decoded_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 168, in output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 269, in process
    self.output(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 168, in output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 424, in process
    self.dofn_receiver.receive(o)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 673, in receive
    self.process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 679, in process
    self._reraise_augmented(exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 677, in process
    self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 414, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 787, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 424, in process
    self.dofn_receiver.receive(o)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 673, in receive
    self.process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 679, in process
    self._reraise_augmented(exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 677, in process
    self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 414, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 787, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 424, in process
    self.dofn_receiver.receive(o)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 673, in receive
    self.process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 679, in process
    self._reraise_augmented(exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 717, in _reraise_augmented
    raise_with_traceback(new_exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3/lib/python3.5/site-packages/future/utils/__init__.py",> line 419, in raise_with_traceback
    raise exc.with_traceback(traceback)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 677, in process
    self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 414, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/core.py",> line 1068, in <lambda>
    wrapper = lambda x: [fn(x)]
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 185, in raise_error
    raise RuntimeError('x')
RuntimeError: x [while running 'StageC']


ok
test_error_traceback_includes_user_code (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: TODO
test_flatten (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_flattened_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_gbk_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_group_by_key (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_large_elements (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: Metrics not supported.
test_multimap_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_no_subtransform_composite (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: Metrics are not supported.
test_pardo_side_and_main_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_pardo_side_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_state_only (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_timers (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_unfusable_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_pardo_windowed_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_progress_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: Progress metrics not supported.
test_read (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_windowing (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_assert_that (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_combine_per_key (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_create (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_error_message_includes_stage (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_error_traceback_includes_user_code (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_flatten (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_flattened_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_gbk_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_group_by_key (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_large_elements (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_multimap_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_no_subtransform_composite (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_side_and_main_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_side_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_state_only (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_timers (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_unfusable_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_windowed_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_progress_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_read (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_windowing (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_stage_multiple_files (apache_beam.runners.portability.portable_stager_test.PortableStagerTest) ... ok
test_stage_single_file (apache_beam.runners.portability.portable_stager_test.PortableStagerTest) ... ok
test_default_resources (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_no_main_session (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_no_staging_location (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_requirements_file_not_present (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_default (apache_beam.runners.portability.stager_test.StagerTest) ... <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/portability/stager.py>:487: DeprecationWarning: The 'warn' function is deprecated, use 'warning' instead
  'of the SDK: %s', repr(e))
ok
test_sdk_location_default_with_wheels (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_http (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_directory (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_directory_not_present (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_source_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_wheel_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_remote_source_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_remote_wheel_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_setup_file_not_named_setup_dot_py (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_setup_file_not_present (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_extra_packages (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_extra_packages_invalid_file_name (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_extra_packages_missing_files (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_main_session (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_requirements_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_requirements_file_and_cache (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_setup_file (apache_beam.runners.portability.stager_test.StagerTest) ... SKIP: This test still needs to be fixed on Python 3
test_in_memory_data_channel (apache_beam.runners.worker.data_plane_test.DataChannelTest) ... ok
test_basic_record (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_exception_record (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_nested_with_per_thread_info (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_record_with_arbitrary_messages (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_record_with_format_character (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_record_with_per_thread_info (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_per_thread_attribute (apache_beam.runners.worker.logger_test.PerThreadLoggingContextTest) ... ok
test_set_when_already_defined (apache_beam.runners.worker.logger_test.PerThreadLoggingContextTest) ... ok
test_set_when_undefined (apache_beam.runners.worker.logger_test.PerThreadLoggingContextTest) ... ok
test_should_sample (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... SKIP: This test still needs to be fixed on Python 3
test_update_int (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_multiple (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_new_object (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_old_object (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_str (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_basic_counters (apache_beam.runners.worker.opcounters_test.TransformIoCounterTest) ... ok
test_parse_pipeline_options (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... ok
test_status_server (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker_main_test.py>:52: DeprecationWarning: Please use assertRegex instead.
  self.assertRegexpMatches(threaddump, '.*wrapped_method_for_test.*')
ok
test_work_count_custom_value (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker_main_test.py>:128: DeprecationWarning: Please use assertEqual instead.
  expected)
ok
test_work_count_default_value (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... ok
test_work_count_wrong_format (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... ok
test_fn_registration (apache_beam.runners.worker.sdk_worker_test.SdkWorkerTest) ... ok
test_emulated_iterable (apache_beam.runners.worker.sideinputs_test.EmulatedCollectionsTest) ... ok
test_large_iterable_values (apache_beam.runners.worker.sideinputs_test.EmulatedCollectionsTest) ... ok
test_bytes_read_are_reported (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_multiple_sources_iterator_fn (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_multiple_sources_single_reader_iterator_fn (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_single_source_iterator_fn (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_source_iterator_fn_exception (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_source_iterator_single_source_exception (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_basic_sampler (apache_beam.runners.worker.statesampler_test.StateSamplerTest) ... ok
test_sampler_transition_overhead (apache_beam.runners.worker.statesampler_test.StateSamplerTest) ... ok
test_failure_when_worker_id_exists (apache_beam.runners.worker.worker_id_interceptor_test.WorkerIdInterceptorTest) ... ok
test_worker_id_insertion (apache_beam.runners.worker.worker_id_interceptor_test.WorkerIdInterceptorTest) ... ok
test_dofn_validate_finish_bundle_error (apache_beam.runners.common_test.DoFnSignatureTest) ... ok
test_dofn_validate_process_error (apache_beam.runners.common_test.DoFnSignatureTest) ... ok
test_dofn_validate_start_bundle_error (apache_beam.runners.common_test.DoFnSignatureTest) ... ok
test_deduplication (apache_beam.runners.pipeline_context_test.PipelineContextTest) ... ok
test_serialization (apache_beam.runners.pipeline_context_test.PipelineContextTest) ... ok
test_create_runner (apache_beam.runners.runner_test.RunnerTest) ... ok
test_create_runner_shorthand (apache_beam.runners.runner_test.RunnerTest) ... ok
test_direct_runner_metrics (apache_beam.runners.runner_test.RunnerTest) ... ok
test_run_api (apache_beam.runners.runner_test.RunnerTest) ... ok
test_run_api_with_callable (apache_beam.runners.runner_test.RunnerTest) ... ok

----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 686 tests in 68.390s

OK (SKIP=148)
py3 runtests: commands[4] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
  py3: commands succeeded
  congratulations :)
:beam-sdks-python:testPython3 (Thread[Daemon worker,5,main]) completed. Took 1 mins 25.415 secs.
:beam-sdks-python:preCommit (Thread[Daemon worker,5,main]) started.

> Task :beam-sdks-python:preCommit
Skipping task ':beam-sdks-python:preCommit' as it has no actions.
:beam-sdks-python:preCommit (Thread[Daemon worker,5,main]) completed. Took 0.0 secs.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/build.gradle'> line: 295

* What went wrong:
Execution failed for task ':beam-sdks-python:postCommitITTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 32m 14s
13 actionable tasks: 13 executed

Publishing build scan...
https://gradle.com/s/2ttclmwusfbgw

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

Build failed in Jenkins: beam_PostCommit_Python_Verify #6183

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

Changes:

[apilloud] [BEAM-5112] UdafImpl isn't part of interpreter

------------------------------------------
[...truncated 1.34 MB...]
    raise RuntimeError('x')
RuntimeError: x

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 131, in _execute
    response = task()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 166, in <lambda>
    self._execute(lambda: worker.do_instruction(work), work)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 212, in do_instruction
    request.instruction_id)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 234, in process_bundle
    processor.process_bundle(instruction_id)
  File "/usr/lib/python3.5/contextlib.py", line 77, in __exit__
    self.gen.throw(type, value, traceback)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 349, in process_instruction_id
    yield
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 234, in process_bundle
    processor.process_bundle(instruction_id)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 419, in process_bundle
    ].process_encoded(data.data)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 124, in process_encoded
    self.output(decoded_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 168, in output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 269, in process
    self.output(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 168, in output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 424, in process
    self.dofn_receiver.receive(o)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 673, in receive
    self.process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 679, in process
    self._reraise_augmented(exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 677, in process
    self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 414, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 787, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 424, in process
    self.dofn_receiver.receive(o)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 673, in receive
    self.process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 679, in process
    self._reraise_augmented(exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 677, in process
    self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 414, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 787, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 424, in process
    self.dofn_receiver.receive(o)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 673, in receive
    self.process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 679, in process
    self._reraise_augmented(exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 717, in _reraise_augmented
    raise_with_traceback(new_exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3/lib/python3.5/site-packages/future/utils/__init__.py",> line 419, in raise_with_traceback
    raise exc.with_traceback(traceback)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 677, in process
    self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 414, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/core.py",> line 1068, in <lambda>
    wrapper = lambda x: [fn(x)]
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 185, in raise_error
    raise RuntimeError('x')
RuntimeError: x [while running 'StageC']


ok
test_error_traceback_includes_user_code (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: TODO
test_flatten (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_flattened_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_gbk_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_group_by_key (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_large_elements (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: Metrics not supported.
test_multimap_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_no_subtransform_composite (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: Metrics are not supported.
test_pardo_side_and_main_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_pardo_side_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_state_only (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_timers (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_unfusable_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_pardo_windowed_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_progress_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: Progress metrics not supported.
test_read (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_windowing (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_assert_that (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_combine_per_key (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_create (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_error_message_includes_stage (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_error_traceback_includes_user_code (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_flatten (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_flattened_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_gbk_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_group_by_key (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_large_elements (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_multimap_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_no_subtransform_composite (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_side_and_main_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_side_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_state_only (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_timers (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_unfusable_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_windowed_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_progress_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_read (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_windowing (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_stage_multiple_files (apache_beam.runners.portability.portable_stager_test.PortableStagerTest) ... ok
test_stage_single_file (apache_beam.runners.portability.portable_stager_test.PortableStagerTest) ... ok
test_default_resources (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_no_main_session (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_no_staging_location (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_requirements_file_not_present (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_default (apache_beam.runners.portability.stager_test.StagerTest) ... <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/portability/stager.py>:487: DeprecationWarning: The 'warn' function is deprecated, use 'warning' instead
  'of the SDK: %s', repr(e))
ok
test_sdk_location_default_with_wheels (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_http (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_directory (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_directory_not_present (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_source_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_wheel_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_remote_source_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_remote_wheel_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_setup_file_not_named_setup_dot_py (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_setup_file_not_present (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_extra_packages (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_extra_packages_invalid_file_name (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_extra_packages_missing_files (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_main_session (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_requirements_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_requirements_file_and_cache (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_setup_file (apache_beam.runners.portability.stager_test.StagerTest) ... SKIP: This test still needs to be fixed on Python 3
test_in_memory_data_channel (apache_beam.runners.worker.data_plane_test.DataChannelTest) ... ok
test_basic_record (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_exception_record (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_nested_with_per_thread_info (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_record_with_arbitrary_messages (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_record_with_format_character (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_record_with_per_thread_info (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_per_thread_attribute (apache_beam.runners.worker.logger_test.PerThreadLoggingContextTest) ... ok
test_set_when_already_defined (apache_beam.runners.worker.logger_test.PerThreadLoggingContextTest) ... ok
test_set_when_undefined (apache_beam.runners.worker.logger_test.PerThreadLoggingContextTest) ... ok
test_should_sample (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... SKIP: This test still needs to be fixed on Python 3
test_update_int (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_multiple (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_new_object (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_old_object (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_str (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_basic_counters (apache_beam.runners.worker.opcounters_test.TransformIoCounterTest) ... ok
test_parse_pipeline_options (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... ok
test_status_server (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker_main_test.py>:52: DeprecationWarning: Please use assertRegex instead.
  self.assertRegexpMatches(threaddump, '.*wrapped_method_for_test.*')
ok
test_work_count_custom_value (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker_main_test.py>:128: DeprecationWarning: Please use assertEqual instead.
  expected)
ok
test_work_count_default_value (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... ok
test_work_count_wrong_format (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... ok
test_fn_registration (apache_beam.runners.worker.sdk_worker_test.SdkWorkerTest) ... ok
test_emulated_iterable (apache_beam.runners.worker.sideinputs_test.EmulatedCollectionsTest) ... ok
test_large_iterable_values (apache_beam.runners.worker.sideinputs_test.EmulatedCollectionsTest) ... ok
test_bytes_read_are_reported (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_multiple_sources_iterator_fn (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_multiple_sources_single_reader_iterator_fn (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_single_source_iterator_fn (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_source_iterator_fn_exception (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_source_iterator_single_source_exception (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_basic_sampler (apache_beam.runners.worker.statesampler_test.StateSamplerTest) ... ok
test_sampler_transition_overhead (apache_beam.runners.worker.statesampler_test.StateSamplerTest) ... ok
test_failure_when_worker_id_exists (apache_beam.runners.worker.worker_id_interceptor_test.WorkerIdInterceptorTest) ... ok
test_worker_id_insertion (apache_beam.runners.worker.worker_id_interceptor_test.WorkerIdInterceptorTest) ... ok
test_dofn_validate_finish_bundle_error (apache_beam.runners.common_test.DoFnSignatureTest) ... ok
test_dofn_validate_process_error (apache_beam.runners.common_test.DoFnSignatureTest) ... ok
test_dofn_validate_start_bundle_error (apache_beam.runners.common_test.DoFnSignatureTest) ... ok
test_deduplication (apache_beam.runners.pipeline_context_test.PipelineContextTest) ... ok
test_serialization (apache_beam.runners.pipeline_context_test.PipelineContextTest) ... ok
test_create_runner (apache_beam.runners.runner_test.RunnerTest) ... ok
test_create_runner_shorthand (apache_beam.runners.runner_test.RunnerTest) ... ok
test_direct_runner_metrics (apache_beam.runners.runner_test.RunnerTest) ... ok
test_run_api (apache_beam.runners.runner_test.RunnerTest) ... ok
test_run_api_with_callable (apache_beam.runners.runner_test.RunnerTest) ... ok

----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 686 tests in 72.877s

OK (SKIP=148)
py3 runtests: commands[4] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
  py3: commands succeeded
  congratulations :)
:beam-sdks-python:testPython3 (Thread[Task worker for ':',5,main]) completed. Took 1 mins 30.47 secs.
:beam-sdks-python:preCommit (Thread[Task worker for ':',5,main]) started.

> Task :beam-sdks-python:preCommit
Skipping task ':beam-sdks-python:preCommit' as it has no actions.
:beam-sdks-python:preCommit (Thread[Task worker for ':',5,main]) completed. Took 0.0 secs.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/build.gradle'> line: 295

* What went wrong:
Execution failed for task ':beam-sdks-python:postCommitITTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 32m 43s
13 actionable tasks: 13 executed

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

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

Build failed in Jenkins: beam_PostCommit_Python_Verify #6182

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

Changes:

[lukasz.gajowy] [BEAM-5355] Add GroupByKeyLoadTest

------------------------------------------
[...truncated 1.34 MB...]
    raise RuntimeError('x')
RuntimeError: x

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 131, in _execute
    response = task()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 166, in <lambda>
    self._execute(lambda: worker.do_instruction(work), work)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 212, in do_instruction
    request.instruction_id)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 234, in process_bundle
    processor.process_bundle(instruction_id)
  File "/usr/lib/python3.5/contextlib.py", line 77, in __exit__
    self.gen.throw(type, value, traceback)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 349, in process_instruction_id
    yield
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 234, in process_bundle
    processor.process_bundle(instruction_id)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 419, in process_bundle
    ].process_encoded(data.data)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 124, in process_encoded
    self.output(decoded_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 168, in output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 269, in process
    self.output(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 168, in output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 424, in process
    self.dofn_receiver.receive(o)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 673, in receive
    self.process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 679, in process
    self._reraise_augmented(exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 677, in process
    self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 414, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 787, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 424, in process
    self.dofn_receiver.receive(o)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 673, in receive
    self.process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 679, in process
    self._reraise_augmented(exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 677, in process
    self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 414, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 787, in process_outputs
    self.main_receivers.receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 88, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 424, in process
    self.dofn_receiver.receive(o)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 673, in receive
    self.process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 679, in process
    self._reraise_augmented(exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 717, in _reraise_augmented
    raise_with_traceback(new_exn)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3/lib/python3.5/site-packages/future/utils/__init__.py",> line 419, in raise_with_traceback
    raise exc.with_traceback(traceback)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 677, in process
    self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/common.py",> line 414, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/core.py",> line 1068, in <lambda>
    wrapper = lambda x: [fn(x)]
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py",> line 185, in raise_error
    raise RuntimeError('x')
RuntimeError: x [while running 'StageC']


ok
test_error_traceback_includes_user_code (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: TODO
test_flatten (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_flattened_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_gbk_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_group_by_key (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_large_elements (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: Metrics not supported.
test_multimap_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_no_subtransform_composite (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: Metrics are not supported.
test_pardo_side_and_main_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_pardo_side_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_state_only (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_timers (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_pardo_unfusable_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_pardo_windowed_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: This test still needs to be fixed on Python 3
test_progress_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... SKIP: Progress metrics not supported.
test_read (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_windowing (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithGrpc) ... ok
test_assert_that (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_combine_per_key (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_create (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_error_message_includes_stage (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_error_traceback_includes_user_code (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_flatten (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_flattened_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_gbk_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_group_by_key (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_large_elements (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_multimap_side_input (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_no_subtransform_composite (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_side_and_main_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_side_outputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_state_only (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_timers (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_unfusable_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_pardo_windowed_side_inputs (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_progress_metrics (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_read (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_windowing (apache_beam.runners.portability.portable_runner_test.PortableRunnerTestWithSubprocesses) ... SKIP: BEAM-3040
test_stage_multiple_files (apache_beam.runners.portability.portable_stager_test.PortableStagerTest) ... ok
test_stage_single_file (apache_beam.runners.portability.portable_stager_test.PortableStagerTest) ... ok
test_default_resources (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_no_main_session (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_no_staging_location (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_requirements_file_not_present (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_default (apache_beam.runners.portability.stager_test.StagerTest) ... <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/portability/stager.py>:487: DeprecationWarning: The 'warn' function is deprecated, use 'warning' instead
  'of the SDK: %s', repr(e))
ok
test_sdk_location_default_with_wheels (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_http (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_directory (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_directory_not_present (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_source_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_local_wheel_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_remote_source_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_sdk_location_remote_wheel_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_setup_file_not_named_setup_dot_py (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_setup_file_not_present (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_extra_packages (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_extra_packages_invalid_file_name (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_extra_packages_missing_files (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_main_session (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_requirements_file (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_requirements_file_and_cache (apache_beam.runners.portability.stager_test.StagerTest) ... ok
test_with_setup_file (apache_beam.runners.portability.stager_test.StagerTest) ... SKIP: This test still needs to be fixed on Python 3
test_in_memory_data_channel (apache_beam.runners.worker.data_plane_test.DataChannelTest) ... ok
test_basic_record (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_exception_record (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_nested_with_per_thread_info (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_record_with_arbitrary_messages (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_record_with_format_character (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_record_with_per_thread_info (apache_beam.runners.worker.logger_test.JsonLogFormatterTest) ... ok
test_per_thread_attribute (apache_beam.runners.worker.logger_test.PerThreadLoggingContextTest) ... ok
test_set_when_already_defined (apache_beam.runners.worker.logger_test.PerThreadLoggingContextTest) ... ok
test_set_when_undefined (apache_beam.runners.worker.logger_test.PerThreadLoggingContextTest) ... ok
test_should_sample (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... SKIP: This test still needs to be fixed on Python 3
test_update_int (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_multiple (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_new_object (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_old_object (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_update_str (apache_beam.runners.worker.opcounters_test.OperationCountersTest) ... ok
test_basic_counters (apache_beam.runners.worker.opcounters_test.TransformIoCounterTest) ... ok
test_parse_pipeline_options (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... ok
test_status_server (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker_main_test.py>:52: DeprecationWarning: Please use assertRegex instead.
  self.assertRegexpMatches(threaddump, '.*wrapped_method_for_test.*')
ok
test_work_count_custom_value (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker_main_test.py>:128: DeprecationWarning: Please use assertEqual instead.
  expected)
ok
test_work_count_default_value (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... ok
test_work_count_wrong_format (apache_beam.runners.worker.sdk_worker_main_test.SdkWorkerMainTest) ... ok
test_fn_registration (apache_beam.runners.worker.sdk_worker_test.SdkWorkerTest) ... ok
test_emulated_iterable (apache_beam.runners.worker.sideinputs_test.EmulatedCollectionsTest) ... ok
test_large_iterable_values (apache_beam.runners.worker.sideinputs_test.EmulatedCollectionsTest) ... ok
test_bytes_read_are_reported (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_multiple_sources_iterator_fn (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_multiple_sources_single_reader_iterator_fn (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_single_source_iterator_fn (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_source_iterator_fn_exception (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_source_iterator_single_source_exception (apache_beam.runners.worker.sideinputs_test.PrefetchingSourceIteratorTest) ... ok
test_basic_sampler (apache_beam.runners.worker.statesampler_test.StateSamplerTest) ... ok
test_sampler_transition_overhead (apache_beam.runners.worker.statesampler_test.StateSamplerTest) ... ok
test_failure_when_worker_id_exists (apache_beam.runners.worker.worker_id_interceptor_test.WorkerIdInterceptorTest) ... ok
test_worker_id_insertion (apache_beam.runners.worker.worker_id_interceptor_test.WorkerIdInterceptorTest) ... ok
test_dofn_validate_finish_bundle_error (apache_beam.runners.common_test.DoFnSignatureTest) ... ok
test_dofn_validate_process_error (apache_beam.runners.common_test.DoFnSignatureTest) ... ok
test_dofn_validate_start_bundle_error (apache_beam.runners.common_test.DoFnSignatureTest) ... ok
test_deduplication (apache_beam.runners.pipeline_context_test.PipelineContextTest) ... ok
test_serialization (apache_beam.runners.pipeline_context_test.PipelineContextTest) ... ok
test_create_runner (apache_beam.runners.runner_test.RunnerTest) ... ok
test_create_runner_shorthand (apache_beam.runners.runner_test.RunnerTest) ... ok
test_direct_runner_metrics (apache_beam.runners.runner_test.RunnerTest) ... ok
test_run_api (apache_beam.runners.runner_test.RunnerTest) ... ok
test_run_api_with_callable (apache_beam.runners.runner_test.RunnerTest) ... ok

----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 686 tests in 65.586s

OK (SKIP=148)
py3 runtests: commands[4] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
  py3: commands succeeded
  congratulations :)
:beam-sdks-python:testPython3 (Thread[Task worker for ':',5,main]) completed. Took 1 mins 21.831 secs.
:beam-sdks-python:preCommit (Thread[Task worker for ':',5,main]) started.

> Task :beam-sdks-python:preCommit
Skipping task ':beam-sdks-python:preCommit' as it has no actions.
:beam-sdks-python:preCommit (Thread[Task worker for ':',5,main]) completed. Took 0.0 secs.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/build.gradle'> line: 295

* What went wrong:
Execution failed for task ':beam-sdks-python:postCommitITTests'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 32m 25s
13 actionable tasks: 13 executed

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

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