See 
<https://ci-beam.apache.org/job/beam_PostCommit_Python36/4049/display/redirect>

Changes:


------------------------------------------
[...truncated 47.01 MB...]
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/be6f33cf-dcc9-4002-ae23-b2f83892dc60?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/be6f33cf-dcc9-4002-ae23-b2f83892dc60?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'xyw', 
datetime.date(2011, 1, 1), datetime.time(23, 59, 59, 999999)), 
(b'\xab\xac\xad', datetime.date(2000, 1, 1), datetime.time(0, 0)), (b'abc', 
datetime.date(2000, 1, 1), datetime.time(0, 0)), (b'\xe4\xbd\xa0\xe5\xa5\xbd', 
datetime.date(3000, 12, 31), datetime.time(23, 59, 59))]
INFO:apache_beam.io.gcp.bigquery_write_it_test:Deleting dataset 
python_write_to_table_16249730466241 in project apache-beam-testing
test_datastore_wordcount_it 
(apache_beam.examples.cookbook.datastore_wordcount_it_test.DatastoreWordCountIT)
 ... ERROR
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_leader_board_it 
(apache_beam.examples.complete.game.leader_board_it_test.LeaderBoardIT) ... 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_run_example_with_setup_file 
(apache_beam.examples.complete.juliaset.juliaset.juliaset_test_it.JuliaSetTestIT)
 ... ok
test_flight_delays 
(apache_beam.examples.dataframe.flight_delays_it_test.FlightDelaysTest) ... ok
test_game_stats_it 
(apache_beam.examples.complete.game.game_stats_it_test.GameStatsIT) ... ok
test_user_score_it 
(apache_beam.examples.complete.game.user_score_it_test.UserScoreIT) ... 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_hourly_team_score_it 
(apache_beam.examples.complete.game.hourly_team_score_it_test.HourlyTeamScoreIT)
 ... 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_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_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_avro_file_load 
(apache_beam.io.gcp.bigquery_test.BigQueryFileLoadsIntegrationTests) ... ok
test_multiple_destinations_transform 
(apache_beam.io.gcp.bigquery_test.BigQueryStreamingInsertTransformIntegrationTests)
 ... ok
test_aggregation (apache_beam.examples.dataframe.taxiride_it_test.TaxirideIT) 
... ok
test_enrich (apache_beam.examples.dataframe.taxiride_it_test.TaxirideIT) ... 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_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_datastore_write_limit 
(apache_beam.io.gcp.datastore.v1new.datastore_write_it_test.DatastoreWriteIT) 
... ok
test_transform_on_gcs (apache_beam.io.fileio_test.MatchIntegrationTest) ... ok
test_parquetio_it (apache_beam.io.parquetio_it_test.TestParquetIT) ... 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_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_analyzing_syntax 
(apache_beam.ml.gcp.naturallanguageml_test_it.NaturalLanguageMlTestIT) ... 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_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_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_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
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

