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

Changes:

[noreply] [BEAM-13204] Fix website bug where code tabs do not appear if the


------------------------------------------
[...truncated 242.14 KB...]
                                                                                
 raise exceptions.HttpError.FromResponse(
                                                                             
apitools.base.py.exceptions.HttpForbiddenError: HttpError accessing 
<https://bigquery.googleapis.com/bigquery/v2/projects/apache-beam-testing/jobs?alt=json>:
 response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 
'application/json; charset=UTF-8', 'date': 'Sat, 16 Apr 2022 01:16:50 GMT', 
'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 
'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 
'transfer-encoding': 'chunked', 'status': '403', 'content-length': '528', 
'-content-encoding': 'gzip'}>, content <{
                                                                               
"error": {
                                                                                
 "code": 403,
                                                                                
 "message": "Access Denied: Table bigquery-samples:airline_ontime_data.flights: 
User does not have permission to query table 
bigquery-samples:airline_ontime_data.flights.",
                                                                                
 "errors": [
                                                                                
   {
                                                                                
     "message": "Access Denied: Table 
bigquery-samples:airline_ontime_data.flights: User does not have permission to 
query table bigquery-samples:airline_ontime_data.flights.",
                                                                                
     "domain": "global",
                                                                                
     "reason": "accessDenied"
                                                                                
   }
                                                                                
 ],
                                                                                
 "status": "PERMISSION_DENIED"
                                                                               }
                                                                             }
                                                                             >
                                                                             
                                                                             
During handling of the above exception, another exception occurred:
                                                                             
                                                                             
Traceback (most recent call last):
                                                                               
File 
"/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/sdk_worker.py",
 line 267, in _execute
                                                                                
 response = task()
                                                                               
File 
"/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/sdk_worker.py",
 line 340, in <lambda>
                                                                                
 lambda: self.create_worker().do_instruction(request), request)
                                                                               
File 
"/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/sdk_worker.py",
 line 580, in do_instruction
                                                                                
 return getattr(self, request_type)(
                                                                               
File 
"/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/sdk_worker.py",
 line 618, in process_bundle
                                                                                
 bundle_processor.process_bundle(instruction_id))
                                                                               
