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/28 00:27:32 UTC

Build failed in Jenkins: beam_PostCommit_Python_Examples_Direct #1417

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

Changes:

[Robert Bradshaw] Add some more links to the case studies page.

[byronellis] Add a bunch of convenience methods for nullable top level schema fields

[byronellis] Updated to use existing addNullableField vs doing it directly

[Robert Bradshaw] Log BatchElement statistics.

[noreply] [24469] Implement CsvIO.Write and supporting classes (#24630)


------------------------------------------
[...truncated 575.11 KB...]
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/ws/src/build/gradleenv/1398941893/lib/python3.9/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
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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)

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/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_Direct/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/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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_Direct/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/dataframe/flight_delays_it_test.py: 46 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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_Direct/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_Direct/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

-- 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_Direct/ws/src/sdks/python/pytest_postCommitExamples-direct-py39.xml> -
=== 22 passed, 7 skipped, 6789 deselected, 89 warnings in 211.63s (0:03:31) ====

> Task :sdks:python:test-suites:direct:py37:examples
INFO     apache_beam.io.fileio:fileio.py:696 Moving temporary files <map object at 0x7f6c5a76ce50> to dir: gs://temp-storage-for-end-to-end-tests/temp-it/flight_delays_it-6983192a-fb62-4ba3-9e1b-7dc132835f62 as ['output.csv-2012-12-24T00:00:00-2012-12-25T00:00:00-00000-of-00001']
INFO     apache_beam.io.fileio:fileio.py:696 Moving temporary files <map object at 0x7f6c5b52a7d0> to dir: gs://temp-storage-for-end-to-end-tests/temp-it/flight_delays_it-6983192a-fb62-4ba3-9e1b-7dc132835f62 as ['output.csv-2012-12-23T00:00:00-2012-12-24T00:00:00-00000-of-00001']
INFO     apache_beam.io.fileio:fileio.py:696 Moving temporary files <map object at 0x7f6c5a5eed10> to dir: gs://temp-storage-for-end-to-end-tests/temp-it/flight_delays_it-6983192a-fb62-4ba3-9e1b-7dc132835f62 as ['output.csv-2012-12-25T00:00:00-2012-12-26T00:00:00-00000-of-00001']
INFO     apache_beam.io.gcp.gcsio:gcsio.py:649 Finished listing 1 files in 0.04353046417236328 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:649 Finished listing 1 files in 0.035364389419555664 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:649 Finished listing 1 files in 0.033524274826049805 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:649 Finished listing 3 files in 0.043412208557128906 seconds.
PASSED                                                                   [ 95%]
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics 
-------------------------------- live log call ---------------------------------
INFO     root:transforms.py:182 Computing dataframe stage <ComputeStage(PTransform) label=[[ComputedExpression[set_column_DataFrame_140103365890448], ComputedExpression[set_index_DataFrame_140103365892048], ComputedExpression[pre_combine_sum_DataFrame_140103329211280]]:140103332332944]> for Stage[inputs={PlaceholderExpression[placeholder_DataFrame_140103367810000]}, partitioning=Arbitrary, ops=[ComputedExpression[set_column_DataFrame_140103365890448], ComputedExpression[set_index_DataFrame_140103365892048], ComputedExpression[pre_combine_sum_DataFrame_140103329211280]], outputs={ComputedExpression[pre_combine_sum_DataFrame_140103329211280], PlaceholderExpression[placeholder_DataFrame_140103367810000]}]
INFO     root:transforms.py:182 Computing dataframe stage <ComputeStage(PTransform) label=[[ComputedExpression[post_combine_sum_DataFrame_140103329213200]]:140103355953552]> for Stage[inputs={ComputedExpression[pre_combine_sum_DataFrame_140103329211280]}, partitioning=Index, ops=[ComputedExpression[post_combine_sum_DataFrame_140103329213200]], outputs={ComputedExpression[post_combine_sum_DataFrame_140103329213200]}]
INFO     apache_beam.io.fileio:fileio.py:596 Added temporary directory gs://temp-storage-for-end-to-end-tests/temp-it/.tempa2f0464e-c9d0-4e6b-b8e4-0ee8b37c767e
WARNING  apache_beam.options.pipeline_options:pipeline_options.py:356 Discarding unparseable args: ['--sleep_secs=20', '--kms_key_name=projects/apache-beam-testing/locations/global/keyRings/beam-it/cryptoKeys/test']
INFO     root:environments.py:376 Default Python SDK image for environment is apache/beam_python3.7_sdk:2.46.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function annotate_downstream_side_inputs at 0x7f6c7dd330e0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function fix_side_input_pcoll_coders at 0x7f6c7dd33200> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function pack_combiners at 0x7f6c7dd33710> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function lift_combiners at 0x7f6c7dd337a0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_sdf at 0x7f6c7dd33950> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_gbk at 0x7f6c7dd339e0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sink_flattens at 0x7f6c7dd33b00> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function greedily_fuse at 0x7f6c7dd33b90> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function read_to_impulse at 0x7f6c7dd33c20> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function impulse_to_input at 0x7f6c7dd33cb0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sort_stages at 0x7f6c7dd33ef0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function add_impulse_to_dangling_transforms at 0x7f6c7dd34050> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function setup_timer_mapping at 0x7f6c7dd33e60> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function populate_data_channel_coders at 0x7f6c7dd33f80> ====================
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 104857600
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:908 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.EmbeddedWorkerHandler object at 0x7f6c592de1d0> for environment ref_Environment_default_environment_1 (beam:env:embedded_python:v1, b'')
INFO     apache_beam.io.fileio:fileio.py:696 Moving temporary files <map object at 0x7f6c5b7c01d0> to dir: gs://temp-storage-for-end-to-end-tests/temp-it as ['da18b78b-93b9-49f9-a685-a306e829d6e4.result-00000-of-00001']
INFO     apache_beam.io.gcp.gcsio:gcsio.py:649 Finished listing 1 files in 0.05059075355529785 seconds.
PASSED                                                                   [100%]

