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 2021/09/16 12:40:57 UTC

Build failed in Jenkins: beam_PostCommit_XVR_Spark3 #695

See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark3/695/display/redirect>

Changes:


------------------------------------------
[...truncated 110.96 KB...]
WARNING  root:environments.py:374 Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
______________________ SqlTransformTest.test_tagged_join _______________________

self = <apache_beam.transforms.sql_test.SqlTransformTest testMethod=test_tagged_join>

    def test_tagged_join(self):
      with TestPipeline() as p:
        enrich = (
            p | "Create enrich" >> beam.Create(
                [Enrich(1, "a"), Enrich(2, "b"), Enrich(26, "z")]))
        simple = (
            p | "Create simple" >> beam.Create([
                SimpleRow(1, "foo", 3.14),
                SimpleRow(26, "bar", 1.11),
                SimpleRow(1, "baz", 2.34)
            ]))
        out = ({
            'simple': simple, 'enrich': enrich
        }
               | SqlTransform(
                   """
                SELECT
                  simple.`id` AS `id`,
                  enrich.metadata AS metadata
                FROM simple
                JOIN enrich
                ON simple.`id` = enrich.`id`"""))
>       assert_that(out, equal_to([(1, "a"), (26, "z"), (1, "a")]))

apache_beam/transforms/sql_test.py:141: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/pipeline.py:590: in __exit__
    self.result = self.run()
apache_beam/testing/test_pipeline.py:114: in run
    False if self.not_use_test_runner_api else test_runner_api))
apache_beam/pipeline.py:567: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/portability/portable_runner.py:438: in run_pipeline
    job_service_handle = self.create_job_service(options)
apache_beam/runners/portability/portable_runner.py:317: in create_job_service
    return self.create_job_service_handle(server.start(), options)
apache_beam/runners/portability/job_server.py:54: in start
    grpc.channel_ready_future(channel).result(timeout=self._timeout)
../../build/gradleenv/1922375555/lib/python3.6/site-packages/grpc/_utilities.py:139: in result
    self._block(timeout)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <grpc._utilities._ChannelReadyFuture object at 0x7f888c13ee80>
timeout = 60

    def _block(self, timeout):
        until = None if timeout is None else time.time() + timeout
        with self._condition:
            while True:
                if self._cancelled:
                    raise grpc.FutureCancelledError()
                elif self._matured:
                    return
                else:
                    if until is None:
                        self._condition.wait()
                    else:
                        remaining = until - time.time()
                        if remaining < 0:
>                           raise grpc.FutureTimeoutError()
E                           grpc.FutureTimeoutError

../../build/gradleenv/1922375555/lib/python3.6/site-packages/grpc/_utilities.py:85: FutureTimeoutError
----------------------------- Captured stderr call -----------------------------
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
------------------------------ Captured log call -------------------------------
WARNING  root:environments.py:374 Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
WARNING  root:environments.py:374 Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
__________________ SqlTransformTest.test_windowing_before_sql __________________

self = <apache_beam.transforms.sql_test.SqlTransformTest testMethod=test_windowing_before_sql>

    def test_windowing_before_sql(self):
      with TestPipeline() as p:
        out = (
            p | beam.Create([
                SimpleRow(5, "foo", 1.),
                SimpleRow(15, "bar", 2.),
                SimpleRow(25, "baz", 3.)
            ])
            | beam.Map(lambda v: beam.window.TimestampedValue(v, v.id)).
            with_output_types(SimpleRow)
            | beam.WindowInto(
                beam.window.FixedWindows(10)).with_output_types(SimpleRow)
            | SqlTransform("SELECT COUNT(*) as `count` FROM PCOLLECTION"))
>       assert_that(out, equal_to([(1, ), (1, ), (1, )]))

apache_beam/transforms/sql_test.py:175: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/pipeline.py:590: in __exit__
    self.result = self.run()
apache_beam/testing/test_pipeline.py:114: in run
    False if self.not_use_test_runner_api else test_runner_api))
