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/18 06:22:35 UTC

Build failed in Jenkins: beam_PostCommit_Py_ValCont #9828

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

Changes:

[noreply] Fix python log_level_overrides cannot be used on flink and other

[noreply] Better error for disabling runner v2 with cross language pipelines.

[noreply] Update scopes to match the existing set and update test to clear


------------------------------------------
[...truncated 1.32 MB...]
gcloud docker -- push $CONTAINER:$TAG
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker


> Task :sdks:python:test-suites:dataflow:py38:validatesContainer

function cleanup_container {
  # Delete the container locally and remotely
  docker rmi $CONTAINER:$TAG || echo "Failed to remove container image"
  for image in $(docker images --format '{{.Repository}}:{{.Tag}}' | grep $PREBUILD_SDK_CONTAINER_REGISTRY_PATH)
    do docker rmi $image || echo "Failed to remove prebuilt sdk container image"
  done
  gcloud --quiet container images delete $CONTAINER:$TAG || echo "Failed to delete container"
  for digest in $(gcloud container images list-tags $PREBUILD_SDK_CONTAINER_REGISTRY_PATH/beam_python_prebuilt_sdk  --format="get(digest)")
    do gcloud container images delete $PREBUILD_SDK_CONTAINER_REGISTRY_PATH/beam_python_prebuilt_sdk@$digest --force-delete-tags --quiet || echo "Failed to remove prebuilt sdk container image"
  done

  echo "Removed the container"
}
trap cleanup_container EXIT

echo ">>> Successfully built and push container $CONTAINER"

cd sdks/python
SDK_LOCATION=$2

# Run ValidatesRunner tests on Google Cloud Dataflow service
echo ">>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST"
pytest -o junit_suite_name=$IMAGE_NAME \
  -m="it_validatescontainer" \
  --show-capture=no \
  --numprocesses=1 \
  --timeout=900 \
  --junitxml=$XUNIT_FILE \
  --ignore-glob '.*py3\d?\.py$' \
  --log-cli-level=INFO \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --region=$REGION \
    --sdk_container_image=$CONTAINER:$TAG \
    --staging_location=$GCS_LOCATION/staging-validatesrunner-test \
    --temp_location=$GCS_LOCATION/temp-validatesrunner-test \
    --output=$GCS_LOCATION/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1 \
    --docker_registry_push_url=$PREBUILD_SDK_CONTAINER_REGISTRY_PATH"

> Task :sdks:python:test-suites:dataflow:py37:validatesContainer

function cleanup_container {
  # Delete the container locally and remotely
  docker rmi $CONTAINER:$TAG || echo "Failed to remove container image"
  for image in $(docker images --format '{{.Repository}}:{{.Tag}}' | grep $PREBUILD_SDK_CONTAINER_REGISTRY_PATH)
    do docker rmi $image || echo "Failed to remove prebuilt sdk container image"
  done
  gcloud --quiet container images delete $CONTAINER:$TAG || echo "Failed to delete container"
  for digest in $(gcloud container images list-tags $PREBUILD_SDK_CONTAINER_REGISTRY_PATH/beam_python_prebuilt_sdk  --format="get(digest)")
    do gcloud container images delete $PREBUILD_SDK_CONTAINER_REGISTRY_PATH/beam_python_prebuilt_sdk@$digest --force-delete-tags --quiet || echo "Failed to remove prebuilt sdk container image"
  done

  echo "Removed the container"
}
trap cleanup_container EXIT

echo ">>> Successfully built and push container $CONTAINER"

cd sdks/python
SDK_LOCATION=$2

# Run ValidatesRunner tests on Google Cloud Dataflow service
echo ">>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST"
pytest -o junit_suite_name=$IMAGE_NAME \
  -m="it_validatescontainer" \
  --show-capture=no \
  --numprocesses=1 \
  --timeout=900 \
  --junitxml=$XUNIT_FILE \
  --ignore-glob '.*py3\d?\.py$' \
  --log-cli-level=INFO \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --region=$REGION \
    --sdk_container_image=$CONTAINER:$TAG \
    --staging_location=$GCS_LOCATION/staging-validatesrunner-test \
    --temp_location=$GCS_LOCATION/temp-validatesrunner-test \
    --output=$GCS_LOCATION/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1 \
    --docker_registry_push_url=$PREBUILD_SDK_CONTAINER_REGISTRY_PATH"

