You are viewing a plain text version of this content. The canonical link for it is here.
Posted to builds@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2019/08/19 18:54:41 UTC

Build failed in Jenkins: beam_PreCommit_Python_Cron #1694

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

Changes:

[chadrik] Fix the exception type of InMemoryJobService when job id not found

[chadrik] Update to also catch StatusRuntimeException

[wcn] [BEAM-7994] Fixing unsafe pointer usage for Go 1.13

[ryan] [BEAM-5164]: Add documentation for ParquetIO.

[ryan] fixup! [BEAM-5164]: Add documentation for ParquetIO.

[ryan] fixup! [BEAM-5164]: Add documentation for ParquetIO.

[ryan] fixup! [BEAM-5164]: Add documentation for ParquetIO.

[lukasz.gajowy] [BEAM-7772] Remove PKB from JdbcIOIT Jenkins job

[lukasz.gajowy] [BEAM-7772] Remove PKB from HadoopFormatIOIT Jenkins job

[lukasz.gajowy] [BEAM-7772] Remove PKB in hdfs file based IOITs

[lukasz.gajowy] [BEAM-7772] Refactor: rename consistently with

[lukasz.gajowy] [BEAM-7772] Remove obsolete pkb config files

[lukasz.gajowy] [BEAM-7772] Refactor: reformat code, fix variable naming

[lukasz.gajowy] [BEAM-7772] Move all file based ioits to one file

[kyle.winkelman] [BEAM-5519] Remove redundant groupByKey in Spark Streaming.

[lukasz.gajowy] [BEAM-5980] Refactor: keep all Flink Python Combine load test scenarios

[lukasz.gajowy] [BEAM-5980] Remove redundant Combine Performance tests

