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/05/11 11:36:02 UTC

Build failed in Jenkins: beam_PostCommit_XVR_Direct #2635

See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/2635/display/redirect>

Changes:


------------------------------------------
[...truncated 1.25 MB...]
            'simple': simple, 'enrich': enrich
        }
               | SqlTransform(
                   """
                SELECT
                  simple.`id` AS `id`,
                  enrich.metadata AS metadata
                FROM simple
                JOIN enrich
>               ON simple.`id` = enrich.`id`"""))

apache_beam/transforms/sql_test.py:140: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/transforms/ptransform.py:614: in __ror__
    result = p.apply(self, pvalueish, label)
apache_beam/pipeline.py:708: in apply
    pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
apache_beam/runners/runner.py:185: in apply
    return m(transform, input, options)
apache_beam/runners/runner.py:215: in apply_PTransform
    return transform.expand(input)
apache_beam/transforms/external.py:523: in expand
    with self._service() as service:
/usr/lib/python3.7/contextlib.py:112: in __enter__
    return next(self.gen)
apache_beam/transforms/external.py:579: in _service
    with self._expansion_service as stub:
apache_beam/transforms/external.py:766: in __enter__
    self._service = self._service_provider.__enter__()
apache_beam/utils/subprocess_server.py:72: in __enter__
    return self.start()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.utils.subprocess_server.JavaJarServer object at 0x7fec2df3de50>

    def start(self):
      try:
        endpoint = self.start_process()
        wait_secs = .1
        channel_options = [("grpc.max_receive_message_length", -1),
                           ("grpc.max_send_message_length", -1)]
        channel = grpc.insecure_channel(endpoint, options=channel_options)
        channel_ready = grpc.channel_ready_future(channel)
        while True:
          if self._process is not None and self._process.poll() is not None:
            _LOGGER.error("Starting job service with %s", self._process.args)
            raise RuntimeError(
>               'Service failed to start up with error %s' % self._process.poll())
E               RuntimeError: Service failed to start up with error 1

apache_beam/utils/subprocess_server.py:89: RuntimeError
----------------------------- Captured stderr call -----------------------------
E0511 11:35:55.274302992 3779876 fork_posix.cc:76]           Other threads are currently calling into gRPC, skipping fork() handlers
ERROR:apache_beam.utils.subprocess_server:Starting job service with ['java', '-jar', '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.40.0-SNAPSHOT.jar',> '59713', '--filesToStage=<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.40.0-SNAPSHOT.jar']>
ERROR:apache_beam.utils.subprocess_server:Error bringing up service
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/utils/subprocess_server.py",> line 89, in start
    'Service failed to start up with error %s' % self._process.poll())
RuntimeError: Service failed to start up with error 1
------------------------------ Captured log call -------------------------------
ERROR    apache_beam.utils.subprocess_server:subprocess_server.py:87 Starting job service with ['java', '-jar', '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.40.0-SNAPSHOT.jar',> '59713', '--filesToStage=<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.40.0-SNAPSHOT.jar']>
ERROR    apache_beam.utils.subprocess_server:subprocess_server.py:101 Error bringing up service
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/utils/subprocess_server.py",> line 89, in start
    'Service failed to start up with error %s' % self._process.poll())
RuntimeError: Service failed to start up with error 1
__________________ 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"))

apache_beam/transforms/sql_test.py:174: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/pvalue.py:137: in __or__
    return self.pipeline.apply(ptransform, self)
apache_beam/pipeline.py:708: in apply
    pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
apache_beam/runners/runner.py:185: in apply
    return m(transform, input, options)
apache_beam/runners/runner.py:215: in apply_PTransform
    return transform.expand(input)
apache_beam/transforms/external.py:523: in expand
    with self._service() as service:
/usr/lib/python3.7/contextlib.py:112: in __enter__
    return next(self.gen)
apache_beam/transforms/external.py:579: in _service
    with self._expansion_service as stub:
apache_beam/transforms/external.py:766: in __enter__
    self._service = self._service_provider.__enter__()
apache_beam/utils/subprocess_server.py:72: in __enter__
    return self.start()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.utils.subprocess_server.JavaJarServer object at 0x7fec2e023810>

    def start(self):
      try:
        endpoint = self.start_process()
        wait_secs = .1
        channel_options = [("grpc.max_receive_message_length", -1),
                           ("grpc.max_send_message_length", -1)]
        channel = grpc.insecure_channel(endpoint, options=channel_options)
        channel_ready = grpc.channel_ready_future(channel)
        while True:
          if self._process is not None and self._process.poll() is not None:
            _LOGGER.error("Starting job service with %s", self._process.args)
            raise RuntimeError(
>               'Service failed to start up with error %s' % self._process.poll())
E               RuntimeError: Service failed to start up with error 1