=============================== warnings summary ===============================
../../build/gradleenv/1398941891/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/ws/src/build/gradleenv/1398941891/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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)

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

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_Direct/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/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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_Direct/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/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/ws/src/sdks/python/apache_beam/examples/dataframe/flight_delays.py>:47: FutureWarning: Dropping of nuisance columns in DataFrame reductions (with 'numeric_only=None') is deprecated; in a future version this will raise TypeError.  Select only valid columns before calling the reduction.
    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_Direct/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

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_Direct/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

-- 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_Direct/ws/src/sdks/python/pytest_postCommitExamples-direct-py37.xml> -
=== 22 passed, 7 skipped, 6789 deselected, 40 warnings in 216.33s (0:03:36) ====

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct: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

BUILD FAILED in 5m 2s
24 actionable tasks: 18 executed, 4 from cache, 2 up-to-date

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

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_Direct #1420

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


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


Build failed in Jenkins: beam_PostCommit_Python_Examples_Direct #1419

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

Changes:


------------------------------------------
[...truncated 574.11 KB...]
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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

-- 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_Direct/ws/src/sdks/python/pytest_postCommitExamples-direct-py39.xml> -
=== 22 passed, 7 skipped, 6789 deselected, 89 warnings in 212.41s (0:03:32) ====