apache_beam/pipeline.py:567: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/portability/portable_runner.py:438: in run_pipeline
    job_service_handle = self.create_job_service(options)
apache_beam/runners/portability/portable_runner.py:317: in create_job_service
    return self.create_job_service_handle(server.start(), options)
apache_beam/runners/portability/job_server.py:54: in start
    grpc.channel_ready_future(channel).result(timeout=self._timeout)
../../build/gradleenv/1922375555/lib/python3.6/site-packages/grpc/_utilities.py:139: in result
    self._block(timeout)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <grpc._utilities._ChannelReadyFuture object at 0x7f888c0b7518>
timeout = 60

    def _block(self, timeout):
        until = None if timeout is None else time.time() + timeout
        with self._condition:
            while True:
                if self._cancelled:
                    raise grpc.FutureCancelledError()
                elif self._matured:
                    return
                else:
                    if until is None:
                        self._condition.wait()
                    else:
                        remaining = until - time.time()
                        if remaining < 0:
>                           raise grpc.FutureTimeoutError()
E                           grpc.FutureTimeoutError

../../build/gradleenv/1922375555/lib/python3.6/site-packages/grpc/_utilities.py:85: FutureTimeoutError
----------------------------- Captured stderr call -----------------------------
WARNING:root:Waiting for grpc channel to be ready at localhost:46031.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
------------------------------ Captured log call -------------------------------
WARNING  root:subprocess_server.py:95 Waiting for grpc channel to be ready at localhost:46031.
WARNING  root:environments.py:374 Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
WARNING  root:environments.py:374 Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
_________________ SqlTransformTest.test_zetasql_generate_data __________________

self = <apache_beam.transforms.sql_test.SqlTransformTest testMethod=test_zetasql_generate_data>

    def test_zetasql_generate_data(self):
      with TestPipeline() as p:
        out = p | SqlTransform(
            """SELECT
              CAST(1 AS INT64) AS `int`,
              CAST('foo' AS STRING) AS `str`,
              CAST(3.14  AS FLOAT64) AS `flt`""",
            dialect="zetasql")
>       assert_that(out, equal_to([(1, "foo", 3.14)]))

apache_beam/transforms/sql_test.py:160: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/pipeline.py:590: in __exit__
    self.result = self.run()
apache_beam/testing/test_pipeline.py:114: in run
    False if self.not_use_test_runner_api else test_runner_api))
apache_beam/pipeline.py:567: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/portability/portable_runner.py:438: in run_pipeline
    job_service_handle = self.create_job_service(options)
apache_beam/runners/portability/portable_runner.py:317: in create_job_service
    return self.create_job_service_handle(server.start(), options)
apache_beam/runners/portability/job_server.py:54: in start
    grpc.channel_ready_future(channel).result(timeout=self._timeout)
../../build/gradleenv/1922375555/lib/python3.6/site-packages/grpc/_utilities.py:139: in result
    self._block(timeout)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <grpc._utilities._ChannelReadyFuture object at 0x7f888c3250b8>
timeout = 60

    def _block(self, timeout):
        until = None if timeout is None else time.time() + timeout
        with self._condition:
            while True:
                if self._cancelled:
                    raise grpc.FutureCancelledError()
                elif self._matured:
                    return
                else:
                    if until is None:
                        self._condition.wait()
                    else:
                        remaining = until - time.time()
                        if remaining < 0:
>                           raise grpc.FutureTimeoutError()
E                           grpc.FutureTimeoutError