apache_beam/utils/subprocess_server.py:89: RuntimeError
----------------------------- Captured stderr call -----------------------------
E0511 11:35:55.699820062 3779876 fork_posix.cc:76]           Other threads are currently calling into gRPC, skipping fork() handlers
ERROR:apache_beam.utils.subprocess_server:Starting job service with ['java', '-jar', '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.40.0-SNAPSHOT.jar',> '38599', '--filesToStage=<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.40.0-SNAPSHOT.jar']>
ERROR:apache_beam.utils.subprocess_server:Error bringing up service
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/utils/subprocess_server.py",> line 89, in start
    'Service failed to start up with error %s' % self._process.poll())
RuntimeError: Service failed to start up with error 1
------------------------------ Captured log call -------------------------------
ERROR    apache_beam.utils.subprocess_server:subprocess_server.py:87 Starting job service with ['java', '-jar', '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.40.0-SNAPSHOT.jar',> '38599', '--filesToStage=<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.40.0-SNAPSHOT.jar']>
ERROR    apache_beam.utils.subprocess_server:subprocess_server.py:101 Error bringing up service
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/utils/subprocess_server.py",> line 89, in start
    'Service failed to start up with error %s' % self._process.poll())
RuntimeError: Service failed to start up with error 1
_________________ 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")

apache_beam/transforms/sql_test.py:159: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/transforms/ptransform.py:614: in __ror__
    result = p.apply(self, pvalueish, label)
apache_beam/pipeline.py:708: in apply
    pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
apache_beam/runners/runner.py:185: in apply
    return m(transform, input, options)
apache_beam/runners/runner.py:215: in apply_PTransform
    return transform.expand(input)
apache_beam/transforms/external.py:523: in expand
    with self._service() as service:
/usr/lib/python3.7/contextlib.py:112: in __enter__
    return next(self.gen)
apache_beam/transforms/external.py:579: in _service
    with self._expansion_service as stub:
apache_beam/transforms/external.py:766: in __enter__
    self._service = self._service_provider.__enter__()
apache_beam/utils/subprocess_server.py:72: in __enter__
    return self.start()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.utils.subprocess_server.JavaJarServer object at 0x7fec2def9090>

    def start(self):
      try:
        endpoint = self.start_process()
        wait_secs = .1
        channel_options = [("grpc.max_receive_message_length", -1),
                           ("grpc.max_send_message_length", -1)]
        channel = grpc.insecure_channel(endpoint, options=channel_options)
        channel_ready = grpc.channel_ready_future(channel)
        while True:
          if self._process is not None and self._process.poll() is not None:
            _LOGGER.error("Starting job service with %s", self._process.args)
            raise RuntimeError(
>               'Service failed to start up with error %s' % self._process.poll())
E               RuntimeError: Service failed to start up with error 1

apache_beam/utils/subprocess_server.py:89: RuntimeError
----------------------------- Captured stderr call -----------------------------
E0511 11:35:55.830728115 3779876 fork_posix.cc:76]           Other threads are currently calling into gRPC, skipping fork() handlers
ERROR:apache_beam.utils.subprocess_server:Starting job service with ['java', '-jar', '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.40.0-SNAPSHOT.jar',> '39025', '--filesToStage=<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.40.0-SNAPSHOT.jar']>
ERROR:apache_beam.utils.subprocess_server:Error bringing up service
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/utils/subprocess_server.py",> line 89, in start
    'Service failed to start up with error %s' % self._process.poll())
RuntimeError: Service failed to start up with error 1
------------------------------ Captured log call -------------------------------
ERROR    apache_beam.utils.subprocess_server:subprocess_server.py:87 Starting job service with ['java', '-jar', '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.40.0-SNAPSHOT.jar',> '39025', '--filesToStage=<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/java/extensions/sql/expansion-service/build/libs/beam-sdks-java-extensions-sql-expansion-service-2.40.0-SNAPSHOT.jar']>
ERROR    apache_beam.utils.subprocess_server:subprocess_server.py:101 Error bringing up service
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/utils/subprocess_server.py",> line 89, in start
    'Service failed to start up with error %s' % self._process.poll())