> Task :sdks:python:test-suites:dataflow:py39:validatesContainer

function cleanup_container {
  # Delete the container locally and remotely
  docker rmi $CONTAINER:$TAG || echo "Failed to remove container image"
  for image in $(docker images --format '{{.Repository}}:{{.Tag}}' | grep $PREBUILD_SDK_CONTAINER_REGISTRY_PATH)
    do docker rmi $image || echo "Failed to remove prebuilt sdk container image"
  done
  gcloud --quiet container images delete $CONTAINER:$TAG || echo "Failed to delete container"
  for digest in $(gcloud container images list-tags $PREBUILD_SDK_CONTAINER_REGISTRY_PATH/beam_python_prebuilt_sdk  --format="get(digest)")
    do gcloud container images delete $PREBUILD_SDK_CONTAINER_REGISTRY_PATH/beam_python_prebuilt_sdk@$digest --force-delete-tags --quiet || echo "Failed to remove prebuilt sdk container image"
  done

  echo "Removed the container"
}
trap cleanup_container EXIT

echo ">>> Successfully built and push container $CONTAINER"

cd sdks/python
SDK_LOCATION=$2

# Run ValidatesRunner tests on Google Cloud Dataflow service
echo ">>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST"
pytest -o junit_suite_name=$IMAGE_NAME \
  -m="it_validatescontainer" \
  --show-capture=no \
  --numprocesses=1 \
  --timeout=900 \
  --junitxml=$XUNIT_FILE \
  --ignore-glob '.*py3\d?\.py$' \
  --log-cli-level=INFO \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --region=$REGION \
    --sdk_container_image=$CONTAINER:$TAG \
    --staging_location=$GCS_LOCATION/staging-validatesrunner-test \
    --temp_location=$GCS_LOCATION/temp-validatesrunner-test \
    --output=$GCS_LOCATION/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1 \
    --docker_registry_push_url=$PREBUILD_SDK_CONTAINER_REGISTRY_PATH"

echo ">>> SUCCESS DATAFLOW RUNNER VALIDATESCONTAINER TEST"
cleanup_container

> Task :sdks:python:test-suites:dataflow:py38:validatesContainer

echo ">>> SUCCESS DATAFLOW RUNNER VALIDATESCONTAINER TEST"
cleanup_container
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk@sha256:2c2845c0b2fc9ac3900adb844a59a9f77a19980e67bf44dd71ab628b181763ea
  Associated tags:
 - 20221018-054024039474656
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk:20221018-054024039474656
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk:20221018-054024039474656].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk@sha256:2c2845c0b2fc9ac3900adb844a59a9f77a19980e67bf44dd71ab628b181763ea].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:2893a45759d130685a886e21b39ca4604d5f77e37d27dc6d5515e23a61708648
  Associated tags:
 - c81d36cb-fb39-489c-bd88-0efca5306cbe
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk:c81d36cb-fb39-489c-bd88-0efca5306cbe].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:2893a45759d130685a886e21b39ca4604d5f77e37d27dc6d5515e23a61708648].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:89cbe685ee25d6e631863dc46a4ac3cdfef99a9ce14d8a197ef52133fb8b35d1
  Associated tags:
 - 65a5e424-3a59-4fbc-82a5-bc0832b2d460
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk:65a5e424-3a59-4fbc-82a5-bc0832b2d460].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:89cbe685ee25d6e631863dc46a4ac3cdfef99a9ce14d8a197ef52133fb8b35d1].