../../build/gradleenv/1922375555/lib/python3.6/site-packages/grpc/_utilities.py:85: FutureTimeoutError
----------------------------- Captured stderr call -----------------------------
WARNING:root:Waiting for grpc channel to be ready at localhost:44785.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
------------------------------ Captured log call -------------------------------
WARNING  root:subprocess_server.py:95 Waiting for grpc channel to be ready at localhost:44785.
WARNING  root:environments.py:374 Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
WARNING  root:environments.py:374 Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark3/ws/src/sdks/python/pytest_xlangSqlValidateRunner.xml> -
================= 9 failed, 4991 deselected in 619.06 seconds ==================
Exception in thread wait_until_finish_read:
Traceback (most recent call last):
  File "/usr/lib/python3.6/threading.py", line 916, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.6/threading.py", line 864, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark3/ws/src/sdks/python/apache_beam/runners/portability/portable_runner.py",> line 565, in read_messages
    for message in self._message_stream:
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark3/ws/src/build/gradleenv/1922375555/lib/python3.6/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark3/ws/src/build/gradleenv/1922375555/lib/python3.6/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "Socket closed"
	debug_error_string = "{"created":"@1631795457.486202390","description":"Error received from peer ipv4:127.0.0.1:41755","file":"src/core/lib/surface/call.cc","file_line":1069,"grpc_message":"Socket closed","grpc_status":14}"
>


> Task :runners:spark:3:job-server:validatesCrossLanguageRunnerPythonUsingSql FAILED
> Task :runners:spark:3:job-server:validatesCrossLanguageRunnerCleanup
> Task :runners:spark:3:job-server:sparkJobServerCleanup

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':runners:spark:3:job-server:validatesCrossLanguageRunnerPythonUsingSql'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.8.3/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 38m 26s
180 actionable tasks: 130 executed, 46 from cache, 4 up-to-date

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

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_XVR_Spark3 #697

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Spark3/697/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_XVR_Spark3 #696

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

Changes:

[noreply] [BEAM-12701] Added extra parameter in to_csv for DeferredFrame to name


------------------------------------------
[...truncated 467.31 KB...]
  adding 'apache_beam/utils/processes_test.py'
  adding 'apache_beam/utils/profiler.py'
  adding 'apache_beam/utils/profiler_test.py'
  adding 'apache_beam/utils/proto_utils.py'
  adding 'apache_beam/utils/retry.py'
  adding 'apache_beam/utils/retry_test.py'
  adding 'apache_beam/utils/sentinel.py'
  adding 'apache_beam/utils/sharded_key.py'
  adding 'apache_beam/utils/shared.py'
  adding 'apache_beam/utils/shared_test.py'
  adding 'apache_beam/utils/subprocess_server.py'
  adding 'apache_beam/utils/subprocess_server_test.py'
  adding 'apache_beam/utils/thread_pool_executor.py'
  adding 'apache_beam/utils/thread_pool_executor_test.py'
  adding 'apache_beam/utils/timestamp.py'
  adding 'apache_beam/utils/timestamp_test.py'
  adding 'apache_beam/utils/urns.py'
  adding 'apache_beam/utils/windowed_value.cpython-36m-x86_64-linux-gnu.so'
  adding 'apache_beam/utils/windowed_value.pxd'
  adding 'apache_beam/utils/windowed_value.py'
  adding 'apache_beam/utils/windowed_value_test.py'
  adding 'apache_beam-2.34.0.dev0.dist-info/METADATA'
  adding 'apache_beam-2.34.0.dev0.dist-info/WHEEL'
  adding 'apache_beam-2.34.0.dev0.dist-info/top_level.txt'
  adding 'apache_beam-2.34.0.dev0.dist-info/RECORD'
  removing build/bdist.linux-x86_64/wheel
  Building wheel for apache-beam (setup.py): finished with status 'done'
  Created wheel for apache-beam: filename=apache_beam-2.34.0.dev0-cp36-cp36m-linux_x86_64.whl size=9822114 sha256=643331d13bc82c8d84d9a59fabfe6a9f5542d4aafc6d399e6bfdb9fa4444c2db
  Stored in directory: /root/.cache/pip/wheels/71/0a/9d/8434df5e361fe8c44220318cb21455c5dcaa3d25589894f9c8
Successfully built apache-beam
Installing collected packages: apache-beam
Successfully installed apache-beam-2.34.0.dev0
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
Removing intermediate container c2b1b7d74ede
 ---> 4caf44f3e758