RuntimeError: Service failed to start up with error 1
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/pytest_xlangSqlValidateRunner.xml> -
============ 9 failed, 1 skipped, 5566 deselected in 11.96 seconds =============

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerPythonUsingSql FAILED

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3748656.
Stopping expansion service pid: 3748657.

> Task :sdks:python:test-suites:direct:xlang:fnApiJobServerCleanup
Killing process at 3740235

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang: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 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.4/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 25m 34s
233 actionable tasks: 154 executed, 68 from cache, 11 up-to-date

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

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_Direct #2637

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/2637/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_Direct #2636

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

Changes:

[noreply] [BEAM-5492] Python Dataflow integration tests should export the pipeline

[noreply] [BEAM-14396] Bump httplib2 upper bound. (#17602)

[noreply] [BEAM-11104] Add self-checkpointing to CHANGES.md (#17612)

[noreply] [BEAM-14081] [CdapIO] Add context classes for CDAP plugins (#17104)


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

<unknown>:54
  <unknown>:54: DeprecationWarning: invalid escape sequence \c

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

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

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/pytest_xlangValidateRunner.xml> -
===== 10 passed, 1 skipped, 5565 deselected, 5 warnings in 427.05 seconds ======

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerPythonUsingPython
>>> RUNNING integration tests with pipeline options: --runner=PortableRunner --job_endpoint=localhost:35417 --environment_cache_millis=10000 --experiments=beam_fn_api
>>>   pytest options: 
>>>   collect markers: -m=xlang_transforms
============================= test session starts ==============================
platform linux -- Python 3.9.10, pytest-4.6.11, py-1.11.0, pluggy-0.13.1
rootdir: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python,> inifile: pytest.ini
plugins: xdist-1.34.0, timeout-1.4.2, forked-1.4.0, requests-mock-1.9.3
timeout: 600.0s
timeout method: signal
timeout func_only: False
collected 5575 items / 5565 deselected / 1 skipped / 9 selected

apache_beam/io/external/generate_sequence_test.py .ss                    [ 30%]
apache_beam/transforms/validate_runner_xlang_test.py .......             [100%]

=============================== warnings summary ===============================
<unknown>:54
  <unknown>:54: DeprecationWarning: invalid escape sequence \c

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

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

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/pytest_xlangValidateRunner.xml> -
====== 8 passed, 3 skipped, 5565 deselected, 3 warnings in 174.70 seconds ======

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerPythonUsingSql
>>> RUNNING integration tests with pipeline options: --runner=PortableRunner --job_endpoint=localhost:35417 --environment_cache_millis=10000 --experiments=beam_fn_api
>>>   pytest options: 
>>>   collect markers: -m=xlang_sql_expansion_service
============================= test session starts ==============================
platform linux -- Python 3.9.10, pytest-4.6.11, py-1.11.0, pluggy-0.13.1
rootdir: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python,> inifile: pytest.ini
plugins: xdist-1.34.0, timeout-1.4.2, forked-1.4.0, requests-mock-1.9.3
timeout: 600.0s
timeout method: signal
timeout func_only: False
collected 5575 items / 5566 deselected / 1 skipped / 8 selected

apache_beam/transforms/sql_test.py ...Exception in thread wait_until_finish_read:
Traceback (most recent call last):
  File "/usr/lib/python3.9/threading.py", line 973, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.9/threading.py", line 910, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/runners/portability/portable_runner.py",> line 571, in read_messages
    for message in self._message_stream:
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.9/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.9/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.DEADLINE_EXCEEDED
	details = "Deadline Exceeded"
	debug_error_string = "{"created":"@1652294224.178336588","description":"Error received from peer ipv4:127.0.0.1:35417","file":"src/core/lib/surface/call.cc","file_line":952,"grpc_message":"Deadline Exceeded","grpc_status":4}"
>
F.....                             [100%]

=================================== FAILURES ===================================
__________________________ SqlTransformTest.test_map ___________________________

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

    def test_map(self):
      with TestPipeline() as p:
        out = (
            p
            | beam.Create([
                Shopper('bob', {
                    'bananas': 6, 'cherries': 3
                }),
                Shopper('alice', {
                    'apples': 2, 'bananas': 3
                })
            ]).with_output_types(Shopper)
            | SqlTransform("SELECT * FROM PCOLLECTION WHERE shopper = 'alice'"))
>       assert_that(out, equal_to([('alice', {'apples': 2, 'bananas': 3})]))

apache_beam/transforms/sql_test.py:190: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/pipeline.py:596: in __exit__
    self.result = self.run()
apache_beam/testing/test_pipeline.py:116: in run
    state = result.wait_until_finish()
apache_beam/runners/portability/portable_runner.py:606: in wait_until_finish
    raise self._runtime_exception
apache_beam/runners/portability/portable_runner.py:612: in _observe_state
    for state_response in self._state_stream:
../../build/gradleenv/1922375555/lib/python3.9/site-packages/grpc/_channel.py:426: in __next__
    return self._next()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.DEADLINE_EXCEEDED
	details = "Deadline Exc...0.1:35417","file":"src/core/lib/surface/call.cc","file_line":952,"grpc_message":"Deadline Exceeded","grpc_status":4}"
>

    def _next(self):
        with self._state.condition:
            if self._state.code is None:
                event_handler = _event_handler(self._state,
                                               self._response_deserializer)
                self._state.due.add(cygrpc.OperationType.receive_message)
                operating = self._call.operate(
                    (cygrpc.ReceiveMessageOperation(_EMPTY_FLAGS),),
                    event_handler)
                if not operating:
                    self._state.due.remove(cygrpc.OperationType.receive_message)
            elif self._state.code is grpc.StatusCode.OK:
                raise StopIteration()
            else:
                raise self
    
            def _response_ready():
                return (self._state.response is not None or
                        (cygrpc.OperationType.receive_message
                         not in self._state.due and
                         self._state.code is not None))
    
            _common.wait(self._state.condition.wait, _response_ready)
            if self._state.response is not None:
                response = self._state.response
                self._state.response = None
                return response
            elif cygrpc.OperationType.receive_message not in self._state.due:
                if self._state.code is grpc.StatusCode.OK:
                    raise StopIteration()
                elif self._state.code is not None:
>                   raise self
E                   grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
E                   	status = StatusCode.DEADLINE_EXCEEDED
E                   	details = "Deadline Exceeded"
E                   	debug_error_string = "{"created":"@1652294224.155367249","description":"Error received from peer ipv4:127.0.0.1:35417","file":"src/core/lib/surface/call.cc","file_line":952,"grpc_message":"Deadline Exceeded","grpc_status":4}"
E                   >

../../build/gradleenv/1922375555/lib/python3.9/site-packages/grpc/_channel.py:826: _MultiThreadedRendezvous
----------------------------- Captured stderr call -----------------------------
WARNING:root:Waiting for grpc channel to be ready at localhost:46957.
WARNING:root:Waiting for grpc channel to be ready at localhost:46957.
WARNING:root:Waiting for grpc channel to be ready at localhost:46957.
WARNING:root:Waiting for grpc channel to be ready at localhost:46957.
WARNING:root:Waiting for grpc channel to be ready at localhost:46957.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.9 interpreter.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.9 interpreter.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.9 interpreter.
------------------------------ Captured log call -------------------------------
WARNING  root:subprocess_server.py:95 Waiting for grpc channel to be ready at localhost:46957.
WARNING  root:subprocess_server.py:95 Waiting for grpc channel to be ready at localhost:46957.
WARNING  root:subprocess_server.py:95 Waiting for grpc channel to be ready at localhost:46957.
WARNING  root:subprocess_server.py:95 Waiting for grpc channel to be ready at localhost:46957.
WARNING  root:subprocess_server.py:95 Waiting for grpc channel to be ready at localhost:46957.
WARNING  root:environments.py:371 Make sure that locally built Python SDK docker image has Python 3.9 interpreter.
WARNING  root:environments.py:371 Make sure that locally built Python SDK docker image has Python 3.9 interpreter.
WARNING  root:portable_runner.py:573 Make sure that locally built Python SDK docker image has Python 3.9 interpreter.
=============================== warnings summary ===============================
<unknown>:54
  <unknown>:54: DeprecationWarning: invalid escape sequence \c

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

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

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/pytest_xlangSqlValidateRunner.xml> -
= 1 failed, 8 passed, 1 skipped, 5566 deselected, 3 warnings in 822.16 seconds =

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerPythonUsingSql FAILED

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 4116571.
Stopping expansion service pid: 4116572.

> Task :sdks:python:test-suites:direct:xlang:fnApiJobServerCleanup
Killing process at 4109961

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/go/test/build.gradle'> line: 195

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerGoUsingJava'.
> 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.
==============================================================================

2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang: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 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.4/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 59m 10s
218 actionable tasks: 35 executed, 183 up-to-date

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

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