------------------------------------------
[...truncated 5.21 MB...]
test_must_be_primitive_type_or_constraint (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok
test_valid_mix_positional_and_keyword_arguments (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok
test_valid_only_positional_arguments (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok
test_valid_simple_type_arguments (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok
test_coercion_fail (apache_beam.typehints.typehints_test.TestCoerceToKvType) ... ok
test_coercion_success (apache_beam.typehints.typehints_test.TestCoerceToKvType) ... ok
test_functions_as_regular_generator (apache_beam.typehints.typehints_test.TestGeneratorWrapper) ... ok
test_compatibility (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_compatibility_arbitrary_length (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_getitem_invalid_ellipsis_type_param (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_getitem_params_must_be_type_or_constraint (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_raw_tuple (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_repr (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_invalid_composite_type (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_invalid_composite_type_arbitrary_length (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_invalid_simple_type_arbitrary_length (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_invalid_simple_types (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_must_be_tuple (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_must_have_same_arity (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_valid_composite_type_arbitrary_length (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_valid_composite_types (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_valid_simple_type_arbitrary_length (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_valid_simple_types (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_dict_union (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_empty_union (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_getitem_duplicates_ignored (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_getitem_must_be_valid_type_param (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_getitem_must_be_valid_type_param_cant_be_object_instance (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_getitem_nested_unions_flattened (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_nested_compatibility (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_union_hint_compatibility (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_union_hint_enforcement_composite_type_in_union (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_union_hint_enforcement_not_part_of_union (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_union_hint_enforcement_part_of_union (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_union_hint_repr (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
Tests if custom message prints an empty string ... ok
test_deprecated_with_since_current (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_deprecated_with_since_current_message (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_deprecated_with_since_current_message_class (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_deprecated_with_since_current_message_custom (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_deprecated_without_current (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_deprecated_without_since_custom_should_fail (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_deprecated_without_since_should_fail (apache_beam.utils.annotations_test.AnnotationTests) ... ok
Tests since replacement token inclusion on the ... ok
test_experimental_with_current (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_experimental_with_current_message (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_experimental_with_current_message_class (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_experimental_with_current_message_custom (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_experimental_without_current (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_equal_objects (apache_beam.utils.counters_test.CounterNameTest) ... ok
test_hash_two_objects (apache_beam.utils.counters_test.CounterNameTest) ... ok
test_name_string_representation (apache_beam.utils.counters_test.CounterNameTest) ... ok
test_method_forwarding_not_windows (apache_beam.utils.processes_test.Exec) ... ok
test_method_forwarding_windows (apache_beam.utils.processes_test.Exec) ... ok
test_check_output_pip_install_non_existing_package (apache_beam.utils.processes_test.TestErrorHandlingCall) ... ok
test_oserror_check_output_message (apache_beam.utils.processes_test.TestErrorHandlingCall) ... ok
test_check_call_pip_install_non_existing_package (apache_beam.utils.processes_test.TestErrorHandlingCheckCall) ... ok
test_oserror_check_call (apache_beam.utils.processes_test.TestErrorHandlingCheckCall) ... ok
test_oserror_check_call_message (apache_beam.utils.processes_test.TestErrorHandlingCheckCall) ... ok
test_check_output_pip_install_non_existing_package (apache_beam.utils.processes_test.TestErrorHandlingCheckOutput) ... ok
test_oserror_check_output_message (apache_beam.utils.processes_test.TestErrorHandlingCheckOutput) ... ok
test_call_two_objects (apache_beam.utils.retry_test.RetryStateTest) ... ok
test_single_failure (apache_beam.utils.retry_test.RetryStateTest) ... ok
test_two_failures (apache_beam.utils.retry_test.RetryStateTest) ... ok
test_log_calls_for_permanent_failure (apache_beam.utils.retry_test.RetryTest) ... ok
test_log_calls_for_transient_failure (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_default_number_of_retries (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_explicit_decorator (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_explicit_initial_delay (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_explicit_number_of_retries (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_http_error_that_should_be_retried (apache_beam.utils.retry_test.RetryTest) ... SKIP: google-apitools is not installed
test_with_http_error_that_should_not_be_retried (apache_beam.utils.retry_test.RetryTest) ... SKIP: google-apitools is not installed
test_with_no_retry_decorator (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_real_clock (apache_beam.utils.retry_test.RetryTest) ... ok
test_arithmetic (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_of (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_precision (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_sort_order (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_str (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_arithmetic (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_from_rfc3339 (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_from_rfc3339_failure (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_from_rfc3339_with_timezone (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_from_utc_datetime (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_of (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_precision (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_sort_order (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_str (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_utc_timestamp (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_equality (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_hash (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_pickle (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_timestamps (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_with_value (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_no_partial_writeouts (apache_beam.pipeline_test.DirectRunnerRetryTests) ... ok
test_retry_fork_graph (apache_beam.pipeline_test.DirectRunnerRetryTests) ... ok
test_element (apache_beam.pipeline_test.DoFnTest) ... ok
test_side_input_no_tag (apache_beam.pipeline_test.DoFnTest) ... ok
test_side_input_tagged (apache_beam.pipeline_test.DoFnTest) ... ok
test_timestamp_param (apache_beam.pipeline_test.DoFnTest) ... ok
test_timestamp_param_map (apache_beam.pipeline_test.DoFnTest) ... ok
test_window_param (apache_beam.pipeline_test.DoFnTest) ... ok
test_attribute_setting (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_defaults (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_dir (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_flag_parsing (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_keyword_parsing (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_view_as (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_aggregator_empty_input (apache_beam.pipeline_test.PipelineTest) ... ok
test_apply_custom_transform (apache_beam.pipeline_test.PipelineTest) ... ok
test_create (apache_beam.pipeline_test.PipelineTest) ... ok
test_create_singleton_pcollection (apache_beam.pipeline_test.PipelineTest) ... ok
test_fake_read (apache_beam.pipeline_test.PipelineTest) ... ok
test_flatmap_builtin (apache_beam.pipeline_test.PipelineTest) ... ok
test_flatmaptuple_builtin (apache_beam.pipeline_test.PipelineTest) ... ok
test_kv_ptransform_honor_type_hints (apache_beam.pipeline_test.PipelineTest) ... ok
test_maptuple_builtin (apache_beam.pipeline_test.PipelineTest) ... ok
test_memory_usage (apache_beam.pipeline_test.PipelineTest) ... SKIP: Fails on some platforms with new urllib3.
test_metrics_in_fake_source (apache_beam.pipeline_test.PipelineTest) ... ok
test_pipeline_as_context (apache_beam.pipeline_test.PipelineTest) ... ok
test_ptransform_override_type_hints (apache_beam.pipeline_test.PipelineTest) ... ok
test_ptransform_overrides (apache_beam.pipeline_test.PipelineTest) ... ok
test_reuse_cloned_custom_transform_instance (apache_beam.pipeline_test.PipelineTest) ... ok
test_reuse_custom_transform_instance (apache_beam.pipeline_test.PipelineTest) ... ok
test_transform_no_super_init (apache_beam.pipeline_test.PipelineTest) ... ok
test_visit_entire_graph (apache_beam.pipeline_test.PipelineTest) ... ok
test_parent_pointer (apache_beam.pipeline_test.RunnerApiTest) ... ok
test_assingleton_multi_element (apache_beam.pvalue_test.PValueTest) ... ok
test_pvalue_expected_arguments (apache_beam.pvalue_test.PValueTest) ... ok
test_passed_tuple_as_tag (apache_beam.pvalue_test.TaggedValueTest) ... ok
test_assert_array_count_equal_mixed (apache_beam.testing.extra_assertions_test.ExtraAssertionsMixinTest) ... ok
test_assert_array_count_equal_strings (apache_beam.testing.extra_assertions_test.ExtraAssertionsMixinTest) ... ok
testCoGroupByKey (apache_beam.testing.load_tests.co_group_by_key_test.CoGroupByKeyTest) ... SKIP: Enabled only for phrase triggering.
testCombineGlobally (apache_beam.testing.load_tests.combine_test.CombineTest) ... SKIP: Enabled only for phrase triggering.
testGroupByKey (apache_beam.testing.load_tests.group_by_key_test.GroupByKeyTest) ... SKIP: Enabled only for phrase triggering.
testParDo (apache_beam.testing.load_tests.pardo_test.ParDoTest) ... SKIP: Enabled only for phrase triggering.
testSideInput (apache_beam.testing.load_tests.sideinput_test.SideInputTest) ... SKIP: Enabled only for phrase triggering.
test_counter_does_not_match_distribution_and_doesnt_crash (apache_beam.testing.metric_result_matchers_test.MetricResultMatchersTest) ... ok
test_distribution_does_not_match_counter_and_doesnt_crash (apache_beam.testing.metric_result_matchers_test.MetricResultMatchersTest) ... ok
test_matches_all_for_counter (apache_beam.testing.metric_result_matchers_test.MetricResultMatchersTest) ... ok
test_matches_all_for_distribution (apache_beam.testing.metric_result_matchers_test.MetricResultMatchersTest) ... ok
test_matches_counter_with_custom_matchers (apache_beam.testing.metric_result_matchers_test.MetricResultMatchersTest) ... ok
test_matches_distribution_with_custom_matchers (apache_beam.testing.metric_result_matchers_test.MetricResultMatchersTest) ... ok
test_matches_key_but_not_value (apache_beam.testing.metric_result_matchers_test.MetricResultMatchersTest) ... ok
test_matches_none_for_counter (apache_beam.testing.metric_result_matchers_test.MetricResultMatchersTest) ... ok
test_matches_none_for_distribution (apache_beam.testing.metric_result_matchers_test.MetricResultMatchersTest) ... ok
test_file_checksum_matchcer_invalid_sleep_time (apache_beam.testing.pipeline_verifiers_test.PipelineVerifiersTest) ... ok
test_file_checksum_matcher_read_failed (apache_beam.testing.pipeline_verifiers_test.PipelineVerifiersTest) ... ok
test_file_checksum_matcher_service_error (apache_beam.testing.pipeline_verifiers_test.PipelineVerifiersTest) ... SKIP: google-apitools is not installed
test_file_checksum_matcher_sleep_before_verify (apache_beam.testing.pipeline_verifiers_test.PipelineVerifiersTest) ... ok
test_file_checksum_matcher_success (apache_beam.testing.pipeline_verifiers_test.PipelineVerifiersTest) ... ok
Test PipelineStateMatcher fails when using default expected state ... ok
Test PipelineStateMatcher successes when matches given state ... ok
Test PipelineStateMatcher successes when using default expected state ... ok
testSyntheticStepSplitProviderUnevenChunks (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_minimal_runtime_with_synthetic_sdf_step_bundle_delay (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_minimal_runtime_with_synthetic_step_delay (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_pipeline_expand_gbk (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_pipeline_expand_side_output (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_pipeline_merge_gbk (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_pipeline_merge_side_input (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_pipeline_shuffle (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_pipeline_side_input (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_split_at_fraction (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_synthetic_sdf_step_multiplies_output_elements_count (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_synthetic_source (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_synthetic_source_split_even (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_synthetic_source_split_uneven (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_synthetic_step_multiplies_output_elements_count (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_synthetic_step_split_provider (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_synthetic_step_split_provider_no_liquid_sharding (apache_beam.testing.synthetic_pipeline_test.SyntheticPipelineTest) ... ok
test_append_extra_options (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... ok
test_append_verifier_in_extra_opt (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... ok
test_create_test_pipeline_options (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... ok
test_empty_option_args_parsing (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... ok
test_get_option (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... ok
test_not_use_test_runner_api (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... ok
test_option_args_parsing (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... ok
test_skip_IT (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... SKIP: IT is skipped because --test-pipeline-options is not specified
test_basic_execution (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_basic_execution_batch_sideinputs (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_basic_execution_batch_sideinputs_fixed_windows (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_basic_execution_sideinputs (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_basic_execution_sideinputs_fixed_windows (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_basic_test_stream (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
Advance TestClock to (X + delta) and see the pipeline does finish. ... ok
test_gbk_execution_after_watermark_trigger (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_gbk_execution_no_triggers (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_test_stream_errors (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_cleanup_subscriptions (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_cleanup_topics (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_delete_files_fails_with_invalid_arg (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_delete_files_fails_with_io_error (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_delete_files_succeeds (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_temp_dir_removes_files (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_temp_file_field_correct (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_assert_that_fails (apache_beam.testing.util_test.UtilTest) ... ok
test_assert_that_fails_on_empty_expected (apache_beam.testing.util_test.UtilTest) ... ok
test_assert_that_fails_on_empty_input (apache_beam.testing.util_test.UtilTest) ... ok
test_assert_that_passes (apache_beam.testing.util_test.UtilTest) ... ok
test_assert_that_passes_empty_equal_to (apache_beam.testing.util_test.UtilTest) ... ok
test_assert_that_passes_empty_is_empty (apache_beam.testing.util_test.UtilTest) ... ok
test_assert_that_passes_is_not_empty (apache_beam.testing.util_test.UtilTest) ... ok
test_assert_that_passes_order_does_not_matter (apache_beam.testing.util_test.UtilTest) ... ok
test_assert_that_passes_order_does_not_matter_with_negatives (apache_beam.testing.util_test.UtilTest) ... ok
test_reified_value_assert_fail_unmatched_timestamp (apache_beam.testing.util_test.UtilTest) ... ok
test_reified_value_assert_fail_unmatched_value (apache_beam.testing.util_test.UtilTest) ... ok
test_reified_value_assert_fail_unmatched_window (apache_beam.testing.util_test.UtilTest) ... ok
test_reified_value_passes (apache_beam.testing.util_test.UtilTest) ... ok

----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 2582 tests in 610.808s

OK (SKIP=520)
py27-cython run-test-post: commands[0] | <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
  py27-cython: commands succeeded
  congratulations :)

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

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/dataflow/py37/build.gradle'> line: 66

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:preCommitIT'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.

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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.2.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 41m 48s
84 actionable tasks: 67 executed, 17 from cache

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

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

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


Jenkins build is back to normal : beam_PreCommit_Python_Cron #1695

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


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