See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4768/display/redirect?page=changes>
Changes: [echauchot] Introduce MetricsPusher in runner core to regularly push aggregated [echauchot] Instanciate MetricsPusher in runner-specific code because we need [echauchot] Improve MetricsPusher: do not aggregate metrics when not needed, improve [echauchot] Create JsonMetricsSerializer [echauchot] Stop MetricsPusher thread by observing pipeline state and improve the [echauchot] Make metrics sink configurable through PipelineOptions, pass [echauchot] Add MetricsPusher tests specific to Spark (because Spark streaming tests [echauchot] Add a MetricksPusher test to runner-core (batch and streaming are done [echauchot] Push metrics at the end of a batch pipeline in flink runner [echauchot] improve MetricsPusher lifecycle and thread safety [echauchot] Make MetricsPusher merge a list a MetricsContainerStepMaps because there [echauchot] Fix thread synchronisation and replace usages of instance variable by [echauchot] Clear dummyMetricsSink before test [echauchot] Push metrics at the end of a batch pipeline in spark runner [echauchot] Improve MetricsPusher teardown to enable multiple pipelines in a single [echauchot] Manually generate json and remove jackson [echauchot] Replace use of http client by use of java.net.HttpUrlConnection and deal [echauchot] Remove DEFAULT_PERIOD constant in favor of already existing [echauchot] Remove unneeded null check, format [echauchot] convert MetricsSink to an interface with a single writeMetrics method [echauchot] Remove MetricsSerializer base class and inline serialization in [echauchot] Dynamically create the sinks by reflection [echauchot] Split DummyMetricsSink into NoOpMetricsSink (default sink) and [echauchot] Reduce overhead when no metricsSink is provided, do not start polling [echauchot] Make MetricsPusher a regular object instead of a singleton to allow [echauchot] Explicitely start MetricsPusher from the runners [echauchot] Separate MetricsHttpSink POC to a new runners-extensions artifact and [echauchot] Fix cycle bug between teardown() and pushmetrics() [echauchot] Update MetricsPusher and TestMetricsSink to new serializable [echauchot] Use regular jackson object mapper to serialize metrics now that they are [echauchot] Give MetricsPusher a bit of time to push before assert in test [echauchot] Make MetricsPusher thread a daemon [echauchot] Fix build and clean: dependencies, rat, checkstyle, findbugs, remove [echauchot] Move build to gradle [echauchot] MetricsSink no more needs to be generic [echauchot] SparkRunnerDebugger does not need to export metrics as it does not run [echauchot] Move MetricsHttpSink and related classes to a new sub-module ------------------------------------------ [...truncated 1.06 MB...] test_type_check_violation_valid_simple_type (apache_beam.typehints.typehints_test.IterableHintTestCase) ... ok test_enforce_kv_type_constraint (apache_beam.typehints.typehints_test.KVHintTestCase) ... ok test_getitem_param_must_be_tuple (apache_beam.typehints.typehints_test.KVHintTestCase) ... ok test_getitem_param_must_have_length_2 (apache_beam.typehints.typehints_test.KVHintTestCase) ... ok test_getitem_proxy_to_tuple (apache_beam.typehints.typehints_test.KVHintTestCase) ... ok test_enforce_list_type_constraint_invalid_composite_type (apache_beam.typehints.typehints_test.ListHintTestCase) ... ok test_enforce_list_type_constraint_invalid_simple_type (apache_beam.typehints.typehints_test.ListHintTestCase) ... ok test_enforce_list_type_constraint_valid_composite_type (apache_beam.typehints.typehints_test.ListHintTestCase) ... ok test_enforce_list_type_constraint_valid_simple_type (apache_beam.typehints.typehints_test.ListHintTestCase) ... ok test_getitem_invalid_composite_type_param (apache_beam.typehints.typehints_test.ListHintTestCase) ... ok test_list_constraint_compatibility (apache_beam.typehints.typehints_test.ListHintTestCase) ... ok test_list_repr (apache_beam.typehints.typehints_test.ListHintTestCase) ... ok test_getitem_proxy_to_union (apache_beam.typehints.typehints_test.OptionalHintTestCase) ... ok test_getitem_sequence_not_allowed (apache_beam.typehints.typehints_test.OptionalHintTestCase) ... ok test_any_return_type_hint (apache_beam.typehints.typehints_test.ReturnsDecoratorTestCase) ... ok test_must_be_primitive_type_or_type_constraint (apache_beam.typehints.typehints_test.ReturnsDecoratorTestCase) ... ok test_must_be_single_return_type (apache_beam.typehints.typehints_test.ReturnsDecoratorTestCase) ... ok test_no_kwargs_accepted (apache_beam.typehints.typehints_test.ReturnsDecoratorTestCase) ... ok test_type_check_composite_type (apache_beam.typehints.typehints_test.ReturnsDecoratorTestCase) ... ok test_type_check_simple_type (apache_beam.typehints.typehints_test.ReturnsDecoratorTestCase) ... ok test_type_check_violation (apache_beam.typehints.typehints_test.ReturnsDecoratorTestCase) ... ok test_compatibility (apache_beam.typehints.typehints_test.SetHintTestCase) ... ok test_getitem_invalid_composite_type_param (apache_beam.typehints.typehints_test.SetHintTestCase) ... ok test_repr (apache_beam.typehints.typehints_test.SetHintTestCase) ... ok test_type_check_invalid_elem_type (apache_beam.typehints.typehints_test.SetHintTestCase) ... ok test_type_check_must_be_set (apache_beam.typehints.typehints_test.SetHintTestCase) ... ok test_type_check_valid_elem_composite_type (apache_beam.typehints.typehints_test.SetHintTestCase) ... ok test_type_check_valid_elem_simple_type (apache_beam.typehints.typehints_test.SetHintTestCase) ... ok test_any_argument_type_hint (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok test_basic_type_assertion (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok test_composite_type_assertion (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok test_invalid_only_positional_arguments (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok 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_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_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 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_without_current (apache_beam.utils.annotations_test.AnnotationTests) ... ok test_deprecated_without_since_should_fail (apache_beam.utils.annotations_test.AnnotationTests) ... 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_without_current (apache_beam.utils.annotations_test.AnnotationTests) ... ok Tests that the filter 'once' is sufficient to print once per ... ok test_equal_objects (apache_beam.utils.counters_test.CounterNameTest) ... ok test_hash_two_objects (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_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) ... ok test_with_http_error_that_should_not_be_retried (apache_beam.utils.retry_test.RetryTest) ... ok 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_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_memory_usage (apache_beam.pipeline_test.PipelineTest) ... ok 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_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) ... ok 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 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_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_wait_for_subscriptions_created_fails (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok test_wait_for_subscriptions_created_succeeds (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok test_wait_for_topics_created_fails (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok test_wait_for_topics_created_succeeds (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_windowed_value_assert_fail_unmatched_timestamp (apache_beam.testing.util_test.UtilTest) ... ok test_windowed_value_assert_fail_unmatched_value (apache_beam.testing.util_test.UtilTest) ... ok test_windowed_value_assert_fail_unmatched_window (apache_beam.testing.util_test.UtilTest) ... ok test_windowed_value_passes (apache_beam.testing.util_test.UtilTest) ... ok ---------------------------------------------------------------------- XML: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/nosetests.xml> ---------------------------------------------------------------------- Ran 1574 tests in 246.514s OK (SKIP=47) py27-gcp runtests: commands[5] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh> py27-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint> py27-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0 py27-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip> py27-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.3,avro==1.8.2,backports.functools-lru-cache==1.5,certifi==2018.4.16,chardet==3.0.4,configparser==3.5.0,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,flake8==3.5.0,funcsigs==1.0.2,future==0.16.0,futures==3.2.0,grpcio==1.11.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,nose==1.3.7,oauth2client==4.1.2,pbr==4.0.2,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,PyHamcrest==1.9.0,pylint==1.7.2,pytz==2018.4,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,singledispatch==3.4.0.3,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11 py27-lint runtests: PYTHONHASHSEED='154785358' py27-lint runtests: commands[0] | python --version Python 2.7.6 py27-lint runtests: commands[1] | pip --version pip 10.0.1 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint/local/lib/python2.7/site-packages/pip> (python 2.7) py27-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh> Skipping lint for generated files: bigquery_v2_client.py, bigquery_v2_messages.py, dataflow_v1b3_client.py, dataflow_v1b3_messages.py, storage_v1_client.py, storage_v1_messages.py, proto2_coder_test_messages_pb2.py, beam_artifact_api_pb2_grpc.py, beam_artifact_api_pb2.py, beam_fn_api_pb2_grpc.py, beam_fn_api_pb2.py, beam_job_api_pb2_grpc.py, beam_job_api_pb2.py, beam_provision_api_pb2_grpc.py, beam_provision_api_pb2.py, beam_runner_api_pb2_grpc.py, beam_runner_api_pb2.py, endpoints_pb2_grpc.py, endpoints_pb2.py, standard_window_fns_pb2_grpc.py, standard_window_fns_pb2.py Running pylint for module apache_beam gen_protos.py setup.py test_config.py: ************* Module apache_beam.runners.portability.fn_api_runner C:874, 0: Wrong hanging indentation (add 2 spaces). data_api_service_descriptor.url) ^ | (bad-continuation) C:903, 0: Wrong hanging indentation (add 2 spaces). controller.state_api_service_descriptor().url) ^ | (bad-continuation) -------------------------------------------------------------------- Your code has been rated at 10.00/10 (previous run: 10.00/10, +0.00) Command exited with non-zero status 16 376.71user 8.76system 1:48.11elapsed 356%CPU (0avgtext+0avgdata 258476maxresident)k 0inputs+168outputs (0major+560413minor)pagefaults 0swaps ERROR: InvocationError for command '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh'> (exited with code 16) py3-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint> py3-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0 py3-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip> py3-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.3,avro==1.8.2,certifi==2018.4.16,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,flake8==3.5.0,future==0.16.0,futures==3.1.1,grpcio==1.11.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,nose==1.3.7,oauth2client==4.1.2,pbr==4.0.2,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,PyHamcrest==1.9.0,pylint==1.7.2,pytz==2018.4,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11 py3-lint runtests: PYTHONHASHSEED='154785358' py3-lint runtests: commands[0] | python --version Python 3.4.3 py3-lint runtests: commands[1] | pip --version pip 10.0.1 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/lib/python3.4/site-packages/pip> (python 3.4) py3-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh> Running flake8 for module apache_beam: 0 50.87user 0.35system 0:19.24elapsed 266%CPU (0avgtext+0avgdata 45304maxresident)k 0inputs+0outputs (0major+68076minor)pagefaults 0swaps ___________________________________ summary ____________________________________ cover: commands succeeded docs: commands succeeded py27: commands succeeded py27-cython: commands succeeded py27-gcp: commands succeeded ERROR: py27-lint: commands failed py3-lint: commands succeeded Build step 'Execute shell' marked build as failure Not sending mail to unregistered user bbassingthwa...@vendasta.com Not sending mail to unregistered user geet.kuma...@gmail.com Not sending mail to unregistered user daniel.o.program...@gmail.com Not sending mail to unregistered user sweg...@google.com Not sending mail to unregistered user kirpic...@google.com Not sending mail to unregistered user git...@alasdairhodge.co.uk