> Task :sdks:python:test-suites:direct:py310:examples
INFO     apache_beam.io.gcp.gcsio:gcsio.py:644 Finished listing 1 files in 0.03579449653625488 seconds.
INFO     apache_beam.io.filebasedsink:filebasedsink.py:310 Starting finalize_write threads with num_shards: 1 (skipped: 0), batches: 1, num_threads: 1
INFO     apache_beam.io.filebasedsink:filebasedsink.py:357 Renamed 1 shards in 0.34 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:644 Finished listing 1 files in 0.04568815231323242 seconds.
INFO     apache_beam.io.filebasedsink:filebasedsink.py:310 Starting finalize_write threads with num_shards: 1 (skipped: 0), batches: 1, num_threads: 1
INFO     apache_beam.io.filebasedsink:filebasedsink.py:357 Renamed 1 shards in 0.33 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:644 Finished listing 1 files in 0.034928321838378906 seconds.
INFO     apache_beam.io.filebasedsink:filebasedsink.py:310 Starting finalize_write threads with num_shards: 1 (skipped: 0), batches: 1, num_threads: 1
INFO     apache_beam.io.filebasedsink:filebasedsink.py:357 Renamed 1 shards in 0.36 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:644 Finished listing 1 files in 0.041078805923461914 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:644 Finished listing 1 files in 0.03972315788269043 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:644 Finished listing 1 files in 0.04593920707702637 seconds.
PASSED                                                                   [ 91%]
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays 
-------------------------------- live log call ---------------------------------
INFO     root:transforms.py:182 Computing dataframe stage <ComputeStage(PTransform) label=[[ComputedExpression[move_grouped_columns_to_index_DataFrame_139862164840384]]:139862164839328]> for Stage[inputs={PlaceholderExpression[placeholder_DataFrame_139861900676160]}, partitioning=Arbitrary, ops=[ComputedExpression[move_grouped_columns_to_index_DataFrame_139862164840384]], outputs={ComputedExpression[move_grouped_columns_to_index_DataFrame_139862164840384], PlaceholderExpression[placeholder_DataFrame_139861900676160]}]
INFO     root:transforms.py:182 Computing dataframe stage <ComputeStage(PTransform) label=[[ComputedExpression[apply_DataFrame_139861900683552]]:139862164839760]> for Stage[inputs={ComputedExpression[move_grouped_columns_to_index_DataFrame_139862164840384]}, partitioning=Index['airline'], ops=[ComputedExpression[apply_DataFrame_139861900683552]], outputs={ComputedExpression[apply_DataFrame_139861900683552]}]
INFO     apache_beam.io.fileio:fileio.py:596 Added temporary directory gs://temp-storage-for-end-to-end-tests/temp-it/.temp5606353a-b94a-4fec-b6ce-c35ec6d52f13
WARNING  apache_beam.options.pipeline_options:pipeline_options.py:356 Discarding unparseable args: ['--sleep_secs=20', '--kms_key_name=projects/apache-beam-testing/locations/global/keyRings/beam-it/cryptoKeys/test']
INFO     root:environments.py:376 Default Python SDK image for environment is apache/beam_python3.10_sdk:2.46.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function annotate_downstream_side_inputs at 0x7f3484578af0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function fix_side_input_pcoll_coders at 0x7f3484578c10> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function pack_combiners at 0x7f3484579120> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function lift_combiners at 0x7f34845791b0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_sdf at 0x7f3484579360> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_gbk at 0x7f34845793f0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sink_flattens at 0x7f3484579510> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function greedily_fuse at 0x7f34845795a0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function read_to_impulse at 0x7f3484579630> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function impulse_to_input at 0x7f34845796c0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sort_stages at 0x7f3484579900> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function add_impulse_to_dangling_transforms at 0x7f3484579a20> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function setup_timer_mapping at 0x7f3484579870> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function populate_data_channel_coders at 0x7f3484579990> ====================
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 104857600
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.EmbeddedWorkerHandler object at 0x7f34383f7280> for environment ref_Environment_default_environment_1 (beam:env:embedded_python:v1, b'')
INFO     apache_beam.io.gcp.bigquery_tools:bigquery_tools.py:562 Started BigQuery job: <JobReference
 location: 'US'
 projectId: 'apache-beam-testing'>
 bq show -j --format=prettyjson --project_id=apache-beam-testing None
INFO     apache_beam.io.gcp.bigquery_tools:bigquery_tools.py:446 Using location 'US' from table <TableReference
 datasetId: 'airline_ontime_data'
 projectId: 'apache-beam-testing'
 tableId: 'flights'> referenced by query 
  SELECT
    FlightDate AS date,
    IATA_CODE_Reporting_Airline AS airline,
    Origin AS departure_airport,
    Dest AS arrival_airport,
    DepDelay AS departure_delay,
    ArrDelay AS arrival_delay
  FROM `apache-beam-testing.airline_ontime_data.flights`
  WHERE
    FlightDate >= '2012-12-23' AND FlightDate <= '2012-12-25' AND
    DepDelay IS NOT NULL AND ArrDelay IS NOT NULL
  
INFO     apache_beam.io.gcp.bigquery_tools:bigquery_tools.py:797 Dataset apache-beam-testing:beam_temp_dataset_b246c78c700f46e79a4283227093424f does not exist so we will create it as temporary with location=US
INFO     apache_beam.io.gcp.bigquery_tools:bigquery_tools.py:562 Started BigQuery job: <JobReference
 jobId: 'beam_bq_job_QUERY_BQ_EXPORT_JOB_e0f756be-0_1674908838_591'
 location: 'US'
 projectId: 'apache-beam-testing'>
 bq show -j --format=prettyjson --project_id=apache-beam-testing beam_bq_job_QUERY_BQ_EXPORT_JOB_e0f756be-0_1674908838_591