File 
"/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/bundle_processor.py",
 line 995, in process_bundle
                                                                                
 input_op_by_transform_id[element.transform_id].process_encoded(
                                                                               
File 
"/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/bundle_processor.py",
 line 221, in process_encoded
                                                                                
 self.output(decoded_value)
                                                                               
File "apache_beam/runners/worker/operations.py", line 346, in 
apache_beam.runners.worker.operations.Operation.output
                                                                               
File "apache_beam/runners/worker/operations.py", line 348, in 
apache_beam.runners.worker.operations.Operation.output
                                                                               
File "apache_beam/runners/worker/operations.py", line 215, in 
apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               
File "apache_beam/runners/worker/operations.py", line 707, in 
apache_beam.runners.worker.operations.DoOperation.process
                                                                               
File "apache_beam/runners/worker/operations.py", line 708, in 
apache_beam.runners.worker.operations.DoOperation.process
                                                                               
File "apache_beam/runners/common.py", line 1200, in 
apache_beam.runners.common.DoFnRunner.process
                                                                               
File "apache_beam/runners/common.py", line 1265, in 
apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               
File "apache_beam/runners/common.py", line 1198, in 
apache_beam.runners.common.DoFnRunner.process
                                                                               
File "apache_beam/runners/common.py", line 536, in 
apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               
File "apache_beam/runners/common.py", line 1361, in 
apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               
File "apache_beam/runners/worker/operations.py", line 215, in 
apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               
File "apache_beam/runners/worker/operations.py", line 707, in 
apache_beam.runners.worker.operations.DoOperation.process
                                                                               
File "apache_beam/runners/worker/operations.py", line 708, in 
apache_beam.runners.worker.operations.DoOperation.process
                                                                               
File "apache_beam/runners/common.py", line 1200, in 
apache_beam.runners.common.DoFnRunner.process
                                                                               
File "apache_beam/runners/common.py", line 1265, in 
apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               
File "apache_beam/runners/common.py", line 1198, in 
apache_beam.runners.common.DoFnRunner.process
                                                                               
File "apache_beam/runners/common.py", line 536, in 
apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               
File "apache_beam/runners/common.py", line 1361, in 
apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               
File "apache_beam/runners/worker/operations.py", line 215, in 
apache_beam.runners.worker.operations.SingletonConsumerSet.receive
                                                                               
File "apache_beam/runners/worker/operations.py", line 707, in 
apache_beam.runners.worker.operations.DoOperation.process
                                                                               
File "apache_beam/runners/worker/operations.py", line 708, in 
apache_beam.runners.worker.operations.DoOperation.process
                                                                               
File "apache_beam/runners/common.py", line 1200, in 
apache_beam.runners.common.DoFnRunner.process
                                                                               
File "apache_beam/runners/common.py", line 1281, in 
apache_beam.runners.common.DoFnRunner._reraise_augmented
                                                                               
File "apache_beam/runners/common.py", line 1198, in 
apache_beam.runners.common.DoFnRunner.process
                                                                               
File "apache_beam/runners/common.py", line 536, in 
apache_beam.runners.common.SimpleInvoker.invoke_process
                                                                               
File "apache_beam/runners/common.py", line 1334, in 
apache_beam.runners.common._OutputProcessor.process_outputs
                                                                               
File 
"/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/bundle_processor.py",
 line 1446, in process
                                                                                
 for part, size in self.restriction_provider.split_and_size(
                                                                               
File "/usr/local/lib/python3.9/site-packages/apache_beam/transforms/core.py", 
line 328, in split_and_size
                                                                                
 for part in self.split(element, restriction):
                                                                               
File "/usr/local/lib/python3.9/site-packages/apache_beam/io/iobase.py", line 
1627, in split
                                                                                
 estimated_size = restriction.source().estimate_size()
                                                                               
File "/usr/local/lib/python3.9/site-packages/apache_beam/io/gcp/bigquery.py", 
line 762, in estimate_size
                                                                                
 job = bq._start_query_job(
                                                                               
File "/usr/local/lib/python3.9/site-packages/apache_beam/utils/retry.py", line 
253, in wrapper
                                                                                
 return fun(*args, **kwargs)
                                                                               
File 
"/usr/local/lib/python3.9/site-packages/apache_beam/io/gcp/bigquery_tools.py", 
line 605, in _start_query_job
                                                                                
 return self._start_job(request)
                                                                               
File 
"/usr/local/lib/python3.9/site-packages/apache_beam/io/gcp/bigquery_tools.py", 
line 551, in _start_job
                                                                                
 response = self.client.jobs.Insert(request, upload=upload)
                                                                               
File 
"/usr/local/lib/python3.9/site-packages/apache_beam/io/gcp/internal/clients/bigquery/bigquery_v2_client.py",
 line 343, in Insert
                                                                                
 return self._RunMethod(
                                                                               
File "/usr/local/lib/python3.9/site-packages/apitools/base/py/base_api.py", 
line 731, in _RunMethod
                                                                                
 return self.ProcessHttpResponse(method_config, http_response, request)
                                                                               
File "/usr/local/lib/python3.9/site-packages/apitools/base/py/base_api.py", 
line 737, in ProcessHttpResponse
                                                                                
 self.__ProcessHttpResponse(method_config, http_response, request))
                                                                               
File "/usr/local/lib/python3.9/site-packages/apitools/base/py/base_api.py", 
line 603, in __ProcessHttpResponse
                                                                                
 raise exceptions.HttpError.FromResponse(
                                                                             
RuntimeError: apitools.base.py.exceptions.HttpForbiddenError: HttpError 
accessing 
<https://bigquery.googleapis.com/bigquery/v2/projects/apache-beam-testing/jobs?alt=json>:
 response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 
'application/json; charset=UTF-8', 'date': 'Sat, 16 Apr 2022 01:16:50 GMT', 
'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 
'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 
'transfer-encoding': 'chunked', 'status': '403', 'content-length': '528', 
'-content-encoding': 'gzip'}>, content <{
                                                                               
"error": {
                                                                                
 "code": 403,
                                                                                
 "message": "Access Denied: Table bigquery-samples:airline_ontime_data.flights: 
User does not have permission to query table 
bigquery-samples:airline_ontime_data.flights.",
                                                                                
 "errors": [
                                                                                
   {
                                                                                
     "message": "Access Denied: Table 
bigquery-samples:airline_ontime_data.flights: User does not have permission to 
query table bigquery-samples:airline_ontime_data.flights.",
                                                                                
     "domain": "global",
                                                                                
     "reason": "accessDenied"
                                                                                
   }
                                                                                
 ],
                                                                                
 "status": "PERMISSION_DENIED"
                                                                               }
                                                                             }
                                                                             > 
[while running 
'ref_AppliedPTransform_read-table-Read-SDFBoundedSourceReader-ParDo-SDFBoundedSourceDoFn-_13/SplitWithSizing-ptransform-42']
INFO     
apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:242 
2022-04-16T01:16:52.873Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     
apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:242 
2022-04-16T01:16:53.194Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     
apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:242 
2022-04-16T01:16:53.220Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     
apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:242 
2022-04-16T01:17:48.140Z: JOB_MESSAGE_DETAILED: Autoscaling: Resized worker 
pool from 1 to 0.
INFO     
apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:242 
2022-04-16T01:17:48.207Z: JOB_MESSAGE_BASIC: Worker pool stopped.
INFO     
apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:242 
2022-04-16T01:17:48.239Z: JOB_MESSAGE_DEBUG: Tearing down pending resources...
INFO     
apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:197 Job 
2022-04-15_18_08_48-6306505124479323734 is in state JOB_STATE_FAILED
INFO     apache_beam.io.gcp.gcsio:gcsio.py:559 Starting the size 
estimation of the input
INFO     apache_beam.io.gcp.gcsio:gcsio.py:572 Finished listing 0 
files in 0.05620837211608887 seconds.
=============================== warnings summary 
===============================
<unknown>:54
<unknown>:54
<unknown>:54
<unknown>:54
<unknown>:54
<unknown>:54
<unknown>:54
<unknown>:54
  <unknown>:54: DeprecationWarning: invalid escape sequence \c

<unknown>:62
<unknown>:62
<unknown>:62
<unknown>:62
<unknown>:62
<unknown>:62
<unknown>:62
<unknown>:62
  <unknown>:62: DeprecationWarning: invalid escape sequence \d

<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/-1734967050/lib/python3.9/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/-1734967050/lib/python3.9/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/-1734967050/lib/python3.9/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/-1734967050/lib/python3.9/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/-1734967050/lib/python3.9/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/-1734967050/lib/python3.9/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/-1734967050/lib/python3.9/site-packages/tenacity/_asyncio.py>:42
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/-1734967050/lib/python3.9/site-packages/tenacity/_asyncio.py>:42
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/-1734967050/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/io/filesystems_test.py:54
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/filesystems_test.py>:54:
 DeprecationWarning: invalid escape sequence \c
    self.assertIsNone(FileSystems.get_scheme('c:\\abc\cdf'))  # pylint: 
disable=anomalous-backslash-in-string

apache_beam/io/filesystems_test.py:62
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/filesystems_test.py>:62:
 DeprecationWarning: invalid escape sequence \d
    self.assertTrue(isinstance(FileSystems.get_filesystem('c:\\abc\def'),  # 
pylint: disable=anomalous-backslash-in-string

apache_beam/dataframe/io.py:629
apache_beam/dataframe/io.py:629
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/dataframe/io.py>:629:
 FutureWarning: WriteToFiles is experimental.
    return pcoll | fileio.WriteToFiles(

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

apache_beam/io/gcp/bigquery.py:2443
apache_beam/io/gcp/bigquery.py:2443
apache_beam/io/gcp/bigquery.py:2443
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2443:
 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/io/gcp/bigquery.py:2445
apache_beam/io/gcp/bigquery.py:2445
apache_beam/io/gcp/bigquery.py:2445
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2445:
 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/io/gcp/bigquery.py:2469
apache_beam/io/gcp/bigquery.py:2469
apache_beam/io/gcp/bigquery.py:2469
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2469:
 BeamDeprecationWarning: options is deprecated since First stable release. 
References to <pipeline>.options will not be supported
    pipeline_options=pcoll.pipeline.options,

apache_beam/io/gcp/bigquery.py:2139
apache_beam/io/gcp/bigquery.py:2139
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2139:
 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/io/gcp/bigquery.py:2143
apache_beam/io/gcp/bigquery.py:2143
apache_beam/io/gcp/bigquery.py:2143
apache_beam/io/gcp/bigquery.py:2143
apache_beam/io/gcp/bigquery.py:2143
apache_beam/io/gcp/bigquery.py:2143
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2143:
 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/io/gcp/bigquery.py:2149
apache_beam/io/gcp/bigquery.py:2149
apache_beam/io/gcp/bigquery.py:2149
apache_beam/io/gcp/bigquery.py:2149
apache_beam/io/gcp/bigquery.py:2149
apache_beam/io/gcp/bigquery.py:2149
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2149:
 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/io/gcp/bigquery_file_loads.py:1128
apache_beam/io/gcp/bigquery_file_loads.py:1128
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1128:
 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/io/gcp/bigquery_file_loads.py:1130
apache_beam/io/gcp/bigquery_file_loads.py:1130
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1130:
 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/io/gcp/tests/utils.py:100
apache_beam/io/gcp/tests/utils.py:100
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/tests/utils.py>:100:
 PendingDeprecationWarning: Client.dataset is deprecated and will be removed in 
a future version. Use a string like 'my_project.my_dataset' or a 
cloud.google.bigquery.DatasetReference object, instead.
    table_ref = client.dataset(dataset_id).table(table_id)

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

apache_beam/examples/dataframe/flight_delays.py:47
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/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()

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: 
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/pytest_postCommitIT-df-py39-xdist.xml>
 -
======== 1 failed, 16 passed, 1 skipped, 62 warnings in 1316.11 
seconds ========

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

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py39: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.
> Run with --scan to get full insights.

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

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

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

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