> Task :sdks:python:test-suites:dataflow:py39:validatesContainer
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.9_sdk@sha256:40cdd74311c34cc1d0c13c2566aab8a3810df561de686553a9f38b647d286cd4
  Associated tags:
 - 20221018-054024055132541
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.9_sdk:20221018-054024055132541
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.9_sdk:20221018-054024055132541].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.9_sdk@sha256:40cdd74311c34cc1d0c13c2566aab8a3810df561de686553a9f38b647d286cd4].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk@sha256:3e34c0b17cd64e6a28bcb51a0647f1f0b08c5ea2532bda3f5bf833bbdd863e0f
  Associated tags:
 - 93d6b915-3797-419a-aa92-1ab3c79bb2d7
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk:93d6b915-3797-419a-aa92-1ab3c79bb2d7].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk@sha256:3e34c0b17cd64e6a28bcb51a0647f1f0b08c5ea2532bda3f5bf833bbdd863e0f].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk@sha256:32428fdea6760b43adbe80c748502ab5f562796a591ca9929511016fd7f9098a
  Associated tags:
 - 1772dd66-50a8-4e5a-b752-650aacf66b0e
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk:1772dd66-50a8-4e5a-b752-650aacf66b0e].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk@sha256:32428fdea6760b43adbe80c748502ab5f562796a591ca9929511016fd7f9098a].
Removed the container

> Task :sdks:python:test-suites:dataflow:py37:validatesContainer
cleanup_container
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk@sha256:d7897e1c4f8ed962d58a5e7601fe462ac36535da0350a814b3b02b28e0d23efe
  Associated tags:
 - 20221018-054024071235947
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk:20221018-054024071235947
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk:20221018-054024071235947].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk@sha256:d7897e1c4f8ed962d58a5e7601fe462ac36535da0350a814b3b02b28e0d23efe].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk@sha256:e786b7351905080cbfea6acf0a67572be06522fdb715db7f8b5e2ec207f0ad44
  Associated tags:
 - e4231172-6b49-4e60-8922-05dd15a65457
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk:e4231172-6b49-4e60-8922-05dd15a65457].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk@sha256:e786b7351905080cbfea6acf0a67572be06522fdb715db7f8b5e2ec207f0ad44].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk@sha256:e5c40675db359f9b2bebe13c43ee05142b3cf53b8b15914ed270581dd3b32885
  Associated tags:
 - a5429146-2d9e-44de-b599-55669ed21f48
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk:a5429146-2d9e-44de-b599-55669ed21f48].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk@sha256:e5c40675db359f9b2bebe13c43ee05142b3cf53b8b15914ed270581dd3b32885].

> Task :sdks:python:test-suites:dataflow:py37:validatesContainer FAILED

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesContainer'.
> 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 53m 58s
51 actionable tasks: 41 executed, 4 from cache, 6 up-to-date

Publishing build scan...
https://gradle.com/s/2luptcr3qsjv6

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_Py_ValCont #9831

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/9831/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_Py_ValCont #9830

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

Changes:

[noreply] [GitHub Actions] - Run RC Validations Workflow  (#23531)

[noreply] Add workflow to update milestone on issue close (#23629)

[noreply] add website page about data processing for ML (#23552)

[noreply] [Go SDK] Dataframe API wrapper  (#23450)

[noreply] [Go SDK]: Adds Automated Python Expansion Service (#23582)

[noreply] Include CombineFn's in __all__ (#23685)

[noreply] Bump google.golang.org/grpc from 1.50.0 to 1.50.1 in /sdks (#23654)

[noreply] [Playground][Frontend] Tags filter for Examples Catalog (#22074)


------------------------------------------
[...truncated 1.34 MB...]
> Task :sdks:python:test-suites:dataflow:py39:validatesContainer

[gw0] [ 50%] PASSED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it_with_prebuilt_sdk_container_cloud_build 
apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it_with_prebuilt_sdk_container_local_docker 
> Task :sdks:python:test-suites:dataflow:py38:validatesContainer

[gw0] [ 50%] FAILED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it_with_prebuilt_sdk_container_cloud_build 
apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it_with_prebuilt_sdk_container_local_docker 
> Task :sdks:python:test-suites:dataflow:py37:validatesContainer

[gw0] [ 75%] PASSED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it_with_prebuilt_sdk_container_local_docker 
apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py::ExerciseMetricsPipelineTest::test_metrics_fnapi_it 
> Task :sdks:python:test-suites:dataflow:py38:validatesContainer

[gw0] [ 75%] PASSED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it_with_prebuilt_sdk_container_local_docker 
apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py::ExerciseMetricsPipelineTest::test_metrics_fnapi_it 
> Task :sdks:python:test-suites:dataflow:py39:validatesContainer

[gw0] [ 75%] PASSED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it_with_prebuilt_sdk_container_local_docker 
apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py::ExerciseMetricsPipelineTest::test_metrics_fnapi_it 
> Task :sdks:python:test-suites:dataflow:py37:validatesContainer

[gw0] [100%] PASSED apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py::ExerciseMetricsPipelineTest::test_metrics_fnapi_it 

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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/pytest-beam_python3.7_sdk.xml> -
============ 4 passed, 3 skipped, 2 warnings in 2250.20s (0:37:30) =============

>>> SUCCESS DATAFLOW RUNNER VALIDATESCONTAINER TEST
echo ">>> SUCCESS DATAFLOW RUNNER VALIDATESCONTAINER TEST"
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk:20221018-165225012363778
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk@sha256:8181cb2a8d3060af537af574230fcd09d5837167331de8e03c6d062ab2dadadd
Untagged: us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk:8126ca6d-b814-454f-9da7-a81c2b8a5d2b
Untagged: us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk@sha256:a641f427fdafd7ff19e88bf2e744aaf82143b93e5a0b9bdab66c89e322d4d0ef
Deleted: sha256:9c9a54aed97854e8783d150525f531fd7d1ad141895130db076c059c5085fe9b
Deleted: sha256:79be5e475dc10f0785f2de9d0e91dc219d90ac0eae20595ce092d04c57dbe52d
Deleted: sha256:4521777660298c0363c257940ac8b2959011324adf2cf69ce1d6d9309fd9b47d
Deleted: sha256:472dbd0a19bac90457721149ee20eb3722d27561dd8857d4fefdc286842b5900
Deleted: sha256:28b7a74630181fff924488e15d23dd0e8153dd613b2107eb0d1ff23d9df87ede
Deleted: sha256:a7128fb879d7424bb67cbe508ec7548820b983cdb6423d37c57ced5aa4761e3c
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk@sha256:8181cb2a8d3060af537af574230fcd09d5837167331de8e03c6d062ab2dadadd
  Associated tags:
 - 20221018-165225012363778
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk:20221018-165225012363778
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk:20221018-165225012363778].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk@sha256:8181cb2a8d3060af537af574230fcd09d5837167331de8e03c6d062ab2dadadd].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk@sha256:a641f427fdafd7ff19e88bf2e744aaf82143b93e5a0b9bdab66c89e322d4d0ef
  Associated tags:
 - 8126ca6d-b814-454f-9da7-a81c2b8a5d2b
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk:8126ca6d-b814-454f-9da7-a81c2b8a5d2b].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk@sha256:a641f427fdafd7ff19e88bf2e744aaf82143b93e5a0b9bdab66c89e322d4d0ef].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk@sha256:d84c11779793a632de97866a27b200a6126f29b63a20e11b6155450793ef7502
  Associated tags:
 - c239ea86-6656-49dc-bdae-84cd8c81246f
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk:c239ea86-6656-49dc-bdae-84cd8c81246f].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk@sha256:d84c11779793a632de97866a27b200a6126f29b63a20e11b6155450793ef7502].
Removed the container

> Task :sdks:python:test-suites:dataflow:py38:validatesContainer

[gw0] [100%] PASSED apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py::ExerciseMetricsPipelineTest::test_metrics_fnapi_it 

=================================== FAILURES ===================================
____ WordCountIT.test_wordcount_it_with_prebuilt_sdk_container_cloud_build _____
[gw0] linux -- Python 3.8.10 <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/build/gradleenv/-1734967051/bin/python3.8>

self = <apache_beam.examples.wordcount_it_test.WordCountIT testMethod=test_wordcount_it_with_prebuilt_sdk_container_cloud_build>

    @pytest.mark.it_validatescontainer
    def test_wordcount_it_with_prebuilt_sdk_container_cloud_build(self):
>     self._run_wordcount_it(
          wordcount.run,
          experiment='beam_fn_api',
          prebuild_sdk_container_engine='cloud_build')

apache_beam/examples/wordcount_it_test.py:106: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/examples/wordcount_it_test.py:149: in _run_wordcount_it
    run_wordcount(
apache_beam/examples/wordcount.py:106: in run
    output | 'Write' >> WriteToText(known_args.output)
apache_beam/pipeline.py:597: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:547: in run
    return Pipeline.from_runner_api(
apache_beam/pipeline.py:574: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/dataflow/test_dataflow_runner.py:66: in run_pipeline
    self.result.wait_until_finish(duration=wait_duration)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <DataflowPipelineResult <Job
 clientRequestId: '20221018171108512280-9986'
 createTime: '2022-10-18T17:11:10.842824Z'
...022-10-18T17:11:10.842824Z'
 steps: []
 tempFiles: []
 type: TypeValueValuesEnum(JOB_TYPE_BATCH, 1)> at 0x7f6056924d60>
duration = None

    def wait_until_finish(self, duration=None):
      if not self.is_in_terminal_state():
        if not self.has_job:
          raise IOError('Failed to get the Dataflow job id.')
        consoleUrl = (
            "Console URL: https://console.cloud.google.com/"
            f"dataflow/jobs/<RegionId>/{self.job_id()}"
            "?project=<ProjectId>")
        thread = threading.Thread(
            target=DataflowRunner.poll_for_job_completion,
            args=(self._runner, self, duration))
    
        # Mark the thread as a daemon thread so a keyboard interrupt on the main
        # thread will terminate everything. This is also the reason we will not
        # use thread.join() to wait for the polling thread.
        thread.daemon = True
        thread.start()
        while thread.is_alive():
>         time.sleep(5.0)
E         Failed: Timeout >900.0s

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

../../build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/build/gradleenv/-1734967051/lib/python3.8/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_Py_ValCont/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_Py_ValCont/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_Py_ValCont/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'),

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/pytest-beam_python3.8_sdk.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it_with_prebuilt_sdk_container_cloud_build
======= 1 failed, 3 passed, 3 skipped, 6 warnings in 2328.16s (0:38:48) ========
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk:20221018-165225012367658
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk@sha256:9c3cd39aa6bbbea54598dbf8d1d690addf75db783f9a77afa59f0305f619b8a9
Untagged: us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk:2cca3eb2-01fc-4a0b-b293-1794919a5365
Untagged: us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:a4544dbe4b7b4fc41c0d30b4f59a7f04c4e04f73076f85ba8f28a34ce9cf81da
Deleted: sha256:5051adca22c20f3188dab163acbc7d5458d915d72bb1200231a4a8bf0f8d43fa
Deleted: sha256:3b02cdcb4973eb8164773aab42719a14d807c24f9561bfb94fe81044ca7c842f
Deleted: sha256:c96a92bf8a8e8494de5292697a271c64e91ea20b8a5d73a9baaac71e1d8f9af0
Deleted: sha256:2f01af814ecff5ff01d7617145dda34f41e7455a4fb4dfaca02d735b9a473965
Deleted: sha256:02b850f1f4c7ca8fab26243106b7f454c030f8325698b963ac24c9386c631703
Deleted: sha256:4b36e9fef0ff186eb528cf6d8e7e0109b85223963445ba805b67f26bb6a97339
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk@sha256:9c3cd39aa6bbbea54598dbf8d1d690addf75db783f9a77afa59f0305f619b8a9
  Associated tags:
 - 20221018-165225012367658
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk:20221018-165225012367658
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk:20221018-165225012367658].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk@sha256:9c3cd39aa6bbbea54598dbf8d1d690addf75db783f9a77afa59f0305f619b8a9].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:a4544dbe4b7b4fc41c0d30b4f59a7f04c4e04f73076f85ba8f28a34ce9cf81da
  Associated tags:
 - 2cca3eb2-01fc-4a0b-b293-1794919a5365
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk:2cca3eb2-01fc-4a0b-b293-1794919a5365].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:a4544dbe4b7b4fc41c0d30b4f59a7f04c4e04f73076f85ba8f28a34ce9cf81da].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:cc849cd81a4a94d39833609ef8e6a725746af22978cfca2b770635e2301eac9f
  Associated tags:
 - 4b50dea7-8604-444b-ab1f-007e64977eb1
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk:4b50dea7-8604-444b-ab1f-007e64977eb1].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:cc849cd81a4a94d39833609ef8e6a725746af22978cfca2b770635e2301eac9f].
Removed the container