======================================================================
ERROR: test_datastore_wordcount_it 
(apache_beam.examples.cookbook.datastore_wordcount_it_test.DatastoreWordCountIT)
----------------------------------------------------------------------
Traceback (most recent call last):
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/examples/cookbook/datastore_wordcount_it_test.py";,>
 line 72, in test_datastore_wordcount_it
    test_pipeline.get_full_options_as_args(**extra_opts))
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/examples/cookbook/datastore_wordcount.py";,>
 line 248, in run
    result = read_from_datastore(project, known_args, pipeline_options)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/examples/cookbook/datastore_wordcount.py";,>
 line 192, in read_from_datastore
    result = p.run()
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/pipeline.py";,>
 line 540, in run
    self._options).run(False)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/pipeline.py";,>
 line 564, in run
    return self.runner.run_pipeline(self, self._options)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py";,>
 line 54, in run_pipeline
    self).run_pipeline(pipeline, options)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py";,>
 line 582, in run_pipeline
    self.dataflow_client.create_job(self.job), self)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/utils/retry.py";,>
 line 253, in wrapper
    return fun(*args, **kwargs)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py";,>
 line 657, in create_job
    self.create_job_description(job)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py";,>
 line 747, in create_job_description
    resources = self._stage_resources(job.proto_pipeline, job.options)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py";,>
 line 610, in _stage_resources
    resources, staging_location=google_cloud_options.staging_location)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/runners/portability/stager.py";,>
 line 383, in stage_job_resources
    file_path, FileSystems.join(staging_location, staged_path))
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py";,>
 line 1018, in stage_artifact
    local_path_to_artifact, artifact_name)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/utils/retry.py";,>
 line 253, in wrapper
    return fun(*args, **kwargs)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py";,>
 line 559, in _gcs_file_copy
    self.stage_file(to_folder, to_name, f, total_size=total_size)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py";,>
 line 635, in stage_file
    response = self._storage_client.objects.Insert(request, upload=upload)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/apache_beam/io/gcp/internal/clients/storage/storage_v1_client.py";,>
 line 1154, in Insert
    upload=upload, upload_config=upload_config)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/apitools/base/py/base_api.py";,>
 line 715, in _RunMethod
    http_request, client=self.client)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/apitools/base/py/transfer.py";,>
 line 908, in InitializeUpload
    return self.StreamInChunks()
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/apitools/base/py/transfer.py";,>
 line 1020, in StreamInChunks
    additional_headers=additional_headers)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/apitools/base/py/transfer.py";,>
 line 957, in __StreamMedia
    response = send_func(self.stream.tell())
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/apitools/base/py/transfer.py";,>
 line 943, in CallSendChunk
    start, additional_headers=additional_headers)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/apitools/base/py/transfer.py";,>
 line 1120, in __SendChunk
    return self.__SendMediaRequest(request, end)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/apitools/base/py/transfer.py";,>
 line 1033, in __SendMediaRequest
    retries=self.num_retries, check_response_func=CheckResponse)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/apitools/base/py/http_wrapper.py";,>
 line 350, in MakeRequest
    check_response_func=check_response_func)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/apitools/base/py/http_wrapper.py";,>
 line 400, in _MakeRequestNoRetry
    redirections=redirections, connection_type=connection_type)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/oauth2client/transport.py";,>
 line 175, in new_request
    redirections, connection_type)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/oauth2client/transport.py";,>
 line 282, in request
    connection_type=connection_type)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/oauth2client/transport.py";,>
 line 175, in new_request
    redirections, connection_type)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/oauth2client/transport.py";,>
 line 282, in request
    connection_type=connection_type)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/httplib2/__init__.py";,>
 line 1709, in request
    conn, authority, uri, request_uri, method, body, headers, redirections, 
cachekey,
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/httplib2/__init__.py";,>
 line 1424, in _request
    (response, content) = self._conn_request(conn, request_uri, method, body, 
headers)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/lib/python3.6/site-packages/httplib2/__init__.py";,>
 line 1376, in _conn_request
    response = conn.getresponse()
  File "/usr/lib/python3.6/http/client.py", line 1331, in getresponse
    response.begin()
  File "/usr/lib/python3.6/http/client.py", line 297, in begin
    version, status, reason = self._read_status()
  File "/usr/lib/python3.6/http/client.py", line 258, in _read_status
    line = str(self.fp.readline(_MAXLINE + 1), "iso-8859-1")
  File "/usr/lib/python3.6/socket.py", line 586, in readinto
    return self._sock.recv_into(b)
  File "/usr/lib/python3.6/ssl.py", line 1012, in recv_into
    return self.read(nbytes, buffer)
  File "/usr/lib/python3.6/ssl.py", line 874, in read
    return self._sslobj.read(len, buffer)
  File "/usr/lib/python3.6/ssl.py", line 631, in read
    v = self._sslobj.read(len, buffer)