INFO     root:bigquery_tools.py:635 Job status: RUNNING
INFO     root:bigquery_tools.py:635 Job status: DONE
INFO     apache_beam.io.gcp.bigquery_tools:bigquery_tools.py:562 Started BigQuery job: <JobReference
 jobId: 'beam_bq_job_EXPORT_BQ_EXPORT_JOB_e0f756be-0_1674908843_972'
 location: 'US'
 projectId: 'apache-beam-testing'>
 bq show -j --format=prettyjson --project_id=apache-beam-testing beam_bq_job_EXPORT_BQ_EXPORT_JOB_e0f756be-0_1674908843_972
INFO     root:bigquery_tools.py:635 Job status: RUNNING
INFO     root:bigquery_tools.py:635 Job status: DONE
INFO     apache_beam.io.gcp.gcsio:gcsio.py:644 Finished listing 1 files in 0.051993370056152344 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:644 Finished listing 1 files in 0.14902305603027344 seconds.
INFO     apache_beam.io.fileio:fileio.py:692 Moving temporary files <map object at 0x7f3432f07220> to dir: gs://temp-storage-for-end-to-end-tests/temp-it/flight_delays_it-1c7d15a6-d9ea-43f4-9f62-0471aebb4cf7 as ['output.csv-2012-12-24T00:00:00-2012-12-25T00:00:00-00000-of-00001']
INFO     apache_beam.io.fileio:fileio.py:692 Moving temporary files <map object at 0x7f3432f07760> to dir: gs://temp-storage-for-end-to-end-tests/temp-it/flight_delays_it-1c7d15a6-d9ea-43f4-9f62-0471aebb4cf7 as ['output.csv-2012-12-25T00:00:00-2012-12-26T00:00:00-00000-of-00001']
INFO     apache_beam.io.fileio:fileio.py:692 Moving temporary files <map object at 0x7f3432f071c0> to dir: gs://temp-storage-for-end-to-end-tests/temp-it/flight_delays_it-1c7d15a6-d9ea-43f4-9f62-0471aebb4cf7 as ['output.csv-2012-12-23T00:00:00-2012-12-24T00:00:00-00000-of-00001']
INFO     apache_beam.io.gcp.gcsio:gcsio.py:644 Finished listing 1 files in 0.03015923500061035 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:644 Finished listing 1 files in 0.04271245002746582 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:644 Finished listing 1 files in 0.03865647315979004 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:644 Finished listing 3 files in 0.04556393623352051 seconds.
PASSED                                                                   [ 95%]
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics 
-------------------------------- live log call ---------------------------------
INFO     root:transforms.py:182 Computing dataframe stage <ComputeStage(PTransform) label=[[ComputedExpression[set_column_DataFrame_139862185655840], ComputedExpression[set_index_DataFrame_139862185645760], ComputedExpression[pre_combine_sum_DataFrame_139862261494400]]:139862261495888]> for Stage[inputs={PlaceholderExpression[placeholder_DataFrame_139862258662224]}, partitioning=Arbitrary, ops=[ComputedExpression[set_column_DataFrame_139862185655840], ComputedExpression[set_index_DataFrame_139862185645760], ComputedExpression[pre_combine_sum_DataFrame_139862261494400]], outputs={PlaceholderExpression[placeholder_DataFrame_139862258662224], ComputedExpression[pre_combine_sum_DataFrame_139862261494400]}]
INFO     root:transforms.py:182 Computing dataframe stage <ComputeStage(PTransform) label=[[ComputedExpression[post_combine_sum_DataFrame_139862261485376]]:139862261490512]> for Stage[inputs={ComputedExpression[pre_combine_sum_DataFrame_139862261494400]}, partitioning=Index, ops=[ComputedExpression[post_combine_sum_DataFrame_139862261485376]], outputs={ComputedExpression[post_combine_sum_DataFrame_139862261485376]}]
INFO     apache_beam.io.fileio:fileio.py:596 Added temporary directory gs://temp-storage-for-end-to-end-tests/temp-it/.temp92f1400e-0e04-4ca3-aaab-a23d2056b806
WARNING  apache_beam.options.pipeline_options:pipeline_options.py:356 Discarding unparseable args: ['--sleep_secs=20', '--kms_key_name=projects/apache-beam-testing/locations/global/keyRings/beam-it/cryptoKeys/test']
INFO     root:environments.py:376 Default Python SDK image for environment is apache/beam_python3.10_sdk:2.46.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function annotate_downstream_side_inputs at 0x7f3484578af0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function fix_side_input_pcoll_coders at 0x7f3484578c10> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function pack_combiners at 0x7f3484579120> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function lift_combiners at 0x7f34845791b0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_sdf at 0x7f3484579360> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_gbk at 0x7f34845793f0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sink_flattens at 0x7f3484579510> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function greedily_fuse at 0x7f34845795a0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function read_to_impulse at 0x7f3484579630> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function impulse_to_input at 0x7f34845796c0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sort_stages at 0x7f3484579900> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function add_impulse_to_dangling_transforms at 0x7f3484579a20> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function setup_timer_mapping at 0x7f3484579870> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function populate_data_channel_coders at 0x7f3484579990> ====================
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 104857600
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.EmbeddedWorkerHandler object at 0x7f3433e4a3e0> for environment ref_Environment_default_environment_1 (beam:env:embedded_python:v1, b'')
INFO     apache_beam.io.fileio:fileio.py:692 Moving temporary files <map object at 0x7f3433ced3f0> to dir: gs://temp-storage-for-end-to-end-tests/temp-it as ['cb1c1c84-e25d-44d6-a126-842d528035df.result-00000-of-00001']
INFO     apache_beam.io.gcp.gcsio:gcsio.py:644 Finished listing 1 files in 0.050057411193847656 seconds.
PASSED                                                                   [100%]