> Task :sdks:python:test-suites:dataflow:py38:validatesContainer FAILED

> Task :sdks:python:test-suites:dataflow:py39:validatesContainer

echo ">>> SUCCESS DATAFLOW RUNNER VALIDATESCONTAINER TEST"
cleanup_container
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.9_sdk@sha256:a139746d8e80dcf078d8822fd9ce8b2a0f41d32dea89e0511d08a9276daeea0a
  Associated tags:
 - 20221018-165225012383880
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.9_sdk:20221018-165225012383880
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.9_sdk:20221018-165225012383880].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.9_sdk@sha256:a139746d8e80dcf078d8822fd9ce8b2a0f41d32dea89e0511d08a9276daeea0a].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk@sha256:1232b0670616fe246aa6495e199710579ab99c299ffb69f589fcbb64f592ee9d
  Associated tags:
 - 515f4772-cba0-4764-9b67-54212b88914b
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk:515f4772-cba0-4764-9b67-54212b88914b].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk@sha256:1232b0670616fe246aa6495e199710579ab99c299ffb69f589fcbb64f592ee9d].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk@sha256:388b7bf68d79bd2817b6e53209f91e7d77246d0870661aa7fa757d599ca6ab9d
  Associated tags:
 - d87f8105-047a-46f7-91a6-e744b6ebfc61
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk:d87f8105-047a-46f7-91a6-e744b6ebfc61].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk@sha256:388b7bf68d79bd2817b6e53209f91e7d77246d0870661aa7fa757d599ca6ab9d].

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesContainer'.
> 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 53m 40s
51 actionable tasks: 41 executed, 4 from cache, 6 up-to-date

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

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_Py_ValCont #9829

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

