You are viewing a plain text version of this content. The canonical link for it is here.
Posted to builds@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2022/10/20 08:47:07 UTC

Build failed in Jenkins: beam_PostCommit_Python_Examples_Dataflow #1020

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

Changes:

[noreply] Reduce log flood in Python PostCommit flink task (#23635)

[noreply] Speed up check on website links (#23737)


------------------------------------------
[...truncated 178.68 KB...]
                       client=None,  # pylint: disable=unused-argument
                       oauth2client_args=None,
                       **kwds):
        """Attempt to get credentials, using an oauth dance as the last resort."""
        scopes = util.NormalizeScopes(scopes)
        client_info = {
            'client_id': client_id,
            'client_secret': client_secret,
            'scope': ' '.join(sorted(scopes)),
            'user_agent': user_agent or '%s-generated/0.1' % package_name,
        }
        for method in _CREDENTIALS_METHODS:
            credentials = method(client_info, **kwds)
            if credentials is not None:
                return credentials
        credentials_filename = credentials_filename or os.path.expanduser(
            '~/.apitools.token')
        credentials = CredentialsFromFile(credentials_filename, client_info,
                                          oauth2client_args=oauth2client_args)
        if credentials is not None:
            return credentials
>       raise exceptions.CredentialsError('Could not create valid credentials')
E       apitools.base.py.exceptions.CredentialsError: Could not create valid credentials

../../build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/credentials_lib.py:157: CredentialsError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.runners.portability.stager:stager.py:754 Executing command: ['<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/bin/python3.10',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', '/tmp/tmp2mfyl7_w/tmp_requirements.txt', '--exists-action', 'i', '--no-deps', '--implementation', 'cp', '--abi', 'cp310', '--platform', 'manylinux2014_x86_64']
INFO     apache_beam.runners.portability.stager:stager.py:325 Copying Beam SDK "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/build/apache-beam.tar.gz"> to staging location.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:484 Pipeline has additional dependencies to be installed in SDK worker container, consider using the SDK container image pre-building workflow to avoid repetitive installations. Learn more on https://cloud.google.com/dataflow/docs/guides/using-custom-containers#prebuild
INFO     root:environments.py:376 Default Python SDK image for environment is apache/beam_python3.10_sdk:2.43.0.dev
INFO     root:environments.py:295 Using provided Python SDK container image: gcr.io/cloud-dataflow/v1beta3/python310-fnapi:beam-master-20221018
INFO     root:environments.py:302 Python SDK container image set to "gcr.io/cloud-dataflow/v1beta3/python310-fnapi:beam-master-20221018" for Docker environment
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function pack_combiners at 0x7f0bca714af0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function sort_stages at 0x7f0bca7152d0> ====================
WARNING  oauth2client.contrib.multiprocess_file_storage:multiprocess_file_storage.py:141 Credentials file could not be loaded, will ignore and overwrite.
WARNING  oauth2client.contrib.multiprocess_file_storage:multiprocess_file_storage.py:141 Credentials file could not be loaded, will ignore and overwrite.
_______________ CodersIT.test_coders_output_files_on_small_input _______________

self = <apache_beam.examples.cookbook.coders_it_test.CodersIT testMethod=test_coders_output_files_on_small_input>

    @pytest.mark.no_xdist
    @pytest.mark.examples_postcommit
    def test_coders_output_files_on_small_input(self):
      test_pipeline = TestPipeline(is_integration_test=True)
      # Setup the files with expected content.
      OUTPUT_FILE_DIR = \
          'gs://temp-storage-for-end-to-end-tests/py-it-cloud/output'
      output = '/'.join([OUTPUT_FILE_DIR, str(uuid.uuid4()), 'result'])
      INPUT_FILE_DIR = \
          'gs://temp-storage-for-end-to-end-tests/py-it-cloud/input'
      input = '/'.join([INPUT_FILE_DIR, str(uuid.uuid4()), 'input.txt'])
>     create_content_input_file(
          input, '\n'.join(map(json.dumps, self.SAMPLE_RECORDS)))

apache_beam/examples/cookbook/coders_it_test.py:90: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/examples/cookbook/coders_it_test.py:50: in create_content_input_file
    with gcs.open(path, 'w') as f:
apache_beam/io/filesystemio.py:215: in close
    self._uploader.finish()
apache_beam/io/gcp/gcsio.py:790: in finish
    raise self._upload_thread.last_error  # pylint: disable=raising-bad-type
apache_beam/io/gcp/gcsio.py:763: in _start_upload
    self._client.objects.Insert(self._insert_request, upload=self._upload)
apache_beam/io/gcp/internal/clients/storage/storage_v1_client.py:1152: in Insert
    return self._RunMethod(
../../build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/base_api.py:714: in _RunMethod
    http_response = upload.InitializeUpload(
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = Upload (uninitialized)
http_request = <apitools.base.py.http_wrapper.Request object at 0x7f0b8ea02410>
http = <httplib2.Http object at 0x7f0b8ea02050>
client = <apache_beam.io.gcp.internal.clients.storage.storage_v1_client.StorageV1 object at 0x7f0b8ea00760>

    def InitializeUpload(self, http_request, http=None, client=None):
        """Initialize this upload from the given http_request."""
        if self.strategy is None:
            raise exceptions.UserError(
                'No upload strategy set; did you call ConfigureRequest?')
        if http is None and client is None:
            raise exceptions.UserError('Must provide client or http.')
        if self.strategy != RESUMABLE_UPLOAD:
            return
        http = http or client.http
        if client is not None:
            http_request.url = client.FinalizeTransferUrl(http_request.url)
        self.EnsureUninitialized()
        http_response = http_wrapper.MakeRequest(http, http_request,
                                                 retries=self.num_retries)
        if http_response.status_code != http_client.OK:
>           raise exceptions.HttpError.FromResponse(http_response)
E           apitools.base.py.exceptions.HttpUnauthorizedError: HttpError accessing <https://www.googleapis.com/resumable/upload/storage/v1/b/temp-storage-for-end-to-end-tests/o?alt=json&name=py-it-cloud%2Finput%2Fdcfe4e1b-54cf-4308-9d19-b5dbcb54ff9e%2Finput.txt&uploadType=resumable>: response: <{'x-guploader-uploadid': 'ADPycduEH56TeQ6AloypUYfRz2w7qQ9gjLHNMqCNxAoQfoiShmlV1Tr4599rR9rKhNsNNa9Z6yEP1evEzDDmN_SgGT6CfQ', 'date': 'Thu, 20 Oct 2022 08:47:03 GMT', 'vary': 'Origin, X-Origin', 'www-authenticate': 'Bearer realm="https://accounts.google.com/"', 'cache-control': 'no-cache, no-store, max-age=0, must-revalidate', 'expires': 'Mon, 01 Jan 1990 00:00:00 GMT', 'pragma': 'no-cache', 'content-length': '438', 'server': 'UploadServer', 'content-type': 'text/html; charset=UTF-8', 'status': '401'}>, content <{
E             "error": {
E               "code": 401,
E               "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
E               "errors": [
E                 {
E                   "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
E                   "domain": "global",
E                   "reason": "required",
E                   "locationType": "header",
E                   "location": "Authorization"
E                 }
E               ]
E             }
E           }
E           >

../../build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/transfer.py:896: HttpUnauthorizedError
------------------------------ Captured log call -------------------------------
INFO     root:coders_it_test.py:48 Creating file: gs://temp-storage-for-end-to-end-tests/py-it-cloud/input/dcfe4e1b-54cf-4308-9d19-b5dbcb54ff9e/input.txt
ERROR    apache_beam.io.gcp.gcsio:gcsio.py:767 Error in _start_upload while inserting file gs://temp-storage-for-end-to-end-tests/py-it-cloud/input/dcfe4e1b-54cf-4308-9d19-b5dbcb54ff9e/input.txt: Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 763, in _start_upload
    self._client.objects.Insert(self._insert_request, upload=self._upload)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/internal/clients/storage/storage_v1_client.py",> line 1152, in Insert
    return self._RunMethod(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/base_api.py",> line 714, in _RunMethod
    http_response = upload.InitializeUpload(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/transfer.py",> line 896, in InitializeUpload
    raise exceptions.HttpError.FromResponse(http_response)
apitools.base.py.exceptions.HttpUnauthorizedError: HttpError accessing <https://www.googleapis.com/resumable/upload/storage/v1/b/temp-storage-for-end-to-end-tests/o?alt=json&name=py-it-cloud%2Finput%2Fdcfe4e1b-54cf-4308-9d19-b5dbcb54ff9e%2Finput.txt&uploadType=resumable>: response: <{'x-guploader-uploadid': 'ADPycduEH56TeQ6AloypUYfRz2w7qQ9gjLHNMqCNxAoQfoiShmlV1Tr4599rR9rKhNsNNa9Z6yEP1evEzDDmN_SgGT6CfQ', 'date': 'Thu, 20 Oct 2022 08:47:03 GMT', 'vary': 'Origin, X-Origin', 'www-authenticate': 'Bearer realm="https://accounts.google.com/"', 'cache-control': 'no-cache, no-store, max-age=0, must-revalidate', 'expires': 'Mon, 01 Jan 1990 00:00:00 GMT', 'pragma': 'no-cache', 'content-length': '438', 'server': 'UploadServer', 'content-type': 'text/html; charset=UTF-8', 'status': '401'}>, content <{
  "error": {
    "code": 401,
    "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
    "errors": [
      {
        "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
        "domain": "global",
        "reason": "required",
        "locationType": "header",
        "location": "Authorization"
      }
    ]
  }
}
>
=============================== warnings summary ===============================
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib and slated for removal in Python 3.12; see the module's documentation for alternative uses
    from imp import load_source

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

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

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

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

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

apache_beam/examples/complete/autocomplete_it_test.py: 1 warning
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 2 warnings
apache_beam/examples/complete/game/user_score_it_test.py: 6 warnings
apache_beam/examples/cookbook/bigquery_side_input_it_test.py: 4 warnings
apache_beam/examples/cookbook/coders_it_test.py: 1 warning
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/httplib2/__init__.py>:147: DeprecationWarning: ssl.PROTOCOL_TLS is deprecated
    context = ssl.SSLContext(DEFAULT_TLS_VERSION)

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1991: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    is_streaming_pipeline = p.options.view_as(StandardOptions).streaming

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1997: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    experiments = p.options.view_as(DebugOptions).experiments or []

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1133: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = p.options.view_as(GoogleCloudOptions).temp_location

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1135: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(GoogleCloudOptions).job_name or 'AUTOMATIC_JOB_NAME')

apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2484: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = pcoll.pipeline.options.view_as(

apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2486: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    job_name = pcoll.pipeline.options.view_as(GoogleCloudOptions).job_name

apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2510: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    pipeline_options=pcoll.pipeline.options,

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/pytest_postCommitIT-df-py310-no-xdist.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/complete/autocomplete_it_test.py::AutocompleteIT::test_autocomplete_output_files_on_small_input
FAILED apache_beam/examples/complete/estimate_pi_it_test.py::EstimatePiIT::test_estimate_pi_output_file
FAILED apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
FAILED apache_beam/examples/complete/game/user_score_it_test.py::UserScoreIT::test_userscore_output_checksum_on_small_input
FAILED apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
FAILED apache_beam/examples/cookbook/coders_it_test.py::CodersIT::test_coders_output_files_on_small_input
ERROR apache_beam/examples/complete/game/user_score_it_test.py::UserScoreIT::test_userscore_output_checksum_on_small_input
ERROR apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
= 6 failed, 4 skipped, 6650 deselected, 31 warnings, 2 errors in 4871.99s (1:21:11) =

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

FAILURE: Build failed with an exception.

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

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

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

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

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

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

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

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

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

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

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


Jenkins build is back to normal : beam_PostCommit_Python_Examples_Dataflow #1024

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


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


Build failed in Jenkins: beam_PostCommit_Python_Examples_Dataflow #1023

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

Changes:

[Kenneth Knowles] Verify that secondary key coder is deterministic in SortValues

[riteshghorse] fix lints

[noreply] Update google cloud vision >= 2.0.0 (#23755)


------------------------------------------
[...truncated 178.19 KB...]
                       client=None,  # pylint: disable=unused-argument
                       oauth2client_args=None,
                       **kwds):
        """Attempt to get credentials, using an oauth dance as the last resort."""
        scopes = util.NormalizeScopes(scopes)
        client_info = {
            'client_id': client_id,
            'client_secret': client_secret,
            'scope': ' '.join(sorted(scopes)),
            'user_agent': user_agent or '%s-generated/0.1' % package_name,
        }
        for method in _CREDENTIALS_METHODS:
            credentials = method(client_info, **kwds)
            if credentials is not None:
                return credentials
        credentials_filename = credentials_filename or os.path.expanduser(
            '~/.apitools.token')
        credentials = CredentialsFromFile(credentials_filename, client_info,
                                          oauth2client_args=oauth2client_args)
        if credentials is not None:
            return credentials
>       raise exceptions.CredentialsError('Could not create valid credentials')
E       apitools.base.py.exceptions.CredentialsError: Could not create valid credentials

../../build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/credentials_lib.py:157: CredentialsError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.runners.portability.stager:stager.py:754 Executing command: ['<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/bin/python3.10',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', '/tmp/tmpkpuqnpum/tmp_requirements.txt', '--exists-action', 'i', '--no-deps', '--implementation', 'cp', '--abi', 'cp310', '--platform', 'manylinux2014_x86_64']
INFO     apache_beam.runners.portability.stager:stager.py:325 Copying Beam SDK "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/build/apache-beam.tar.gz"> to staging location.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:484 Pipeline has additional dependencies to be installed in SDK worker container, consider using the SDK container image pre-building workflow to avoid repetitive installations. Learn more on https://cloud.google.com/dataflow/docs/guides/using-custom-containers#prebuild
INFO     root:environments.py:376 Default Python SDK image for environment is apache/beam_python3.10_sdk:2.44.0.dev
INFO     root:environments.py:295 Using provided Python SDK container image: gcr.io/cloud-dataflow/v1beta3/python310-fnapi:beam-master-20221018
INFO     root:environments.py:302 Python SDK container image set to "gcr.io/cloud-dataflow/v1beta3/python310-fnapi:beam-master-20221018" for Docker environment
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function pack_combiners at 0x7faa141e4c10> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function sort_stages at 0x7faa141e53f0> ====================
WARNING  oauth2client.contrib.multiprocess_file_storage:multiprocess_file_storage.py:141 Credentials file could not be loaded, will ignore and overwrite.
WARNING  oauth2client.contrib.multiprocess_file_storage:multiprocess_file_storage.py:141 Credentials file could not be loaded, will ignore and overwrite.
_______________ CodersIT.test_coders_output_files_on_small_input _______________

self = <apache_beam.examples.cookbook.coders_it_test.CodersIT testMethod=test_coders_output_files_on_small_input>

    @pytest.mark.no_xdist
    @pytest.mark.examples_postcommit
    def test_coders_output_files_on_small_input(self):
      test_pipeline = TestPipeline(is_integration_test=True)
      # Setup the files with expected content.
      OUTPUT_FILE_DIR = \
          'gs://temp-storage-for-end-to-end-tests/py-it-cloud/output'
      output = '/'.join([OUTPUT_FILE_DIR, str(uuid.uuid4()), 'result'])
      INPUT_FILE_DIR = \
          'gs://temp-storage-for-end-to-end-tests/py-it-cloud/input'
      input = '/'.join([INPUT_FILE_DIR, str(uuid.uuid4()), 'input.txt'])
>     create_content_input_file(
          input, '\n'.join(map(json.dumps, self.SAMPLE_RECORDS)))

apache_beam/examples/cookbook/coders_it_test.py:90: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/examples/cookbook/coders_it_test.py:50: in create_content_input_file
    with gcs.open(path, 'w') as f:
apache_beam/io/filesystemio.py:215: in close
    self._uploader.finish()
apache_beam/io/gcp/gcsio.py:790: in finish
    raise self._upload_thread.last_error  # pylint: disable=raising-bad-type
apache_beam/io/gcp/gcsio.py:763: in _start_upload
    self._client.objects.Insert(self._insert_request, upload=self._upload)
apache_beam/io/gcp/internal/clients/storage/storage_v1_client.py:1152: in Insert
    return self._RunMethod(
../../build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/base_api.py:714: in _RunMethod
    http_response = upload.InitializeUpload(
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = Upload (uninitialized)
http_request = <apitools.base.py.http_wrapper.Request object at 0x7fa9bfb3df60>
http = <httplib2.Http object at 0x7fa9bfb3cca0>
client = <apache_beam.io.gcp.internal.clients.storage.storage_v1_client.StorageV1 object at 0x7fa9bfb3d6c0>

    def InitializeUpload(self, http_request, http=None, client=None):
        """Initialize this upload from the given http_request."""
        if self.strategy is None:
            raise exceptions.UserError(
                'No upload strategy set; did you call ConfigureRequest?')
        if http is None and client is None:
            raise exceptions.UserError('Must provide client or http.')
        if self.strategy != RESUMABLE_UPLOAD:
            return
        http = http or client.http
        if client is not None:
            http_request.url = client.FinalizeTransferUrl(http_request.url)
        self.EnsureUninitialized()
        http_response = http_wrapper.MakeRequest(http, http_request,
                                                 retries=self.num_retries)
        if http_response.status_code != http_client.OK:
>           raise exceptions.HttpError.FromResponse(http_response)
E           apitools.base.py.exceptions.HttpUnauthorizedError: HttpError accessing <https://www.googleapis.com/resumable/upload/storage/v1/b/temp-storage-for-end-to-end-tests/o?alt=json&name=py-it-cloud%2Finput%2F30870152-15cc-4123-a2c2-1e7d98dbc87f%2Finput.txt&uploadType=resumable>: response: <{'x-guploader-uploadid': 'ADPycdvMtr6aGscwnoQh6-MT4UDk8N4A9WZmzmMJQi_U5XALKXaEeCbCUqqg9RqpHTWJlaKdwdMuj_YVJwBmVCzsbpg83lrhr_cJ', 'date': 'Fri, 21 Oct 2022 02:43:59 GMT', 'vary': 'Origin, X-Origin', 'www-authenticate': 'Bearer realm="https://accounts.google.com/"', 'cache-control': 'no-cache, no-store, max-age=0, must-revalidate', 'expires': 'Mon, 01 Jan 1990 00:00:00 GMT', 'pragma': 'no-cache', 'content-length': '438', 'server': 'UploadServer', 'content-type': 'text/html; charset=UTF-8', 'status': '401'}>, content <{
E             "error": {
E               "code": 401,
E               "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
E               "errors": [
E                 {
E                   "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
E                   "domain": "global",
E                   "reason": "required",
E                   "locationType": "header",
E                   "location": "Authorization"
E                 }
E               ]
E             }
E           }
E           >

../../build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/transfer.py:896: HttpUnauthorizedError
------------------------------ Captured log call -------------------------------
INFO     root:coders_it_test.py:48 Creating file: gs://temp-storage-for-end-to-end-tests/py-it-cloud/input/30870152-15cc-4123-a2c2-1e7d98dbc87f/input.txt
ERROR    apache_beam.io.gcp.gcsio:gcsio.py:767 Error in _start_upload while inserting file gs://temp-storage-for-end-to-end-tests/py-it-cloud/input/30870152-15cc-4123-a2c2-1e7d98dbc87f/input.txt: Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 763, in _start_upload
    self._client.objects.Insert(self._insert_request, upload=self._upload)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/internal/clients/storage/storage_v1_client.py",> line 1152, in Insert
    return self._RunMethod(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/base_api.py",> line 714, in _RunMethod
    http_response = upload.InitializeUpload(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/transfer.py",> line 896, in InitializeUpload
    raise exceptions.HttpError.FromResponse(http_response)
apitools.base.py.exceptions.HttpUnauthorizedError: HttpError accessing <https://www.googleapis.com/resumable/upload/storage/v1/b/temp-storage-for-end-to-end-tests/o?alt=json&name=py-it-cloud%2Finput%2F30870152-15cc-4123-a2c2-1e7d98dbc87f%2Finput.txt&uploadType=resumable>: response: <{'x-guploader-uploadid': 'ADPycdvMtr6aGscwnoQh6-MT4UDk8N4A9WZmzmMJQi_U5XALKXaEeCbCUqqg9RqpHTWJlaKdwdMuj_YVJwBmVCzsbpg83lrhr_cJ', 'date': 'Fri, 21 Oct 2022 02:43:59 GMT', 'vary': 'Origin, X-Origin', 'www-authenticate': 'Bearer realm="https://accounts.google.com/"', 'cache-control': 'no-cache, no-store, max-age=0, must-revalidate', 'expires': 'Mon, 01 Jan 1990 00:00:00 GMT', 'pragma': 'no-cache', 'content-length': '438', 'server': 'UploadServer', 'content-type': 'text/html; charset=UTF-8', 'status': '401'}>, content <{
  "error": {
    "code": 401,
    "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
    "errors": [
      {
        "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
        "domain": "global",
        "reason": "required",
        "locationType": "header",
        "location": "Authorization"
      }
    ]
  }
}
>
=============================== warnings summary ===============================
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib and slated for removal in Python 3.12; see the module's documentation for alternative uses
    from imp import load_source

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

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

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

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

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

apache_beam/examples/complete/autocomplete_it_test.py: 1 warning
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 2 warnings
apache_beam/examples/complete/game/user_score_it_test.py: 6 warnings
apache_beam/examples/cookbook/bigquery_side_input_it_test.py: 4 warnings
apache_beam/examples/cookbook/coders_it_test.py: 1 warning
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/httplib2/__init__.py>:147: DeprecationWarning: ssl.PROTOCOL_TLS is deprecated
    context = ssl.SSLContext(DEFAULT_TLS_VERSION)

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1991: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    is_streaming_pipeline = p.options.view_as(StandardOptions).streaming

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1997: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    experiments = p.options.view_as(DebugOptions).experiments or []

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1133: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = p.options.view_as(GoogleCloudOptions).temp_location

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1135: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(GoogleCloudOptions).job_name or 'AUTOMATIC_JOB_NAME')

apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2484: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = pcoll.pipeline.options.view_as(

apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2486: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    job_name = pcoll.pipeline.options.view_as(GoogleCloudOptions).job_name

apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2510: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    pipeline_options=pcoll.pipeline.options,

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/pytest_postCommitIT-df-py310-no-xdist.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/complete/autocomplete_it_test.py::AutocompleteIT::test_autocomplete_output_files_on_small_input
FAILED apache_beam/examples/complete/estimate_pi_it_test.py::EstimatePiIT::test_estimate_pi_output_file
FAILED apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
FAILED apache_beam/examples/complete/game/user_score_it_test.py::UserScoreIT::test_userscore_output_checksum_on_small_input
FAILED apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
FAILED apache_beam/examples/cookbook/coders_it_test.py::CodersIT::test_coders_output_files_on_small_input
ERROR apache_beam/examples/complete/game/user_score_it_test.py::UserScoreIT::test_userscore_output_checksum_on_small_input
ERROR apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
= 6 failed, 4 skipped, 6650 deselected, 31 warnings, 2 errors in 4877.28s (1:21:17) =

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

FAILURE: Build failed with an exception.

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

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

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

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

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

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

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

BUILD FAILED in 1h 48m 35s
15 actionable tasks: 9 executed, 4 from cache, 2 up-to-date

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

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

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


Build failed in Jenkins: beam_PostCommit_Python_Examples_Dataflow #1022

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

Changes:

[noreply] Issue#23599 Updated dataframe notebook

[noreply] Added a missing line break.

[Chamikara Madhusanka Jayalath] Updating Python dependencies for the 2.43.0 release

[thiagotnunes] tests: fixes SpannerIO unavailable retry test

[noreply] Remove yeandy from reviewers (#23753)

[noreply] Revert bigdataoss version upgrade (#23727)

[Chamikara Madhusanka Jayalath] Moving to 2.44.0-SNAPSHOT on master branch.

[noreply] Update the timeout in ValidatesContainer suite. (#23732)


------------------------------------------
[...truncated 178.23 KB...]
                       client=None,  # pylint: disable=unused-argument
                       oauth2client_args=None,
                       **kwds):
        """Attempt to get credentials, using an oauth dance as the last resort."""
        scopes = util.NormalizeScopes(scopes)
        client_info = {
            'client_id': client_id,
            'client_secret': client_secret,
            'scope': ' '.join(sorted(scopes)),
            'user_agent': user_agent or '%s-generated/0.1' % package_name,
        }
        for method in _CREDENTIALS_METHODS:
            credentials = method(client_info, **kwds)
            if credentials is not None:
                return credentials
        credentials_filename = credentials_filename or os.path.expanduser(
            '~/.apitools.token')
        credentials = CredentialsFromFile(credentials_filename, client_info,
                                          oauth2client_args=oauth2client_args)
        if credentials is not None:
            return credentials
>       raise exceptions.CredentialsError('Could not create valid credentials')
E       apitools.base.py.exceptions.CredentialsError: Could not create valid credentials

../../build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/credentials_lib.py:157: CredentialsError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.runners.portability.stager:stager.py:754 Executing command: ['<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/bin/python3.10',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', '/tmp/tmprcq20ibj/tmp_requirements.txt', '--exists-action', 'i', '--no-deps', '--implementation', 'cp', '--abi', 'cp310', '--platform', 'manylinux2014_x86_64']
INFO     apache_beam.runners.portability.stager:stager.py:325 Copying Beam SDK "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/build/apache-beam.tar.gz"> to staging location.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:484 Pipeline has additional dependencies to be installed in SDK worker container, consider using the SDK container image pre-building workflow to avoid repetitive installations. Learn more on https://cloud.google.com/dataflow/docs/guides/using-custom-containers#prebuild
INFO     root:environments.py:376 Default Python SDK image for environment is apache/beam_python3.10_sdk:2.44.0.dev
INFO     root:environments.py:295 Using provided Python SDK container image: gcr.io/cloud-dataflow/v1beta3/python310-fnapi:beam-master-20221018
INFO     root:environments.py:302 Python SDK container image set to "gcr.io/cloud-dataflow/v1beta3/python310-fnapi:beam-master-20221018" for Docker environment
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function pack_combiners at 0x7f088ca50c10> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function sort_stages at 0x7f088ca513f0> ====================
WARNING  oauth2client.contrib.multiprocess_file_storage:multiprocess_file_storage.py:141 Credentials file could not be loaded, will ignore and overwrite.
WARNING  oauth2client.contrib.multiprocess_file_storage:multiprocess_file_storage.py:141 Credentials file could not be loaded, will ignore and overwrite.
_______________ CodersIT.test_coders_output_files_on_small_input _______________

self = <apache_beam.examples.cookbook.coders_it_test.CodersIT testMethod=test_coders_output_files_on_small_input>

    @pytest.mark.no_xdist
    @pytest.mark.examples_postcommit
    def test_coders_output_files_on_small_input(self):
      test_pipeline = TestPipeline(is_integration_test=True)
      # Setup the files with expected content.
      OUTPUT_FILE_DIR = \
          'gs://temp-storage-for-end-to-end-tests/py-it-cloud/output'
      output = '/'.join([OUTPUT_FILE_DIR, str(uuid.uuid4()), 'result'])
      INPUT_FILE_DIR = \
          'gs://temp-storage-for-end-to-end-tests/py-it-cloud/input'
      input = '/'.join([INPUT_FILE_DIR, str(uuid.uuid4()), 'input.txt'])
>     create_content_input_file(
          input, '\n'.join(map(json.dumps, self.SAMPLE_RECORDS)))

apache_beam/examples/cookbook/coders_it_test.py:90: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/examples/cookbook/coders_it_test.py:50: in create_content_input_file
    with gcs.open(path, 'w') as f:
apache_beam/io/filesystemio.py:215: in close
    self._uploader.finish()
apache_beam/io/gcp/gcsio.py:790: in finish
    raise self._upload_thread.last_error  # pylint: disable=raising-bad-type
apache_beam/io/gcp/gcsio.py:763: in _start_upload
    self._client.objects.Insert(self._insert_request, upload=self._upload)
apache_beam/io/gcp/internal/clients/storage/storage_v1_client.py:1152: in Insert
    return self._RunMethod(
../../build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/base_api.py:714: in _RunMethod
    http_response = upload.InitializeUpload(
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = Upload (uninitialized)
http_request = <apitools.base.py.http_wrapper.Request object at 0x7f08406a1b70>
http = <httplib2.Http object at 0x7f08406a2830>
client = <apache_beam.io.gcp.internal.clients.storage.storage_v1_client.StorageV1 object at 0x7f08406a2410>

    def InitializeUpload(self, http_request, http=None, client=None):
        """Initialize this upload from the given http_request."""
        if self.strategy is None:
            raise exceptions.UserError(
                'No upload strategy set; did you call ConfigureRequest?')
        if http is None and client is None:
            raise exceptions.UserError('Must provide client or http.')
        if self.strategy != RESUMABLE_UPLOAD:
            return
        http = http or client.http
        if client is not None:
            http_request.url = client.FinalizeTransferUrl(http_request.url)
        self.EnsureUninitialized()
        http_response = http_wrapper.MakeRequest(http, http_request,
                                                 retries=self.num_retries)
        if http_response.status_code != http_client.OK:
>           raise exceptions.HttpError.FromResponse(http_response)
E           apitools.base.py.exceptions.HttpUnauthorizedError: HttpError accessing <https://www.googleapis.com/resumable/upload/storage/v1/b/temp-storage-for-end-to-end-tests/o?alt=json&name=py-it-cloud%2Finput%2Fe3b00b6e-14eb-4968-bf85-bff01cae30c0%2Finput.txt&uploadType=resumable>: response: <{'x-guploader-uploadid': 'ADPycdubcz4M8aE5nNR2MPhm6z9YcuFTVHJNLGniVczPB9M6PlUzues0rrTY3DNKdqr2YJ2rv28MYtz6S1XyhhZ1XfR7Rw', 'date': 'Thu, 20 Oct 2022 20:44:16 GMT', 'vary': 'Origin, X-Origin', 'www-authenticate': 'Bearer realm="https://accounts.google.com/"', 'cache-control': 'no-cache, no-store, max-age=0, must-revalidate', 'expires': 'Mon, 01 Jan 1990 00:00:00 GMT', 'pragma': 'no-cache', 'content-length': '438', 'server': 'UploadServer', 'content-type': 'text/html; charset=UTF-8', 'status': '401'}>, content <{
E             "error": {
E               "code": 401,
E               "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
E               "errors": [
E                 {
E                   "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
E                   "domain": "global",
E                   "reason": "required",
E                   "locationType": "header",
E                   "location": "Authorization"
E                 }
E               ]
E             }
E           }
E           >

../../build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/transfer.py:896: HttpUnauthorizedError
------------------------------ Captured log call -------------------------------
INFO     root:coders_it_test.py:48 Creating file: gs://temp-storage-for-end-to-end-tests/py-it-cloud/input/e3b00b6e-14eb-4968-bf85-bff01cae30c0/input.txt
ERROR    apache_beam.io.gcp.gcsio:gcsio.py:767 Error in _start_upload while inserting file gs://temp-storage-for-end-to-end-tests/py-it-cloud/input/e3b00b6e-14eb-4968-bf85-bff01cae30c0/input.txt: Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 763, in _start_upload
    self._client.objects.Insert(self._insert_request, upload=self._upload)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/internal/clients/storage/storage_v1_client.py",> line 1152, in Insert
    return self._RunMethod(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/base_api.py",> line 714, in _RunMethod
    http_response = upload.InitializeUpload(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/transfer.py",> line 896, in InitializeUpload
    raise exceptions.HttpError.FromResponse(http_response)
apitools.base.py.exceptions.HttpUnauthorizedError: HttpError accessing <https://www.googleapis.com/resumable/upload/storage/v1/b/temp-storage-for-end-to-end-tests/o?alt=json&name=py-it-cloud%2Finput%2Fe3b00b6e-14eb-4968-bf85-bff01cae30c0%2Finput.txt&uploadType=resumable>: response: <{'x-guploader-uploadid': 'ADPycdubcz4M8aE5nNR2MPhm6z9YcuFTVHJNLGniVczPB9M6PlUzues0rrTY3DNKdqr2YJ2rv28MYtz6S1XyhhZ1XfR7Rw', 'date': 'Thu, 20 Oct 2022 20:44:16 GMT', 'vary': 'Origin, X-Origin', 'www-authenticate': 'Bearer realm="https://accounts.google.com/"', 'cache-control': 'no-cache, no-store, max-age=0, must-revalidate', 'expires': 'Mon, 01 Jan 1990 00:00:00 GMT', 'pragma': 'no-cache', 'content-length': '438', 'server': 'UploadServer', 'content-type': 'text/html; charset=UTF-8', 'status': '401'}>, content <{
  "error": {
    "code": 401,
    "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
    "errors": [
      {
        "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
        "domain": "global",
        "reason": "required",
        "locationType": "header",
        "location": "Authorization"
      }
    ]
  }
}
>
=============================== warnings summary ===============================
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib and slated for removal in Python 3.12; see the module's documentation for alternative uses
    from imp import load_source

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

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

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

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

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

apache_beam/examples/complete/autocomplete_it_test.py: 1 warning
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 2 warnings
apache_beam/examples/complete/game/user_score_it_test.py: 6 warnings
apache_beam/examples/cookbook/bigquery_side_input_it_test.py: 4 warnings
apache_beam/examples/cookbook/coders_it_test.py: 1 warning
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/httplib2/__init__.py>:147: DeprecationWarning: ssl.PROTOCOL_TLS is deprecated
    context = ssl.SSLContext(DEFAULT_TLS_VERSION)

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1991: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    is_streaming_pipeline = p.options.view_as(StandardOptions).streaming

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1997: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    experiments = p.options.view_as(DebugOptions).experiments or []

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1133: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = p.options.view_as(GoogleCloudOptions).temp_location

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1135: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(GoogleCloudOptions).job_name or 'AUTOMATIC_JOB_NAME')

apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2484: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = pcoll.pipeline.options.view_as(

apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2486: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    job_name = pcoll.pipeline.options.view_as(GoogleCloudOptions).job_name

apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2510: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    pipeline_options=pcoll.pipeline.options,

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/pytest_postCommitIT-df-py310-no-xdist.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/complete/autocomplete_it_test.py::AutocompleteIT::test_autocomplete_output_files_on_small_input
FAILED apache_beam/examples/complete/estimate_pi_it_test.py::EstimatePiIT::test_estimate_pi_output_file
FAILED apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
FAILED apache_beam/examples/complete/game/user_score_it_test.py::UserScoreIT::test_userscore_output_checksum_on_small_input
FAILED apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
FAILED apache_beam/examples/cookbook/coders_it_test.py::CodersIT::test_coders_output_files_on_small_input
ERROR apache_beam/examples/complete/game/user_score_it_test.py::UserScoreIT::test_userscore_output_checksum_on_small_input
ERROR apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
= 6 failed, 4 skipped, 6650 deselected, 31 warnings, 2 errors in 4885.21s (1:21:25) =

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

FAILURE: Build failed with an exception.

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

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

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

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

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

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

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

BUILD FAILED in 1h 48m 52s
15 actionable tasks: 9 executed, 4 from cache, 2 up-to-date

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

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

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


Build failed in Jenkins: beam_PostCommit_Python_Examples_Dataflow #1021

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

Changes:


------------------------------------------
[...truncated 178.50 KB...]
                       client=None,  # pylint: disable=unused-argument
                       oauth2client_args=None,
                       **kwds):
        """Attempt to get credentials, using an oauth dance as the last resort."""
        scopes = util.NormalizeScopes(scopes)
        client_info = {
            'client_id': client_id,
            'client_secret': client_secret,
            'scope': ' '.join(sorted(scopes)),
            'user_agent': user_agent or '%s-generated/0.1' % package_name,
        }
        for method in _CREDENTIALS_METHODS:
            credentials = method(client_info, **kwds)
            if credentials is not None:
                return credentials
        credentials_filename = credentials_filename or os.path.expanduser(
            '~/.apitools.token')
        credentials = CredentialsFromFile(credentials_filename, client_info,
                                          oauth2client_args=oauth2client_args)
        if credentials is not None:
            return credentials
>       raise exceptions.CredentialsError('Could not create valid credentials')
E       apitools.base.py.exceptions.CredentialsError: Could not create valid credentials

../../build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/credentials_lib.py:157: CredentialsError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.runners.portability.stager:stager.py:754 Executing command: ['<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/bin/python3.10',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', '/tmp/tmp27v80qwl/tmp_requirements.txt', '--exists-action', 'i', '--no-deps', '--implementation', 'cp', '--abi', 'cp310', '--platform', 'manylinux2014_x86_64']
INFO     apache_beam.runners.portability.stager:stager.py:325 Copying Beam SDK "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/build/apache-beam.tar.gz"> to staging location.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:484 Pipeline has additional dependencies to be installed in SDK worker container, consider using the SDK container image pre-building workflow to avoid repetitive installations. Learn more on https://cloud.google.com/dataflow/docs/guides/using-custom-containers#prebuild
INFO     root:environments.py:376 Default Python SDK image for environment is apache/beam_python3.10_sdk:2.43.0.dev
INFO     root:environments.py:295 Using provided Python SDK container image: gcr.io/cloud-dataflow/v1beta3/python310-fnapi:beam-master-20221018
INFO     root:environments.py:302 Python SDK container image set to "gcr.io/cloud-dataflow/v1beta3/python310-fnapi:beam-master-20221018" for Docker environment
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function pack_combiners at 0x7f032677cc10> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function sort_stages at 0x7f032677d3f0> ====================
WARNING  oauth2client.contrib.multiprocess_file_storage:multiprocess_file_storage.py:141 Credentials file could not be loaded, will ignore and overwrite.
WARNING  oauth2client.contrib.multiprocess_file_storage:multiprocess_file_storage.py:141 Credentials file could not be loaded, will ignore and overwrite.
_______________ CodersIT.test_coders_output_files_on_small_input _______________

self = <apache_beam.examples.cookbook.coders_it_test.CodersIT testMethod=test_coders_output_files_on_small_input>

    @pytest.mark.no_xdist
    @pytest.mark.examples_postcommit
    def test_coders_output_files_on_small_input(self):
      test_pipeline = TestPipeline(is_integration_test=True)
      # Setup the files with expected content.
      OUTPUT_FILE_DIR = \
          'gs://temp-storage-for-end-to-end-tests/py-it-cloud/output'
      output = '/'.join([OUTPUT_FILE_DIR, str(uuid.uuid4()), 'result'])
      INPUT_FILE_DIR = \
          'gs://temp-storage-for-end-to-end-tests/py-it-cloud/input'
      input = '/'.join([INPUT_FILE_DIR, str(uuid.uuid4()), 'input.txt'])
>     create_content_input_file(
          input, '\n'.join(map(json.dumps, self.SAMPLE_RECORDS)))

apache_beam/examples/cookbook/coders_it_test.py:90: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/examples/cookbook/coders_it_test.py:50: in create_content_input_file
    with gcs.open(path, 'w') as f:
apache_beam/io/filesystemio.py:215: in close
    self._uploader.finish()
apache_beam/io/gcp/gcsio.py:790: in finish
    raise self._upload_thread.last_error  # pylint: disable=raising-bad-type
apache_beam/io/gcp/gcsio.py:763: in _start_upload
    self._client.objects.Insert(self._insert_request, upload=self._upload)
apache_beam/io/gcp/internal/clients/storage/storage_v1_client.py:1152: in Insert
    return self._RunMethod(
../../build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/base_api.py:714: in _RunMethod
    http_response = upload.InitializeUpload(
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = Upload (uninitialized)
http_request = <apitools.base.py.http_wrapper.Request object at 0x7f02e5d22f50>
http = <httplib2.Http object at 0x7f02e5d226b0>
client = <apache_beam.io.gcp.internal.clients.storage.storage_v1_client.StorageV1 object at 0x7f02e5d22740>

    def InitializeUpload(self, http_request, http=None, client=None):
        """Initialize this upload from the given http_request."""
        if self.strategy is None:
            raise exceptions.UserError(
                'No upload strategy set; did you call ConfigureRequest?')
        if http is None and client is None:
            raise exceptions.UserError('Must provide client or http.')
        if self.strategy != RESUMABLE_UPLOAD:
            return
        http = http or client.http
        if client is not None:
            http_request.url = client.FinalizeTransferUrl(http_request.url)
        self.EnsureUninitialized()
        http_response = http_wrapper.MakeRequest(http, http_request,
                                                 retries=self.num_retries)
        if http_response.status_code != http_client.OK:
>           raise exceptions.HttpError.FromResponse(http_response)
E           apitools.base.py.exceptions.HttpUnauthorizedError: HttpError accessing <https://www.googleapis.com/resumable/upload/storage/v1/b/temp-storage-for-end-to-end-tests/o?alt=json&name=py-it-cloud%2Finput%2F5aed1df9-36bb-476a-9fca-75758ad3fe70%2Finput.txt&uploadType=resumable>: response: <{'x-guploader-uploadid': 'ADPycdssgOYOtXkuYkZx9e8dQPTry2dL3hu6gdMcwz--IFhyyq_EjSQOyr2xjqm6VtrcsQAJVtNa1-cqlxxjsJb6qwoUqQ', 'date': 'Thu, 20 Oct 2022 14:41:43 GMT', 'vary': 'Origin, X-Origin', 'www-authenticate': 'Bearer realm="https://accounts.google.com/"', 'cache-control': 'no-cache, no-store, max-age=0, must-revalidate', 'expires': 'Mon, 01 Jan 1990 00:00:00 GMT', 'pragma': 'no-cache', 'content-length': '438', 'server': 'UploadServer', 'content-type': 'text/html; charset=UTF-8', 'status': '401'}>, content <{
E             "error": {
E               "code": 401,
E               "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
E               "errors": [
E                 {
E                   "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
E                   "domain": "global",
E                   "reason": "required",
E                   "locationType": "header",
E                   "location": "Authorization"
E                 }
E               ]
E             }
E           }
E           >

../../build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/transfer.py:896: HttpUnauthorizedError
------------------------------ Captured log call -------------------------------
INFO     root:coders_it_test.py:48 Creating file: gs://temp-storage-for-end-to-end-tests/py-it-cloud/input/5aed1df9-36bb-476a-9fca-75758ad3fe70/input.txt
ERROR    apache_beam.io.gcp.gcsio:gcsio.py:767 Error in _start_upload while inserting file gs://temp-storage-for-end-to-end-tests/py-it-cloud/input/5aed1df9-36bb-476a-9fca-75758ad3fe70/input.txt: Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 763, in _start_upload
    self._client.objects.Insert(self._insert_request, upload=self._upload)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/internal/clients/storage/storage_v1_client.py",> line 1152, in Insert
    return self._RunMethod(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/base_api.py",> line 714, in _RunMethod
    http_response = upload.InitializeUpload(
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/transfer.py",> line 896, in InitializeUpload
    raise exceptions.HttpError.FromResponse(http_response)
apitools.base.py.exceptions.HttpUnauthorizedError: HttpError accessing <https://www.googleapis.com/resumable/upload/storage/v1/b/temp-storage-for-end-to-end-tests/o?alt=json&name=py-it-cloud%2Finput%2F5aed1df9-36bb-476a-9fca-75758ad3fe70%2Finput.txt&uploadType=resumable>: response: <{'x-guploader-uploadid': 'ADPycdssgOYOtXkuYkZx9e8dQPTry2dL3hu6gdMcwz--IFhyyq_EjSQOyr2xjqm6VtrcsQAJVtNa1-cqlxxjsJb6qwoUqQ', 'date': 'Thu, 20 Oct 2022 14:41:43 GMT', 'vary': 'Origin, X-Origin', 'www-authenticate': 'Bearer realm="https://accounts.google.com/"', 'cache-control': 'no-cache, no-store, max-age=0, must-revalidate', 'expires': 'Mon, 01 Jan 1990 00:00:00 GMT', 'pragma': 'no-cache', 'content-length': '438', 'server': 'UploadServer', 'content-type': 'text/html; charset=UTF-8', 'status': '401'}>, content <{
  "error": {
    "code": 401,
    "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
    "errors": [
      {
        "message": "Anonymous caller does not have storage.objects.create access to the Google Cloud Storage object.",
        "domain": "global",
        "reason": "required",
        "locationType": "header",
        "location": "Authorization"
      }
    ]
  }
}
>
=============================== warnings summary ===============================
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib and slated for removal in Python 3.12; see the module's documentation for alternative uses
    from imp import load_source

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

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

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

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

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

apache_beam/examples/complete/autocomplete_it_test.py: 1 warning
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 2 warnings
apache_beam/examples/complete/game/user_score_it_test.py: 6 warnings
apache_beam/examples/cookbook/bigquery_side_input_it_test.py: 4 warnings
apache_beam/examples/cookbook/coders_it_test.py: 1 warning
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/httplib2/__init__.py>:147: DeprecationWarning: ssl.PROTOCOL_TLS is deprecated
    context = ssl.SSLContext(DEFAULT_TLS_VERSION)

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1991: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    is_streaming_pipeline = p.options.view_as(StandardOptions).streaming

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1997: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    experiments = p.options.view_as(DebugOptions).experiments or []

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1133: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = p.options.view_as(GoogleCloudOptions).temp_location

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1135: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(GoogleCloudOptions).job_name or 'AUTOMATIC_JOB_NAME')

apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2484: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = pcoll.pipeline.options.view_as(

apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2486: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    job_name = pcoll.pipeline.options.view_as(GoogleCloudOptions).job_name

apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2510: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    pipeline_options=pcoll.pipeline.options,

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Dataflow/ws/src/sdks/python/pytest_postCommitIT-df-py310-no-xdist.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/complete/autocomplete_it_test.py::AutocompleteIT::test_autocomplete_output_files_on_small_input
FAILED apache_beam/examples/complete/estimate_pi_it_test.py::EstimatePiIT::test_estimate_pi_output_file
FAILED apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
FAILED apache_beam/examples/complete/game/user_score_it_test.py::UserScoreIT::test_userscore_output_checksum_on_small_input
FAILED apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
FAILED apache_beam/examples/cookbook/coders_it_test.py::CodersIT::test_coders_output_files_on_small_input
ERROR apache_beam/examples/complete/game/user_score_it_test.py::UserScoreIT::test_userscore_output_checksum_on_small_input
ERROR apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
= 6 failed, 4 skipped, 6650 deselected, 31 warnings, 2 errors in 4880.96s (1:21:20) =

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

FAILURE: Build failed with an exception.

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

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

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

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

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

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

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

BUILD FAILED in 1h 46m 19s
15 actionable tasks: 9 executed, 4 from cache, 2 up-to-date

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

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

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