=============================== warnings summary ===============================
../../build/gradleenv/417525523/lib/python3.10/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/ws/src/build/gradleenv/417525523/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/417525523/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_Direct/ws/src/build/gradleenv/417525523/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/417525523/lib/python3.10/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/ws/src/build/gradleenv/417525523/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
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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)

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/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_Direct/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/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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_Direct/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/dataframe/flight_delays_it_test.py: 46 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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_Direct/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_Direct/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

-- 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_Direct/ws/src/sdks/python/pytest_postCommitExamples-direct-py310.xml> -
=== 22 passed, 7 skipped, 6789 deselected, 90 warnings in 223.68s (0:03:43) ====

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:py37: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

BUILD FAILED in 5m 17s
24 actionable tasks: 18 executed, 4 from cache, 2 up-to-date

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

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

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


Build failed in Jenkins: beam_PostCommit_Python_Examples_Direct #1418

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/1418/display/redirect?page=changes>

Changes:

[noreply] Implement mongodbio.Read with an SDF (#25160)

[Robert Bradshaw] Fix website.


------------------------------------------
[...truncated 574.65 KB...]
    def call(self, fn, *args, **kwargs):

apache_beam/typehints/pandas_type_compatibility_test.py:67
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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)

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/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_Direct/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/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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_Direct/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/dataframe/flight_delays_it_test.py: 46 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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_Direct/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_Direct/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

-- 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_Direct/ws/src/sdks/python/pytest_postCommitExamples-direct-py39.xml> -
=== 22 passed, 7 skipped, 6789 deselected, 89 warnings in 223.45s (0:03:43) ====