Changes:

[Alexey Romanenko] [TPC-DS] Use "nonpartitioned" input for Jenkins jobs


------------------------------------------
[...truncated 1.35 MB...]
  docker rmi $CONTAINER:$TAG || echo "Failed to remove container image"
  for image in $(docker images --format '{{.Repository}}:{{.Tag}}' | grep $PREBUILD_SDK_CONTAINER_REGISTRY_PATH)
    do docker rmi $image || echo "Failed to remove prebuilt sdk container image"
  done
  gcloud --quiet container images delete $CONTAINER:$TAG || echo "Failed to delete container"
  for digest in $(gcloud container images list-tags $PREBUILD_SDK_CONTAINER_REGISTRY_PATH/beam_python_prebuilt_sdk  --format="get(digest)")
    do gcloud container images delete $PREBUILD_SDK_CONTAINER_REGISTRY_PATH/beam_python_prebuilt_sdk@$digest --force-delete-tags --quiet || echo "Failed to remove prebuilt sdk container image"
  done

  echo "Removed the container"
}
trap cleanup_container EXIT

echo ">>> Successfully built and push container $CONTAINER"

cd sdks/python
SDK_LOCATION=$2

# Run ValidatesRunner tests on Google Cloud Dataflow service
echo ">>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST"
pytest -o junit_suite_name=$IMAGE_NAME \
  -m="it_validatescontainer" \
  --show-capture=no \
  --numprocesses=1 \
  --timeout=900 \
  --junitxml=$XUNIT_FILE \
  --ignore-glob '.*py3\d?\.py$' \
  --log-cli-level=INFO \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --region=$REGION \
    --sdk_container_image=$CONTAINER:$TAG \
    --staging_location=$GCS_LOCATION/staging-validatesrunner-test \
    --temp_location=$GCS_LOCATION/temp-validatesrunner-test \
    --output=$GCS_LOCATION/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1 \
    --docker_registry_push_url=$PREBUILD_SDK_CONTAINER_REGISTRY_PATH"

> Task :sdks:python:test-suites:dataflow:py37:validatesContainer