Step 15/27 : COPY target/license_scripts /tmp/license_scripts/
 ---> f2730f70d719
Step 16/27 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> cf42b08b7a7c
Step 17/27 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in bffcb85a3d64
Removing intermediate container bffcb85a3d64
 ---> 5246118fbbce
Step 18/27 : COPY target/license_scripts /tmp/license_scripts/
 ---> 6736d4f80eff
Step 19/27 : RUN if [ "$pull_licenses" = "true" ] ; then     pip install 'pip-licenses<3.0.0;python_version>="3.5"' &&     pip install 'pip-licenses==1.18.0;python_version<="2.7"' &&     python /tmp/license_scripts/pull_licenses_py.py &&     pip uninstall -y pip-licenses &&     rm -rf /root/.cache/pip ;    else     rm -rf /opt/apache/beam/third_party_licenses ;    fi
 ---> Running in d164af42406b
Collecting pip-licenses<3.0.0
  Downloading pip_licenses-2.3.0-py3-none-any.whl (14 kB)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22924 sha256=b5bef4c0645eb31721e72892eddaa9abef26f23c9ca000ac6d40f29948c7efb9
  Stored in directory: /root/.cache/pip/wheels/f3/65/67/71f473ec87ea4554d1bdfb1b5128cfe1414c2b113b72a1ee8e
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-2.3.0
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
Ignoring pip-licenses: markers 'python_version <= "2.7"' don't match your environment
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
INFO:root:Successfully pulled licenses for 112 dependencies
Skip pulling license for  bs4
Found existing installation: pip-licenses 2.3.0
Uninstalling pip-licenses-2.3.0:
  Successfully uninstalled pip-licenses-2.3.0
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
Removing intermediate container d164af42406b
 ---> 75ca0db23b27
Step 20/27 : RUN rm -rf /tmp/license_scripts
 ---> Running in 7935df8c84f3
Removing intermediate container 7935df8c84f3
 ---> 2439a523c577
Step 21/27 : RUN pip freeze --all
 ---> Running in ebe43911d1bd