socket.timeout: The read operation timed out
-------------------- >> begin captured logging << --------------------
root: DEBUG: Unhandled type_constraint: Union[]
apache_beam.runners.portability.stager: INFO: Executing command: 
['<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/build/gradleenv/-1734967053/bin/python',>
 '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 
'postcommit_requirements.txt', '--exists-action', 'i', '--no-binary', ':all:']
apache_beam.runners.portability.stager: INFO: Copying Beam SDK 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/build/apache-beam.tar.gz";>
 to staging location.
root: WARNING: Make sure that locally built Python SDK docker image has Python 
3.6 interpreter.
root: INFO: Default Python SDK image for environment is 
apache/beam_python3.6_sdk:2.32.0.dev
root: INFO: Using provided Python SDK container image: 
gcr.io/cloud-dataflow/v1beta3/python36:beam-master-20210622
root: INFO: Python SDK container image set to 
"gcr.io/cloud-dataflow/v1beta3/python36:beam-master-20210622" for Docker 
environment
apache_beam.runners.portability.fn_api_runner.translations: INFO: 
==================== <function pack_combiners at 0x7f48dd52c840> 
====================
apache_beam.runners.portability.fn_api_runner.translations: DEBUG: 26 [1, 1, 1, 
1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1]
apache_beam.runners.portability.fn_api_runner.translations: DEBUG: Stages: 
['ref_AppliedPTransform_read-from-datastore-UserQuery-Impulse_4\n  read from 
datastore/UserQuery/Impulse:beam:transform:impulse:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-UserQuery-FlatMap-lambda-at-core-py-2972-_5\n
  read from datastore/UserQuery/FlatMap(<lambda at 
core.py:2972>):beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-UserQuery-Map-decode-_7\n  read from 
datastore/UserQuery/Map(decode):beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-SplitQuery_8\n  read from 
datastore/SplitQuery:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-Reshuffle-AddRandomKeys_10\n  read 
from datastore/Reshuffle/AddRandomKeys:beam:transform:pardo:v1\n  must follow: 
\n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-Reshuffle-ReshufflePerKey-Map-reify_timestamps-_12\n
  read from 
datastore/Reshuffle/ReshufflePerKey/Map(reify_timestamps):beam:transform:pardo:v1\n
  must follow: \n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-Reshuffle-ReshufflePerKey-GroupByKey_13\n
  read from 
datastore/Reshuffle/ReshufflePerKey/GroupByKey:beam:transform:group_by_key:v1\n 
 must follow: \n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-Reshuffle-ReshufflePerKey-FlatMap-restore_timestamps-_14\n
  read from 
datastore/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps):beam:transform:pardo:v1\n
  must follow: \n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-Reshuffle-RemoveRandomKeys_15\n  