echo ">>> SUCCESS DATAFLOW RUNNER VALIDATESCONTAINER TEST"
cleanup_container
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk@sha256:6fa3e8b08aebf792b0d15aeb4c626f5bab99e3f3a1c4d1fbcdda020830ba7b83
  Associated tags:
 - 20221018-105412629141695
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk:20221018-105412629141695
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk:20221018-105412629141695].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk@sha256:6fa3e8b08aebf792b0d15aeb4c626f5bab99e3f3a1c4d1fbcdda020830ba7b83].

> Task :sdks:python:test-suites:dataflow:py39:validatesContainer

echo ">>> SUCCESS DATAFLOW RUNNER VALIDATESCONTAINER TEST"
cleanup_container
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.9_sdk@sha256:65b85ec95a0e5289bcc544a0be71685212e24f6820acf26bfddf217e6ef51ca9
  Associated tags:
 - 20221018-105412666033512
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.9_sdk:20221018-105412666033512
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.9_sdk:20221018-105412666033512].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.9_sdk@sha256:65b85ec95a0e5289bcc544a0be71685212e24f6820acf26bfddf217e6ef51ca9].

> Task :sdks:python:test-suites:dataflow:py37:validatesContainer
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk@sha256:c68b126419c2d2076d381206006edd854dbb4683e4cd814abcb81061d9bb627c
  Associated tags:
 - 429cf689-518e-40b9-89b4-a5fa2dcd61e3
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk:429cf689-518e-40b9-89b4-a5fa2dcd61e3].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk@sha256:c68b126419c2d2076d381206006edd854dbb4683e4cd814abcb81061d9bb627c].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk@sha256:1de0e7d10e0c271b8c926a990c7df4c5711d523c87922c9b8f057bea3ac4ab9d
  Associated tags:
 - 1025ac92-99fc-464e-b079-3eb33fd93b68
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk:1025ac92-99fc-464e-b079-3eb33fd93b68].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python37_sdk/beam_python_prebuilt_sdk@sha256:1de0e7d10e0c271b8c926a990c7df4c5711d523c87922c9b8f057bea3ac4ab9d].

> Task :sdks:python:test-suites:dataflow:py39:validatesContainer
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk@sha256:58173ed826925bcfe5a11f9af97b6abf11bb85160f49fb5e18b06ccc329d3c4a
  Associated tags:
 - fb4d33fc-bf35-4cde-96a3-8e28a3ce0bbf
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk:fb4d33fc-bf35-4cde-96a3-8e28a3ce0bbf].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk@sha256:58173ed826925bcfe5a11f9af97b6abf11bb85160f49fb5e18b06ccc329d3c4a].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk@sha256:60fed0a13cf1a2c3c27e59624b69d75b28d1412fff7218325ccb62027da1f8db
  Associated tags:
 - f09adf82-4716-4cae-989e-7e54ef13d98d
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk:f09adf82-4716-4cae-989e-7e54ef13d98d].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python39_sdk/beam_python_prebuilt_sdk@sha256:60fed0a13cf1a2c3c27e59624b69d75b28d1412fff7218325ccb62027da1f8db].

> Task :sdks:python:test-suites:dataflow:py38:validatesContainer

[gw0] [100%] PASSED apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py::ExerciseMetricsPipelineTest::test_metrics_fnapi_it 

=================================== FAILURES ===================================
____ WordCountIT.test_wordcount_it_with_prebuilt_sdk_container_cloud_build _____
[gw0] linux -- Python 3.8.10 <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/build/gradleenv/-1734967051/bin/python3.8>

self = <apache_beam.examples.wordcount_it_test.WordCountIT testMethod=test_wordcount_it_with_prebuilt_sdk_container_cloud_build>

    @pytest.mark.it_validatescontainer
    def test_wordcount_it_with_prebuilt_sdk_container_cloud_build(self):
>     self._run_wordcount_it(
          wordcount.run,
          experiment='beam_fn_api',
          prebuild_sdk_container_engine='cloud_build')