absl-py==0.13.0
apache-beam @ file:///opt/apache/beam/tars/apache-beam.tar.gz
astunparse==1.6.3
atomicwrites==1.4.0
attrs==21.2.0
avro-python3==1.8.2
beautifulsoup4==4.9.1
bs4==0.0.1
cached-property==1.5.2
cachetools==3.1.1
certifi==2021.5.30
chardet==3.0.4
click==8.0.1
crcmod==1.7
Cython==0.29.21
dataclasses==0.8
dill==0.3.1.1
docopt==0.6.2
fastavro==1.0.0.post1
fasteners==0.16.3
flatbuffers==1.12
freezegun==0.3.15
future==0.18.2
gast==0.4.0
google-api-core==1.22.2
google-api-python-client==2.21.0
google-apitools==0.5.31
google-auth==1.31.0
google-auth-httplib2==0.1.0
google-auth-oauthlib==0.4.6
google-cloud-bigquery==1.26.1
google-cloud-bigtable==1.0.0
google-cloud-core==1.4.1
google-cloud-datastore==1.15.3
google-cloud-dlp==0.13.0
google-cloud-language==1.3.0
google-cloud-profiler==3.0.4
google-cloud-pubsub==1.0.2
google-cloud-recommendations-ai==0.2.0
google-cloud-spanner==1.13.0
google-cloud-videointelligence==1.13.0
google-cloud-vision==0.42.0
google-crc32c==1.1.5
google-pasta==0.2.0
google-python-cloud-debugger==2.15
google-resumable-media==1.3.3
googleapis-common-protos==1.53.0
grpc-google-iam-v1==0.12.3
grpcio==1.34.0
grpcio-gcp==0.2.2
guppy3==3.0.10
h5py==3.1.0
hdfs==2.5.8
httplib2==0.19.1
idna==2.10
importlib-metadata==4.8.1
joblib==1.0.1
keras-nightly==2.5.0.dev2021032900
Keras-Preprocessing==1.1.2
Markdown==3.3.4
mmh3==2.5.1
more-itertools==8.9.0
nltk==3.5
numpy==1.19.5
oauth2client==4.1.3
oauthlib==3.1.1
opt-einsum==3.3.0
orjson==3.6.1
packaging==21.0
pandas==1.1.5
Pillow==7.2.0
pip==21.2.4
pluggy==0.13.1
proto-plus==1.19.0
protobuf==3.12.2
protorpc==0.12.0
PTable==0.9.2
py==1.10.0
pyarrow==3.0.0
pyasn1==0.4.8
pyasn1-modules==0.2.8
pydot==1.4.1
PyHamcrest==1.10.1
pymongo==3.10.1
pyparsing==2.4.7
pytest==4.6.11
python-dateutil==2.8.1
python-gflags==3.1.2
python-snappy==0.5.4
pytz==2020.1
PyYAML==5.4
regex==2021.8.28
requests==2.24.0
requests-oauthlib==1.3.0
rsa==4.7.2
scikit-learn==0.24.1
scipy==1.4.1
setuptools==57.5.0
six==1.15.0
soupsieve==2.2.1
tenacity==8.0.1
tensorboard==2.6.0
tensorboard-data-server==0.6.1
tensorboard-plugin-wit==1.8.0
tensorflow==2.5.0
tensorflow-estimator==2.5.0
termcolor==1.1.0
threadpoolctl==2.2.0
tqdm==4.62.2
typing-extensions==3.7.4.3
uritemplate==3.0.1
urllib3==1.25.11
wcwidth==0.2.5
Werkzeug==2.0.1
wheel==0.37.0
wrapt==1.12.1
zipp==3.5.0
Removing intermediate container ebe43911d1bd
 ---> 5fb719a0992a
Step 22/27 : RUN pip check
 ---> Running in e1956755cd3f
No broken requirements found.
Removing intermediate container e1956755cd3f
 ---> 205f6adfa08f
Step 23/27 : COPY target/LICENSE /opt/apache/beam/
 ---> 1c8a7b724c22
Step 24/27 : COPY target/LICENSE.python /opt/apache/beam/
 ---> c3165b00ed8b
Step 25/27 : COPY target/NOTICE /opt/apache/beam/
 ---> 89ccbc685800
Step 26/27 : ADD target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> 03ea9e3b5e3f
Step 27/27 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in 878da31ecf33
Removing intermediate container 878da31ecf33
 ---> 6a1516c5a7f8
Successfully built 6a1516c5a7f8
Successfully tagged apache/beam_python3.6_sdk:2.34.0.dev

> Task :runners:spark:3:job-server:validatesCrossLanguageRunnerSetup
> Task :runners:spark:3:job-server:validatesCrossLanguageRunnerJavaUsingJava
> Task :runners:spark:3:job-server:validatesCrossLanguageRunnerJavaUsingPython
> Task :runners:spark:3:job-server:validatesCrossLanguageRunnerJavaUsingPythonOnly
> Task :runners:spark:3:job-server:validatesCrossLanguageRunnerPythonUsingJava
> Task :runners:spark:3:job-server:validatesCrossLanguageRunnerPythonUsingPython
> Task :runners:spark:3:job-server:validatesCrossLanguageRunnerPythonUsingSql
> Task :runners:spark:3:job-server:validatesCrossLanguageRunnerPythonUsingSql FAILED
> Task :runners:spark:3:job-server:validatesCrossLanguageRunnerCleanup
> Task :runners:spark:3:job-server:sparkJobServerCleanup

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':runners:spark:3:job-server:validatesCrossLanguageRunnerPythonUsingSql'.
> Process 'command 'sh'' finished with non-zero exit value 1

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

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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.8.3/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 36m 20s
180 actionable tasks: 128 executed, 48 from cache, 4 up-to-date

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

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