read from datastore/Reshuffle/RemoveRandomKeys:beam:transform:pardo:v1\n  must 
follow: \n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-Read_16\n  read from 
datastore/Read:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 'ref_AppliedPTransform_split_17\n  
split:beam:transform:pardo:v1\n  must follow: \n  downstream_side_inputs: 
<unknown>', 'ref_AppliedPTransform_pair_with_one_18\n  
pair_with_one:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 'ref_AppliedPTransform_group_19\n  
group:beam:transform:group_by_key:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 'ref_AppliedPTransform_count_20\n  
count:beam:transform:pardo:v1\n  must follow: \n  downstream_side_inputs: 
<unknown>', 'ref_AppliedPTransform_format_21\n  
format:beam:transform:pardo:v1\n  must follow: \n  downstream_side_inputs: 
<unknown>', 'ref_AppliedPTransform_write-Write-WriteImpl-DoOnce-Impulse_26\n  
write/Write/WriteImpl/DoOnce/Impulse:beam:transform:impulse:v1\n  must follow: 
\n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-DoOnce-FlatMap-lambda-at-core-py-2972-_27\n
  write/Write/WriteImpl/DoOnce/FlatMap(<lambda at 
core.py:2972>):beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-DoOnce-Map-decode-_29\n  
write/Write/WriteImpl/DoOnce/Map(decode):beam:transform:pardo:v1\n  must 
follow: \n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-InitializeWrite_30\n  
write/Write/WriteImpl/InitializeWrite:beam:transform:pardo:v1\n  must follow: 
\n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-WindowInto-WindowIntoFn-_31\n  
write/Write/WriteImpl/WindowInto(WindowIntoFn):beam:transform:window_into:v1\n  
must follow: \n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-WriteBundles_32\n  
write/Write/WriteImpl/WriteBundles:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-Pair_33\n  
write/Write/WriteImpl/Pair:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-GroupByKey_34\n  
write/Write/WriteImpl/GroupByKey:beam:transform:group_by_key:v1\n  must follow: 
\n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-Extract_35\n  
write/Write/WriteImpl/Extract:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-PreFinalize_36\n  
write/Write/WriteImpl/PreFinalize:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-FinalizeWrite_37\n  
write/Write/WriteImpl/FinalizeWrite:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>']
apache_beam.runners.portability.fn_api_runner.translations: INFO: 
==================== <function sort_stages at 0x7f48dd52d048> 
====================
apache_beam.runners.portability.fn_api_runner.translations: DEBUG: 26 [1, 1, 1, 
1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1]
apache_beam.runners.portability.fn_api_runner.translations: DEBUG: Stages: 
['ref_AppliedPTransform_read-from-datastore-UserQuery-Impulse_4\n  read from 
datastore/UserQuery/Impulse:beam:transform:impulse:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-UserQuery-FlatMap-lambda-at-core-py-2972-_5\n
  read from datastore/UserQuery/FlatMap(<lambda at 
core.py:2972>):beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-UserQuery-Map-decode-_7\n  read from 
datastore/UserQuery/Map(decode):beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-SplitQuery_8\n  read from 
datastore/SplitQuery:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-Reshuffle-AddRandomKeys_10\n  read 
from datastore/Reshuffle/AddRandomKeys:beam:transform:pardo:v1\n  must follow: 
\n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-Reshuffle-ReshufflePerKey-Map-reify_timestamps-_12\n
  read from 
datastore/Reshuffle/ReshufflePerKey/Map(reify_timestamps):beam:transform:pardo:v1\n
  must follow: \n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-Reshuffle-ReshufflePerKey-GroupByKey_13\n
  read from 
datastore/Reshuffle/ReshufflePerKey/GroupByKey:beam:transform:group_by_key:v1\n 
 must follow: \n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-Reshuffle-ReshufflePerKey-FlatMap-restore_timestamps-_14\n
  read from 
datastore/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps):beam:transform:pardo:v1\n
  must follow: \n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-Reshuffle-RemoveRandomKeys_15\n  