apache_beam/examples/wordcount_it_test.py:106: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/examples/wordcount_it_test.py:149: in _run_wordcount_it
    run_wordcount(
apache_beam/examples/wordcount.py:106: in run
    output | 'Write' >> WriteToText(known_args.output)
apache_beam/pipeline.py:597: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:547: in run
    return Pipeline.from_runner_api(
apache_beam/pipeline.py:574: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/dataflow/test_dataflow_runner.py:66: in run_pipeline
    self.result.wait_until_finish(duration=wait_duration)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <DataflowPipelineResult <Job
 clientRequestId: '20221018111232735471-9986'
 createTime: '2022-10-18T11:12:33.845021Z'
...022-10-18T11:12:33.845021Z'
 steps: []
 tempFiles: []
 type: TypeValueValuesEnum(JOB_TYPE_BATCH, 1)> at 0x7f6e3abb9970>
duration = None

    def wait_until_finish(self, duration=None):
      if not self.is_in_terminal_state():
        if not self.has_job:
          raise IOError('Failed to get the Dataflow job id.')
        consoleUrl = (
            "Console URL: https://console.cloud.google.com/"
            f"dataflow/jobs/<RegionId>/{self.job_id()}"
            "?project=<ProjectId>")
        thread = threading.Thread(
            target=DataflowRunner.poll_for_job_completion,
            args=(self._runner, self, duration))
    
        # Mark the thread as a daemon thread so a keyboard interrupt on the main
        # thread will terminate everything. This is also the reason we will not
        # use thread.join() to wait for the polling thread.
        thread.daemon = True
        thread.start()
        while thread.is_alive():
>         time.sleep(5.0)
E         Failed: Timeout >900.0s

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

../../build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/build/gradleenv/-1734967051/lib/python3.8/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_Py_ValCont/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_Py_ValCont/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_Py_ValCont/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'),

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/pytest-beam_python3.8_sdk.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it_with_prebuilt_sdk_container_cloud_build
======= 1 failed, 3 passed, 3 skipped, 6 warnings in 2330.70s (0:38:50) ========
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk:20221018-105412467124395
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk@sha256:675117c94e1455ec637f4cdb40fdc897e91d428fc569bf6caf0b5e0ad034b106
Untagged: us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk:d3388398-7198-44f9-b279-ebfbf35eebc4
Untagged: us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:9c016f3b9038151344a2515ec2235cc711cdefcc8e84cab2665ee9e05de67b3d
Deleted: sha256:7d8b2061bbf23d18f7e567df8ce14082463938ef62ba382d5863e26fb0c71a82
Deleted: sha256:1fa53c88d07a93d48b210d47e3de169a8fee664485006fcfa145ba8a975ebc0e
Deleted: sha256:efa8a425bb5c87835c1c2bc0df02743a01f980349cfaedbbe8a119c24cec0a28
Deleted: sha256:36fdd1130f903c1189225eb59639c7b32879a3c2fc4310e9ff78a470aa4c10fb
Deleted: sha256:c448a69cda304441259336e6a34ff5aa20ef3fce86cfcd32460107020508cd2e
Deleted: sha256:93c489ee19831a13bd7234085ff706f2da8ff32f437b7ef5a8b74ada33c1e36e
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk@sha256:675117c94e1455ec637f4cdb40fdc897e91d428fc569bf6caf0b5e0ad034b106
  Associated tags:
 - 20221018-105412467124395
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk:20221018-105412467124395
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk:20221018-105412467124395].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk@sha256:675117c94e1455ec637f4cdb40fdc897e91d428fc569bf6caf0b5e0ad034b106].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:9c016f3b9038151344a2515ec2235cc711cdefcc8e84cab2665ee9e05de67b3d
  Associated tags:
 - d3388398-7198-44f9-b279-ebfbf35eebc4
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk:d3388398-7198-44f9-b279-ebfbf35eebc4].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:9c016f3b9038151344a2515ec2235cc711cdefcc8e84cab2665ee9e05de67b3d].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:31a8af08209ac143306616bcca0c2e082ceb743314a4f712c825e0cbce5608a0
  Associated tags:
 - a82243e6-2773-451e-840c-d1bbd462f889
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk:a82243e6-2773-451e-840c-d1bbd462f889].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:31a8af08209ac143306616bcca0c2e082ceb743314a4f712c825e0cbce5608a0].
Removed the container

> Task :sdks:python:test-suites:dataflow:py38:validatesContainer FAILED

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesContainer'.
> 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 55m 16s
51 actionable tasks: 41 executed, 4 from cache, 6 up-to-date

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

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