You are viewing a plain text version of this content. The canonical link for it is here.
Posted to builds@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2023/01/12 01:46:43 UTC

Build failed in Jenkins: beam_PostCommit_Python_Examples_Dataflow #1354

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

Changes:

[noreply] [Playground] Add an option for Datastore namespace value for ci_cd.py

[noreply] Multifile examples on frontend (#24859) (#24865)

[noreply] Return only Playground examples in GetCatalog() (#24816)

[noreply] [Website] add credit karma case-study card (#24970)


------------------------------------------
[...truncated 43.02 KB...]
../../build/gradleenv/2050596098/lib/python3.10/site-packages/grpc/_channel.py:849: _InactiveRpcError

The above exception was the direct cause of the following exception:

self = <apache_beam.examples.complete.game.leader_board_it_test.LeaderBoardIT testMethod=test_leader_board_it>

    def setUp(self):
      self.test_pipeline = TestPipeline(is_integration_test=True)
      self.project = self.test_pipeline.get_option('project')
      _unique_id = str(uuid.uuid4())
    
      # Set up PubSub environment.
      from google.cloud import pubsub
    
      self.pub_client = pubsub.PublisherClient()
      self.input_topic = self.pub_client.create_topic(
          name=self.pub_client.topic_path(
              self.project, self.INPUT_TOPIC + _unique_id))
    
      self.sub_client = pubsub.SubscriberClient()
>     self.input_sub = self.sub_client.create_subscription(
          name=self.sub_client.subscription_path(
              self.project, self.INPUT_SUB + _unique_id),
          topic=self.input_topic.name)

apache_beam/examples/complete/game/leader_board_it_test.py:83: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/pubsub_v1/services/subscriber/client.py:672: in create_subscription
    response = rpc(
../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/gapic_v1/method.py:113: in __call__
    return wrapped_func(*args, **kwargs)
../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/retry.py:349: in retry_wrapped_func
    return retry_target(
../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/retry.py:191: in retry_target
    return target()
../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/timeout.py:120: in func_with_timeout
    return func(*args, **kwargs)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

args = (name: "projects/apache-beam-testing/subscriptions/leader_board_it_input_subscription61e8feca-48f2-4a3c-9cb8-b68c89b121f8"
topic: "projects/apache-beam-testing/topics/leader_board_it_input_topic61e8feca-48f2-4a3c-9cb8-b68c89b121f8"
,)
kwargs = {'metadata': [('x-goog-request-params', 'name=projects/apache-beam-testing/subscriptions/leader_board_it_input_subscri...c-9cb8-b68c89b121f8'), ('x-goog-api-client', 'gl-python/3.10.2 grpc/1.51.1 gax/2.11.0 gccl/2.13.12')], 'timeout': 60.0}

    @functools.wraps(callable_)
    def error_remapped_callable(*args, **kwargs):
        try:
            return callable_(*args, **kwargs)
        except grpc.RpcError as exc:
>           raise exceptions.from_grpc_error(exc) from exc
E           google.api_core.exceptions.DeadlineExceeded: 504 Deadline Exceeded

../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/grpc_helpers.py:74: DeadlineExceeded
=============================== warnings summary ===============================
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib and slated for removal in Python 3.12; see the module's documentation for alternative uses
    from imp import load_source

../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/operations_v1/abstract_operations_client.py:17
../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/operations_v1/abstract_operations_client.py:17
../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/operations_v1/abstract_operations_client.py:17
../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/operations_v1/abstract_operations_client.py:17
../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/operations_v1/abstract_operations_client.py:17
../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/operations_v1/abstract_operations_client.py:17
../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/operations_v1/abstract_operations_client.py:17
../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/operations_v1/abstract_operations_client.py:17
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/operations_v1/abstract_operations_client.py>:17: DeprecationWarning: The distutils package is deprecated and slated for removal in Python 3.12. Use setuptools or check PEP 632 for potential alternatives
    from distutils import util

../../build/gradleenv/2050596098/lib/python3.10/site-packages/tenacity/_asyncio.py:42
../../build/gradleenv/2050596098/lib/python3.10/site-packages/tenacity/_asyncio.py:42
../../build/gradleenv/2050596098/lib/python3.10/site-packages/tenacity/_asyncio.py:42
../../build/gradleenv/2050596098/lib/python3.10/site-packages/tenacity/_asyncio.py:42
../../build/gradleenv/2050596098/lib/python3.10/site-packages/tenacity/_asyncio.py:42
../../build/gradleenv/2050596098/lib/python3.10/site-packages/tenacity/_asyncio.py:42
../../build/gradleenv/2050596098/lib/python3.10/site-packages/tenacity/_asyncio.py:42
../../build/gradleenv/2050596098/lib/python3.10/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

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

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

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

apache_beam/examples/wordcount_minimal_test.py: 7 warnings
apache_beam/examples/wordcount_debugging_test.py: 7 warnings
apache_beam/examples/wordcount_test.py: 7 warnings
apache_beam/examples/dataframe/flight_delays_it_test.py: 10 warnings
apache_beam/examples/complete/tfidf_it_test.py: 14 warnings
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 2 warnings
apache_beam/examples/complete/game/game_stats_it_test.py: 2 warnings
apache_beam/examples/cookbook/filters_test.py: 2 warnings
apache_beam/examples/cookbook/group_with_coder_test.py: 5 warnings
apache_beam/examples/cookbook/multiple_output_pardo_test.py: 11 warnings
apache_beam/examples/cookbook/mergecontacts_test.py: 13 warnings
apache_beam/examples/dataframe/wordcount_test.py: 7 warnings
apache_beam/examples/cookbook/custom_ptransform_it_test.py: 16 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/httplib2/__init__.py>:147: DeprecationWarning: ssl.PROTOCOL_TLS is deprecated
    context = ssl.SSLContext(DEFAULT_TLS_VERSION)

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = pcoll.pipeline.options.view_as(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    job_name = pcoll.pipeline.options.view_as(GoogleCloudOptions).job_name

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2511: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    pipeline_options=pcoll.pipeline.options,

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/examples/dataframe/flight_delays.py>:47: FutureWarning: The default value of numeric_only in DataFrame.mean is deprecated. In a future version, it will default to False. In addition, specifying 'numeric_only=None' is deprecated. Select only valid columns or specify the value of numeric_only to silence this warning.
    return airline_df[at_top_airports].mean()

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/dataframe/io.py>:659: FutureWarning: WriteToFiles is experimental.
    return pcoll | fileio.WriteToFiles(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/fileio.py>:591: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(GoogleCloudOptions).temp_location or

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    self.table_reference.projectId = pcoll.pipeline.options.view_as(

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/complete/game/game_stats_it_test.py::GameStatsIT::test_game_stats_it
apache_beam/examples/complete/game/game_stats_it_test.py::GameStatsIT::test_game_stats_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    is_streaming_pipeline = p.options.view_as(StandardOptions).streaming

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/complete/game/game_stats_it_test.py::GameStatsIT::test_game_stats_it
apache_beam/examples/complete/game/game_stats_it_test.py::GameStatsIT::test_game_stats_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    experiments = p.options.view_as(DebugOptions).experiments or []

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1166: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    self.project = self.project or p.options.view_as(GoogleCloudOptions).project

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1173: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = p.options.view_as(GoogleCloudOptions).temp_location

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1175: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(GoogleCloudOptions).job_name or 'AUTOMATIC_JOB_NAME')

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/tests/utils.py>:100: PendingDeprecationWarning: Client.dataset is deprecated and will be removed in a future version. Use a string like 'my_project.my_dataset' or a cloud.google.bigquery.DatasetReference object, instead.
    table_ref = client.dataset(dataset_id).table(table_id)

apache_beam/examples/complete/game/game_stats_it_test.py::GameStatsIT::test_game_stats_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/tests/utils.py>:63: PendingDeprecationWarning: Client.dataset is deprecated and will be removed in a future version. Use a string like 'my_project.my_dataset' or a cloud.google.bigquery.DatasetReference object, instead.
    dataset_ref = client.dataset(unique_dataset_name, project=project)

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/pytest_postCommitIT-df-py310-xdist.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/complete/game/leader_board_it_test.py::LeaderBoardIT::test_leader_board_it - google.api_core.exceptions.DeadlineExceeded: 504 Deadline Exceeded
====== 1 failed, 14 passed, 7 skipped, 185 warnings in 2988.24s (0:49:48) ======

> Task :sdks:python:test-suites:dataflow:py310:examples FAILED

FAILURE: Build failed with an exception.

* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 173

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

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

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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 51m 14s
15 actionable tasks: 9 executed, 4 from cache, 2 up-to-date

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

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_PostCommit_Python_Examples_Dataflow #1368

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/1368/display/redirect>


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


beam_PostCommit_Python_Examples_Dataflow - Build # 1367 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Python_Examples_Dataflow - Build # 1367 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/1367/ to view the results.

beam_PostCommit_Python_Examples_Dataflow - Build # 1366 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Python_Examples_Dataflow - Build # 1366 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/1366/ to view the results.

beam_PostCommit_Python_Examples_Dataflow - Build # 1365 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Python_Examples_Dataflow - Build # 1365 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/1365/ to view the results.

beam_PostCommit_Python_Examples_Dataflow - Build # 1364 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Python_Examples_Dataflow - Build # 1364 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/1364/ to view the results.

beam_PostCommit_Python_Examples_Dataflow - Build # 1363 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Python_Examples_Dataflow - Build # 1363 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/1363/ to view the results.

beam_PostCommit_Python_Examples_Dataflow - Build # 1362 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Python_Examples_Dataflow - Build # 1362 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/1362/ to view the results.

beam_PostCommit_Python_Examples_Dataflow - Build # 1361 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Python_Examples_Dataflow - Build # 1361 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/1361/ to view the results.

beam_PostCommit_Python_Examples_Dataflow - Build # 1360 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Python_Examples_Dataflow - Build # 1360 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/1360/ to view the results.

beam_PostCommit_Python_Examples_Dataflow - Build # 1359 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Python_Examples_Dataflow - Build # 1359 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/1359/ to view the results.

beam_PostCommit_Python_Examples_Dataflow - Build # 1358 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Python_Examples_Dataflow - Build # 1358 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/1358/ to view the results.

beam_PostCommit_Python_Examples_Dataflow - Build # 1357 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Python_Examples_Dataflow - Build # 1357 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/1357/ to view the results.

beam_PostCommit_Python_Examples_Dataflow - Build # 1356 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Python_Examples_Dataflow - Build # 1356 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/1356/ to view the results.

beam_PostCommit_Python_Examples_Dataflow - Build # 1355 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_Python_Examples_Dataflow - Build # 1355 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/1355/ to view the results.