read from datastore/Reshuffle/RemoveRandomKeys:beam:transform:pardo:v1\n  must 
follow: \n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_read-from-datastore-Read_16\n  read from 
datastore/Read:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 'ref_AppliedPTransform_split_17\n  
split:beam:transform:pardo:v1\n  must follow: \n  downstream_side_inputs: 
<unknown>', 'ref_AppliedPTransform_pair_with_one_18\n  
pair_with_one:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 'ref_AppliedPTransform_group_19\n  
group:beam:transform:group_by_key:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 'ref_AppliedPTransform_count_20\n  
count:beam:transform:pardo:v1\n  must follow: \n  downstream_side_inputs: 
<unknown>', 'ref_AppliedPTransform_format_21\n  
format:beam:transform:pardo:v1\n  must follow: \n  downstream_side_inputs: 
<unknown>', 'ref_AppliedPTransform_write-Write-WriteImpl-DoOnce-Impulse_26\n  
write/Write/WriteImpl/DoOnce/Impulse:beam:transform:impulse:v1\n  must follow: 
\n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-DoOnce-FlatMap-lambda-at-core-py-2972-_27\n
  write/Write/WriteImpl/DoOnce/FlatMap(<lambda at 
core.py:2972>):beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-DoOnce-Map-decode-_29\n  
write/Write/WriteImpl/DoOnce/Map(decode):beam:transform:pardo:v1\n  must 
follow: \n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-InitializeWrite_30\n  
write/Write/WriteImpl/InitializeWrite:beam:transform:pardo:v1\n  must follow: 
\n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-WindowInto-WindowIntoFn-_31\n  
write/Write/WriteImpl/WindowInto(WindowIntoFn):beam:transform:window_into:v1\n  
must follow: \n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-WriteBundles_32\n  
write/Write/WriteImpl/WriteBundles:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-Pair_33\n  
write/Write/WriteImpl/Pair:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-GroupByKey_34\n  
write/Write/WriteImpl/GroupByKey:beam:transform:group_by_key:v1\n  must follow: 
\n  downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-Extract_35\n  
write/Write/WriteImpl/Extract:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-PreFinalize_36\n  
write/Write/WriteImpl/PreFinalize:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>', 
'ref_AppliedPTransform_write-Write-WriteImpl-FinalizeWrite_37\n  
write/Write/WriteImpl/FinalizeWrite:beam:transform:pardo:v1\n  must follow: \n  
downstream_side_inputs: <unknown>']
apache_beam.runners.dataflow.dataflow_runner: WARNING: Typical end users should 
not use this worker jar feature. It can only be used when FnAPI is enabled.
apache_beam.internal.gcp.auth: INFO: Setting socket default timeout to 60 
seconds.
apache_beam.internal.gcp.auth: INFO: socket default timeout is 60.0 seconds.
root: DEBUG: Connecting using Google Application Default Credentials.
apache_beam.runners.dataflow.internal.apiclient: INFO: Starting GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/requirements.txt...
oauth2client.transport: INFO: Attempting refresh to obtain initial access_token
oauth2client.transport: INFO: Attempting refresh to obtain initial access_token
apache_beam.runners.dataflow.internal.apiclient: INFO: Completed GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/requirements.txt
 in 0 seconds.
apache_beam.runners.dataflow.internal.apiclient: INFO: Starting GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/pbr-5.6.0.tar.gz...
apache_beam.runners.dataflow.internal.apiclient: INFO: Completed GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/pbr-5.6.0.tar.gz
 in 0 seconds.
apache_beam.runners.dataflow.internal.apiclient: INFO: Starting GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/mock-2.0.0.tar.gz...
apache_beam.runners.dataflow.internal.apiclient: INFO: Completed GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/mock-2.0.0.tar.gz
 in 0 seconds.
apache_beam.runners.dataflow.internal.apiclient: INFO: Starting GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/six-1.16.0.tar.gz...
apache_beam.runners.dataflow.internal.apiclient: INFO: Completed GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/six-1.16.0.tar.gz
 in 0 seconds.
apache_beam.runners.dataflow.internal.apiclient: INFO: Starting GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/soupsieve-2.2.1.tar.gz...
apache_beam.runners.dataflow.internal.apiclient: INFO: Completed GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/soupsieve-2.2.1.tar.gz
 in 0 seconds.
apache_beam.runners.dataflow.internal.apiclient: INFO: Starting GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/PyHamcrest-1.10.1.tar.gz...
apache_beam.runners.dataflow.internal.apiclient: INFO: Completed GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/PyHamcrest-1.10.1.tar.gz
 in 0 seconds.
apache_beam.runners.dataflow.internal.apiclient: INFO: Starting GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/parameterized-0.7.5.tar.gz...
apache_beam.runners.dataflow.internal.apiclient: INFO: Completed GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/parameterized-0.7.5.tar.gz
 in 0 seconds.
apache_beam.runners.dataflow.internal.apiclient: INFO: Starting GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/beautifulsoup4-4.9.3.tar.gz...
apache_beam.runners.dataflow.internal.apiclient: INFO: Completed GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/beautifulsoup4-4.9.3.tar.gz
 in 0 seconds.