> Task :sdks:python:test-suites:direct:py37:examples
INFO     apache_beam.io.gcp.gcsio:gcsio.py:649 Finished listing 1 files in 0.05919361114501953 seconds.
INFO     apache_beam.io.fileio:fileio.py:696 Moving temporary files <map object at 0x7fc06dc6cc50> to dir: gs://temp-storage-for-end-to-end-tests/temp-it/flight_delays_it-1d9fb0ff-f79e-47fa-b2b5-29c2cf65b241 as ['output.csv-2012-12-24T00:00:00-2012-12-25T00:00:00-00000-of-00001']
INFO     apache_beam.io.fileio:fileio.py:696 Moving temporary files <map object at 0x7fc06dc6c690> to dir: gs://temp-storage-for-end-to-end-tests/temp-it/flight_delays_it-1d9fb0ff-f79e-47fa-b2b5-29c2cf65b241 as ['output.csv-2012-12-25T00:00:00-2012-12-26T00:00:00-00000-of-00001']
INFO     apache_beam.io.fileio:fileio.py:696 Moving temporary files <map object at 0x7fc06db71690> to dir: gs://temp-storage-for-end-to-end-tests/temp-it/flight_delays_it-1d9fb0ff-f79e-47fa-b2b5-29c2cf65b241 as ['output.csv-2012-12-23T00:00:00-2012-12-24T00:00:00-00000-of-00001']
INFO     apache_beam.io.gcp.gcsio:gcsio.py:649 Finished listing 1 files in 0.10628700256347656 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:649 Finished listing 1 files in 0.04381060600280762 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:649 Finished listing 1 files in 0.04073023796081543 seconds.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:649 Finished listing 3 files in 0.03511476516723633 seconds.
PASSED                                                                   [ 95%]
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics 
-------------------------------- live log call ---------------------------------
INFO     root:transforms.py:182 Computing dataframe stage <ComputeStage(PTransform) label=[[ComputedExpression[set_column_DataFrame_140464212698128], ComputedExpression[set_index_DataFrame_140464212700176], ComputedExpression[pre_combine_sum_DataFrame_140464445227408]]:140464452373008]> for Stage[inputs={PlaceholderExpression[placeholder_DataFrame_140464462387920]}, partitioning=Arbitrary, ops=[ComputedExpression[set_column_DataFrame_140464212698128], ComputedExpression[set_index_DataFrame_140464212700176], ComputedExpression[pre_combine_sum_DataFrame_140464445227408]], outputs={ComputedExpression[pre_combine_sum_DataFrame_140464445227408], PlaceholderExpression[placeholder_DataFrame_140464462387920]}]
INFO     root:transforms.py:182 Computing dataframe stage <ComputeStage(PTransform) label=[[ComputedExpression[post_combine_sum_DataFrame_140464445228560]]:140464447304720]> for Stage[inputs={ComputedExpression[pre_combine_sum_DataFrame_140464445227408]}, partitioning=Index, ops=[ComputedExpression[post_combine_sum_DataFrame_140464445228560]], outputs={ComputedExpression[post_combine_sum_DataFrame_140464445228560]}]
INFO     apache_beam.io.fileio:fileio.py:596 Added temporary directory gs://temp-storage-for-end-to-end-tests/temp-it/.tempf931c038-6773-4b66-9d67-3da83b6b36b6
WARNING  apache_beam.options.pipeline_options:pipeline_options.py:356 Discarding unparseable args: ['--sleep_secs=20', '--kms_key_name=projects/apache-beam-testing/locations/global/keyRings/beam-it/cryptoKeys/test']
INFO     root:environments.py:376 Default Python SDK image for environment is apache/beam_python3.7_sdk:2.46.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function annotate_downstream_side_inputs at 0x7fc082e740e0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function fix_side_input_pcoll_coders at 0x7fc082e74200> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function pack_combiners at 0x7fc082e74710> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function lift_combiners at 0x7fc082e747a0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_sdf at 0x7fc082e74950> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_gbk at 0x7fc082e749e0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sink_flattens at 0x7fc082e74b00> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function greedily_fuse at 0x7fc082e74b90> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function read_to_impulse at 0x7fc082e74c20> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function impulse_to_input at 0x7fc082e74cb0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sort_stages at 0x7fc082e74ef0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function add_impulse_to_dangling_transforms at 0x7fc082e77050> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function setup_timer_mapping at 0x7fc082e74e60> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function populate_data_channel_coders at 0x7fc082e74f80> ====================
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 104857600
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:908 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.EmbeddedWorkerHandler object at 0x7fc06d8d7790> for environment ref_Environment_default_environment_1 (beam:env:embedded_python:v1, b'')
INFO     apache_beam.io.fileio:fileio.py:696 Moving temporary files <map object at 0x7fc06c5abd10> to dir: gs://temp-storage-for-end-to-end-tests/temp-it as ['4ac27831-d405-44ee-8ba8-59ea7eeb27b9.result-00000-of-00001']
INFO     apache_beam.io.gcp.gcsio:gcsio.py:649 Finished listing 1 files in 0.04865527153015137 seconds.
PASSED                                                                   [100%]

=============================== warnings summary ===============================
../../build/gradleenv/1398941891/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/ws/src/build/gradleenv/1398941891/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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)

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
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_Direct/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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
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
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

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_Direct/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/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/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_Direct/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/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Direct/ws/src/sdks/python/apache_beam/examples/dataframe/flight_delays.py>:47: FutureWarning: Dropping of nuisance columns in DataFrame reductions (with 'numeric_only=None') is deprecated; in a future version this will raise TypeError.  Select only valid columns before calling the reduction.
    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_Direct/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

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_Direct/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

-- 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_Direct/ws/src/sdks/python/pytest_postCommitExamples-direct-py37.xml> -
=== 22 passed, 7 skipped, 6789 deselected, 40 warnings in 228.16s (0:03:48) ====

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct: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

BUILD FAILED in 5m 26s
24 actionable tasks: 18 executed, 4 from cache, 2 up-to-date

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

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