See <https://ci-beam.apache.org/job/beam_PostCommit_Python38/1473/display/redirect>
Changes: ------------------------------------------ [...truncated 23.16 MB...] INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:31:00.133Z: JOB_MESSAGE_DEBUG: Executing wait step start13 INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:31:00.181Z: JOB_MESSAGE_BASIC: Executing operation GroupByKey/Create INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:31:00.228Z: JOB_MESSAGE_DEBUG: Starting worker pool setup. INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:31:00.249Z: JOB_MESSAGE_BASIC: Starting 1 workers in us-central1-a... INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:31:00.757Z: JOB_MESSAGE_BASIC: Finished operation GroupByKey/Create INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:31:00.831Z: JOB_MESSAGE_DEBUG: Value "GroupByKey/Session" materialized. INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:31:00.942Z: JOB_MESSAGE_BASIC: Executing operation Create/Read+metrics+map_to_common_key+GroupByKey/Reify+GroupByKey/Write INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:31:08.828Z: JOB_MESSAGE_BASIC: Your project already contains 100 Dataflow-created metric descriptors, so new user metrics of the form custom.googleapis.com/* will not be created. However, all user metrics are also available in the metric dataflow.googleapis.com/job/user_counter. If you rely on the custom metrics, you can delete old / unused metric descriptors. See https://developers.google.com/apis-explorer/#p/monitoring/v3/monitoring.projects.metricDescriptors.list and https://developers.google.com/apis-explorer/#p/monitoring/v3/monitoring.projects.metricDescriptors.delete INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:31:42.462Z: JOB_MESSAGE_DETAILED: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running stage(s). INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:32:06.967Z: JOB_MESSAGE_DETAILED: Workers have started successfully. INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:32:07.002Z: JOB_MESSAGE_DETAILED: Workers have started successfully. INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:32:19.361Z: JOB_MESSAGE_DETAILED: Autoscaling: Resized worker pool from 1 to 0. INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:32:19.402Z: JOB_MESSAGE_BASIC: Worker pool stopped. INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:32:19.442Z: JOB_MESSAGE_DEBUG: Tearing down pending resources... INFO:apache_beam.runners.dataflow.dataflow_runner:Job 2021-07-24_18_23_45-18099532356155480085 is in state JOB_STATE_DONE INFO:apache_beam.io.gcp.tests.bigquery_matcher:Attempting to perform query SELECT bytes, date, time FROM python_write_to_table_16271762117390.python_no_schema_table to BQ DEBUG:google.auth._default:Checking None for explicit credentials as part of auth process... DEBUG:google.auth._default:Checking Cloud SDK credentials as part of auth process... DEBUG:google.auth._default:Cloud SDK credentials not found on disk; not using them DEBUG:google.auth._default:Checking for App Engine runtime as part of auth process... DEBUG:google.auth._default:No App Engine library was found so cannot authentication via App Engine Identity Credentials. DEBUG:google.auth.transport._http_client:Making request: GET http://169.254.169.254 DEBUG:google.auth.transport._http_client:Making request: GET http://metadata.google.internal/computeMetadata/v1/project/project-id DEBUG:urllib3.util.retry:Converted retries value: 3 -> Retry(total=3, connect=None, read=None, redirect=None, status=None) DEBUG:google.auth.transport.requests:Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/default/?recursive=true DEBUG:urllib3.connectionpool:Starting new HTTP connection (1): metadata.google.internal:80 DEBUG:urllib3.connectionpool:http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/default/?recursive=true HTTP/1.1" 200 144 DEBUG:google.auth.transport.requests:Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/[email protected]/token?scopes=https%3A%2F%2Fwww.googleapis.com%2Fauth%2Fbigquery%2Chttps%3A%2F%2Fwww.googleapis.com%2Fauth%2Fcloud-platform DEBUG:urllib3.connectionpool:http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/[email protected]/token?scopes=https%3A%2F%2Fwww.googleapis.com%2Fauth%2Fbigquery%2Chttps%3A%2F%2Fwww.googleapis.com%2Fauth%2Fcloud-platform HTTP/1.1" 200 244 DEBUG:urllib3.connectionpool:Starting new HTTPS connection (1): bigquery.googleapis.com:443 DEBUG:urllib3.connectionpool:https://bigquery.googleapis.com:443 "POST /bigquery/v2/projects/apache-beam-testing/jobs?prettyPrint=false HTTP/1.1" 200 None DEBUG:urllib3.connectionpool:https://bigquery.googleapis.com:443 "GET /bigquery/v2/projects/apache-beam-testing/queries/1e86cf78-da8c-4e76-ace6-8d38bd9f264d?maxResults=0&timeoutMs=10000&location=US&prettyPrint=false HTTP/1.1" 200 None DEBUG:urllib3.connectionpool:https://bigquery.googleapis.com:443 "GET /bigquery/v2/projects/apache-beam-testing/queries/1e86cf78-da8c-4e76-ace6-8d38bd9f264d?fields=jobReference%2CtotalRows%2CpageToken%2Crows&location=US&formatOptions.useInt64Timestamp=True&prettyPrint=false HTTP/1.1" 200 None INFO:apache_beam.io.gcp.tests.bigquery_matcher:Result of query is: [(b'\xe4\xbd\xa0\xe5\xa5\xbd', datetime.date(3000, 12, 31), datetime.time(23, 59, 59)), (b'xyw', datetime.date(2011, 1, 1), datetime.time(23, 59, 59, 999999)), (b'abc', datetime.date(2000, 1, 1), datetime.time(0, 0)), (b'\xab\xac\xad', datetime.date(2000, 1, 1), datetime.time(0, 0))] INFO:apache_beam.io.gcp.bigquery_write_it_test:Deleting dataset python_write_to_table_16271762117390 in project apache-beam-testing INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:34:53.504Z: JOB_MESSAGE_BASIC: Finished operation Create data/Read+Predict UserEvent/ParDo(_PredictUserEventFn)+ParDo(CallableWrapperDoFn)+assert_that/WindowInto(WindowIntoFn)+assert_that/ToVoidKey+assert_that/Group/_CoGBKImpl/Tag[1]+assert_that/Group/_CoGBKImpl/GroupByKey/Reify+assert_that/Group/_CoGBKImpl/GroupByKey/Write INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:34:55.357Z: JOB_MESSAGE_BASIC: Finished operation assert_that/Create/Read+assert_that/Group/_CoGBKImpl/Tag[0]+assert_that/Group/_CoGBKImpl/GroupByKey/Reify+assert_that/Group/_CoGBKImpl/GroupByKey/Write INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:34:55.450Z: JOB_MESSAGE_BASIC: Executing operation assert_that/Group/_CoGBKImpl/GroupByKey/Close INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:34:55.510Z: JOB_MESSAGE_BASIC: Finished operation assert_that/Group/_CoGBKImpl/GroupByKey/Close INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:34:55.579Z: JOB_MESSAGE_BASIC: Executing operation assert_that/Group/_CoGBKImpl/GroupByKey/Read+assert_that/Group/_CoGBKImpl/GroupByKey/GroupByWindow+assert_that/Group/_CoGBKImpl/MapTuple(collect_values)+assert_that/Group/RestoreTags+assert_that/Unkey+assert_that/Match INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:35:00.028Z: JOB_MESSAGE_BASIC: Finished operation assert_that/Group/_CoGBKImpl/GroupByKey/Read+assert_that/Group/_CoGBKImpl/GroupByKey/GroupByWindow+assert_that/Group/_CoGBKImpl/MapTuple(collect_values)+assert_that/Group/RestoreTags+assert_that/Unkey+assert_that/Match INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:35:00.087Z: JOB_MESSAGE_DEBUG: Executing success step success19 INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:35:00.168Z: JOB_MESSAGE_DETAILED: Cleaning up. INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:35:00.223Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown. INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:35:00.253Z: JOB_MESSAGE_BASIC: Stopping worker pool... INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:36:31.554Z: JOB_MESSAGE_BASIC: Finished operation Create/Read+metrics+map_to_common_key+GroupByKey/Reify+GroupByKey/Write INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:36:31.618Z: JOB_MESSAGE_BASIC: Executing operation GroupByKey/Close INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:36:31.676Z: JOB_MESSAGE_BASIC: Finished operation GroupByKey/Close INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:36:31.749Z: JOB_MESSAGE_BASIC: Executing operation GroupByKey/Read+GroupByKey/GroupByWindow+m_out INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:36:36.122Z: JOB_MESSAGE_BASIC: Finished operation GroupByKey/Read+GroupByKey/GroupByWindow+m_out INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:36:36.203Z: JOB_MESSAGE_DEBUG: Executing success step success11 INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:36:36.268Z: JOB_MESSAGE_DETAILED: Cleaning up. INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:36:36.319Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown. INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:36:36.351Z: JOB_MESSAGE_BASIC: Stopping worker pool... INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:37:11.983Z: JOB_MESSAGE_DETAILED: Autoscaling: Resized worker pool from 1 to 0. INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:37:12.016Z: JOB_MESSAGE_BASIC: Worker pool stopped. INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:37:12.047Z: JOB_MESSAGE_DEBUG: Tearing down pending resources... INFO:apache_beam.runners.dataflow.dataflow_runner:Job 2021-07-24_18_29_22-6566296019455520862 is in state JOB_STATE_DONE INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:38:52.399Z: JOB_MESSAGE_DETAILED: Autoscaling: Resized worker pool from 1 to 0. INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:38:52.446Z: JOB_MESSAGE_BASIC: Worker pool stopped. INFO:apache_beam.runners.dataflow.dataflow_runner:2021-07-25T01:38:52.481Z: JOB_MESSAGE_DEBUG: Tearing down pending resources... INFO:apache_beam.runners.dataflow.dataflow_runner:Job 2021-07-24_18_30_52-15392854720641582841 is in state JOB_STATE_DONE test_autocomplete_it (apache_beam.examples.complete.autocomplete_test.AutocompleteTest) ... ok test_bigquery_tornadoes_it (apache_beam.examples.cookbook.bigquery_tornadoes_it_test.BigqueryTornadoesIT) ... ok test_datastore_wordcount_it (apache_beam.examples.cookbook.datastore_wordcount_it_test.DatastoreWordCountIT) ... ok test_run_example_with_setup_file (apache_beam.examples.complete.juliaset.juliaset.juliaset_test_it.JuliaSetTestIT) ... ok test_streaming_wordcount_debugging_it (apache_beam.examples.streaming_wordcount_debugging_it_test.StreamingWordcountDebuggingIT) ... SKIP: Skipped due to [BEAM-3377]: assert_that not working for streaming test_leader_board_it (apache_beam.examples.complete.game.leader_board_it_test.LeaderBoardIT) ... ok test_game_stats_it (apache_beam.examples.complete.game.game_stats_it_test.GameStatsIT) ... ok test_flight_delays (apache_beam.examples.dataframe.flight_delays_it_test.FlightDelaysTest) ... ok test_user_score_it (apache_beam.examples.complete.game.user_score_it_test.UserScoreIT) ... ok test_hourly_team_score_it (apache_beam.examples.complete.game.hourly_team_score_it_test.HourlyTeamScoreIT) ... ok test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT) ... ok test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ok test_wordcount_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ok test_avro_it (apache_beam.examples.fastavro_it_test.FastavroIT) ... ok test_read_via_sql (apache_beam.io.gcp.experimental.spannerio_read_it_test.SpannerReadIntegrationTest) ... ok test_read_via_table (apache_beam.io.gcp.experimental.spannerio_read_it_test.SpannerReadIntegrationTest) ... ok test_read_queries (apache_beam.io.gcp.bigquery_read_it_test.ReadAllBQTests) ... ok test_bigquery_read_1M_python (apache_beam.io.gcp.bigquery_io_read_it_test.BigqueryIOReadIT) ... ok test_bigquery_read_custom_1M_python (apache_beam.io.gcp.bigquery_io_read_it_test.BigqueryIOReadIT) ... ok test_spanner_error (apache_beam.io.gcp.experimental.spannerio_write_it_test.SpannerWriteIntegrationTest) ... ok test_spanner_update (apache_beam.io.gcp.experimental.spannerio_write_it_test.SpannerWriteIntegrationTest) ... ok test_write_batches (apache_beam.io.gcp.experimental.spannerio_write_it_test.SpannerWriteIntegrationTest) ... ok test_bqfl_streaming (apache_beam.io.gcp.bigquery_file_loads_test.BigQueryFileLoadsIT) ... SKIP: TestStream is not supported on TestDataflowRunner test_multiple_destinations_transform (apache_beam.io.gcp.bigquery_file_loads_test.BigQueryFileLoadsIT) ... ok test_one_job_fails_all_jobs_fail (apache_beam.io.gcp.bigquery_file_loads_test.BigQueryFileLoadsIT) ... ok test_aggregation (apache_beam.examples.dataframe.taxiride_it_test.TaxirideIT) ... ok test_enrich (apache_beam.examples.dataframe.taxiride_it_test.TaxirideIT) ... ok test_multiple_destinations_transform (apache_beam.io.gcp.bigquery_test.BigQueryStreamingInsertTransformIntegrationTests) ... ok test_iobase_source (apache_beam.io.gcp.bigquery_read_it_test.ReadNewTypesTests) ... ok test_native_source (apache_beam.io.gcp.bigquery_read_it_test.ReadNewTypesTests) ... ok test_avro_file_load (apache_beam.io.gcp.bigquery_test.BigQueryFileLoadsIntegrationTests) ... ok test_copy (apache_beam.io.gcp.gcsio_integration_test.GcsIOIntegrationTest) ... ok test_copy_batch (apache_beam.io.gcp.gcsio_integration_test.GcsIOIntegrationTest) ... ok test_copy_batch_kms (apache_beam.io.gcp.gcsio_integration_test.GcsIOIntegrationTest) ... ok test_copy_batch_rewrite_token (apache_beam.io.gcp.gcsio_integration_test.GcsIOIntegrationTest) ... SKIP: BEAM-12352: enable once maxBytesRewrittenPerCall works again test_copy_kms (apache_beam.io.gcp.gcsio_integration_test.GcsIOIntegrationTest) ... ok test_copy_rewrite_token (apache_beam.io.gcp.gcsio_integration_test.GcsIOIntegrationTest) ... SKIP: BEAM-12352: enable once maxBytesRewrittenPerCall works again test_value_provider_transform (apache_beam.io.gcp.bigquery_test.BigQueryStreamingInsertTransformIntegrationTests) ... ok test_iobase_source (apache_beam.io.gcp.bigquery_read_it_test.ReadTests) ... ok test_native_source (apache_beam.io.gcp.bigquery_read_it_test.ReadTests) ... ok test_transform_on_gcs (apache_beam.io.fileio_test.MatchIntegrationTest) ... ok test_datastore_write_limit (apache_beam.io.gcp.datastore.v1new.datastore_write_it_test.DatastoreWriteIT) ... ok test_parquetio_it (apache_beam.io.parquetio_it_test.TestParquetIT) ... ok test_dicom_search_instances (apache_beam.io.gcp.dicomio_integration_test.DICOMIoIntegrationTest) ... ok test_dicom_store_instance_from_gcs (apache_beam.io.gcp.dicomio_integration_test.DICOMIoIntegrationTest) ... ok test_streaming_data_only (apache_beam.io.gcp.pubsub_integration_test.PubSubIntegrationTest) ... ok test_streaming_with_attributes (apache_beam.io.gcp.pubsub_integration_test.PubSubIntegrationTest) ... ok test_analyzing_syntax (apache_beam.ml.gcp.naturallanguageml_test_it.NaturalLanguageMlTestIT) ... ok test_big_query_legacy_sql (apache_beam.io.gcp.big_query_query_to_table_it_test.BigQueryQueryToTableIT) ... ok test_big_query_new_types (apache_beam.io.gcp.big_query_query_to_table_it_test.BigQueryQueryToTableIT) ... ok test_big_query_new_types_avro (apache_beam.io.gcp.big_query_query_to_table_it_test.BigQueryQueryToTableIT) ... ok test_big_query_new_types_native (apache_beam.io.gcp.big_query_query_to_table_it_test.BigQueryQueryToTableIT) ... ok test_big_query_standard_sql (apache_beam.io.gcp.big_query_query_to_table_it_test.BigQueryQueryToTableIT) ... ok test_big_query_standard_sql_kms_key_native (apache_beam.io.gcp.big_query_query_to_table_it_test.BigQueryQueryToTableIT) ... ok test_label_detection_with_video_context (apache_beam.ml.gcp.videointelligenceml_test_it.VideoIntelligenceMlTestIT) ... ok test_basic_execution (apache_beam.testing.test_stream_it_test.TestStreamIntegrationTests) ... SKIP: The "TestDataflowRunner", does not support the TestStream transform. Supported runners: ['DirectRunner', 'SwitchingDirectRunner'] Tests that the TestStream supports emitting to multiple PCollections. ... SKIP: The "TestDataflowRunner", does not support the TestStream transform. Supported runners: ['DirectRunner', 'SwitchingDirectRunner'] Tests that the TestStream can independently control output watermarks. ... SKIP: The "TestDataflowRunner", does not support the TestStream transform. Supported runners: ['DirectRunner', 'SwitchingDirectRunner'] test_deidentification (apache_beam.ml.gcp.cloud_dlp_it_test.CloudDLPIT) ... ok test_inspection (apache_beam.ml.gcp.cloud_dlp_it_test.CloudDLPIT) ... ok test_text_detection_with_language_hint (apache_beam.ml.gcp.visionml_test_it.VisionMlTestIT) ... ok test_job_python_from_python_it (apache_beam.transforms.external_it_test.ExternalTransformIT) ... ok test_file_loads (apache_beam.io.gcp.bigquery_test.PubSubBigQueryIT) ... ok test_streaming_inserts (apache_beam.io.gcp.bigquery_test.PubSubBigQueryIT) ... ok test_big_query_write (apache_beam.io.gcp.bigquery_write_it_test.BigQueryWriteIntegrationTests) ... ok test_big_query_write_new_types (apache_beam.io.gcp.bigquery_write_it_test.BigQueryWriteIntegrationTests) ... ok test_big_query_write_schema_autodetect (apache_beam.io.gcp.bigquery_write_it_test.BigQueryWriteIntegrationTests) ... SKIP: DataflowRunner does not support schema autodetection Test that schema update options are respected when appending to an existing ... ok test_big_query_write_without_schema (apache_beam.io.gcp.bigquery_write_it_test.BigQueryWriteIntegrationTests) ... ok test_create_catalog_item (apache_beam.ml.gcp.recommendations_ai_test_it.RecommendationAIIT) ... ok test_create_user_event (apache_beam.ml.gcp.recommendations_ai_test_it.RecommendationAIIT) ... ok test_predict (apache_beam.ml.gcp.recommendations_ai_test_it.RecommendationAIIT) ... ok test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest) ... ok test_metrics_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest) ... ok ---------------------------------------------------------------------- XML: nosetests-postCommitIT-df-py38.xmlWorker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_05_01-1498890087079504460?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_20_33-1899168264825279053?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_29_37-14983505798657549017?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_38_37-12806671676485261394?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_47_50-929057579611018751?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_57_03-13124620490640481216?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_06_36-7900781873394427286?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_15_49-6966689114711207812?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_04_49-5282295075012325625?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_22_21-3131902876366565103?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_30_39-5991567804886998282?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_39_26-12101901704739076830?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_48_12-5189774660915224880?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_56_51-4588733780916953831?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_05_30-16520150455238197082?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_13_51-14485858518997166633?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_04_59-2220012860547018578?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_23_55-13226974277258996338?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_32_08-17803516105227836437?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_40_08-11569133435921736947?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_48_05-776817157502026684?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_56_40-13668412805218261101?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_05_47-14451582484581575202?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_14_34-15155804284220611116?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_23_45-18099532356155480085?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_07_23-11170060297325248732?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_16_44-6096047091733232043?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_27_13-8004415467806365084?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_36_07-15055166049371433780?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_45_10-17976193679216361394?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_54_30-14563010944193249019?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_03_28-14913004732635863077?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_12_33-17892408264287181170?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_21_13-12860110620281336157?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_04_57-16548176295673629773?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_17_56-18125735947704286207?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_29_41-4290940119064240465?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_39_41-3521281605068062094?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_49_00-15236253134484479735?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_58_02-5152149579765019972?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_07_06-14062634697075869985?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_15_24-17981165806735199625?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_04_50-11616468757159276179?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_13_35-16733162118348941810?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_22_11-11424571760209740689?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_30_25-10706697680727464684?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_38_51-18119582941431298859?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_47_27-14068226721210731173?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_03_43-12523462818394567339?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_12_16-8941965086716667646?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_20_54-7302115986186973823?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_30_52-15392854720641582841?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_05_00-16632930336246784183?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_13_55-9120267119357974295?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_28_18-4300904085955279533?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_54_34-15824985295255613893?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_13_04-1902055676381414626?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_04_53-12391017823035992586?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_14_08-5447362289023566120?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_24_13-6921621771367775761?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_34_45-11603793242070852087?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_46_06-7911118729046094463?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_17_54_57-14686858761737592029?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_03_37-12795872806773439668?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_12_20-17736673715890363397?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_20_54-17791335699233783897?project=apache-beam-testing Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2021-07-24_18_29_22-6566296019455520862?project=apache-beam-testing ---------------------------------------------------------------------- XML: <https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/sdks/python/nosetests.xml> ---------------------------------------------------------------------- Ran 74 tests in 5687.879s OK (SKIP=8) FAILURE: Build completed with 2 failures. 1: Task failed with an exception. ----------- * What went wrong: Execution failed for task ':release:go-licenses:py:docker'. > Process 'command 'docker'' finished with non-zero exit value 1 * Try: Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights. ============================================================================== 2: Task failed with an exception. ----------- * What went wrong: Execution failed for task ':release:go-licenses:java:docker'. > Process 'command 'docker'' finished with non-zero exit value 1 * Try: Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights. ============================================================================== * Get more help at https://help.gradle.org Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0. Use '--warning-mode all' to show the individual deprecation warnings. See https://docs.gradle.org/6.8.3/userguide/command_line_interface.html#sec:command_line_warnings BUILD FAILED in 1h 38m 37s 207 actionable tasks: 144 executed, 59 from cache, 4 up-to-date Publishing build scan... https://gradle.com/s/hjz5nih6r4goa Build step 'Invoke Gradle script' changed build result to FAILURE Build step 'Invoke Gradle script' marked build as failure --------------------------------------------------------------------- To unsubscribe, e-mail: [email protected] For additional commands, e-mail: [email protected]