apache_beam.runners.dataflow.internal.apiclient: INFO: Starting GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/dataflow_python_sdk.tar...
apache_beam.runners.dataflow.internal.apiclient: INFO: Completed GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/dataflow_python_sdk.tar
 in 0 seconds.
apache_beam.runners.dataflow.internal.apiclient: INFO: Starting GCS upload to 
gs://temp-storage-for-end-to-end-tests/staging-it/beamapp-jenkins-0629120436-097606.1624968276.098001/dataflow-worker.jar...
root: DEBUG: Caught socket error, retrying: [Errno 104] Connection reset by peer
root: DEBUG: Retrying request to url 
https://www.googleapis.com/resumable/upload/storage/v1/b/temp-storage-for-end-to-end-tests/o?alt=json&name=staging-it%2Fbeamapp-jenkins-0629120436-097606.1624968276.098001%2Fdataflow-worker.jar&uploadType=resumable&upload_id=ADPycdss80E-v2LsTT2GI5_h95gYZRMlMYE8mgB5krN5Z424hzWB0cm0QNyy65-2Y3hHtGmsI49gU1BnD2Mw_-8dEu4
 after exception [Errno 104] Connection reset by peer
root: DEBUG: Caught socket error, retrying: The read operation timed out
root: DEBUG: Retrying request to url 
https://www.googleapis.com/resumable/upload/storage/v1/b/temp-storage-for-end-to-end-tests/o?alt=json&name=staging-it%2Fbeamapp-jenkins-0629120436-097606.1624968276.098001%2Fdataflow-worker.jar&uploadType=resumable&upload_id=ADPycdss80E-v2LsTT2GI5_h95gYZRMlMYE8mgB5krN5Z424hzWB0cm0QNyy65-2Y3hHtGmsI49gU1BnD2Mw_-8dEu4
 after exception The read operation timed out
root: DEBUG: Caught socket error, retrying: The read operation timed out
root: DEBUG: Retrying request to url 
https://www.googleapis.com/resumable/upload/storage/v1/b/temp-storage-for-end-to-end-tests/o?alt=json&name=staging-it%2Fbeamapp-jenkins-0629120436-097606.1624968276.098001%2Fdataflow-worker.jar&uploadType=resumable&upload_id=ADPycdss80E-v2LsTT2GI5_h95gYZRMlMYE8mgB5krN5Z424hzWB0cm0QNyy65-2Y3hHtGmsI49gU1BnD2Mw_-8dEu4
 after exception The read operation timed out
root: DEBUG: Caught socket error, retrying: The read operation timed out
root: DEBUG: Retrying request to url 
https://www.googleapis.com/resumable/upload/storage/v1/b/temp-storage-for-end-to-end-tests/o?alt=json&name=staging-it%2Fbeamapp-jenkins-0629120436-097606.1624968276.098001%2Fdataflow-worker.jar&uploadType=resumable&upload_id=ADPycdss80E-v2LsTT2GI5_h95gYZRMlMYE8mgB5krN5Z424hzWB0cm0QNyy65-2Y3hHtGmsI49gU1BnD2Mw_-8dEu4
 after exception The read operation timed out
--------------------- >> end captured logging << ---------------------

----------------------------------------------------------------------
XML: nosetests-postCommitIT-df-py36.xml
----------------------------------------------------------------------
XML: 
<https://ci-beam.apache.org/job/beam_PostCommit_Python36/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 71 tests in 5347.644s

FAILED (SKIP=8, errors=1)

> Task :sdks:python:test-suites:dataflow:py36:postCommitIT FAILED

FAILURE: Build failed with an exception.

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

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

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

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

Deprecated Gradle features were used in this build, making it incompatible with 
Gradle 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 32m 40s
213 actionable tasks: 151 executed, 58 from cache, 4 up-to-date

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

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]

Reply via email to