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/10/04 18:25:00 UTC

Build failed in Jenkins: beam_PostCommit_XVR_Samza #304

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

Changes:

[noreply] [BEAM-11516] Upgrade to pylint 2.11.1, fix warnings (#15612)

[noreply] [BEAM-12979, BEAM-11097] Change cache to store ReStreams, clean up to…

[noreply] [BEAM-3304, BEAM-12513] Trigger changes and Windowing. (#15644)


------------------------------------------
[...truncated 356.54 KB...]
    state = result.wait_until_finish()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.portable_runner.PipelineResult object at 0x7f0c291cf630>
duration = None

    def wait_until_finish(self, duration=None):
      """
      :param duration: The maximum time in milliseconds to wait for the result of
      the execution. If None or zero, will wait until the pipeline finishes.
      :return: The result of the pipeline, i.e. PipelineResult.
      """
      def read_messages():
        # type: () -> None
        previous_state = -1
        for message in self._message_stream:
          if message.HasField('message_response'):
            logging.log(
                MESSAGE_LOG_LEVELS[message.message_response.importance],
                "%s",
                message.message_response.message_text)
          else:
            current_state = message.state_response.state
            if current_state != previous_state:
              _LOGGER.info(
                  "Job state changed to %s",
                  self._runner_api_state_to_pipeline_state(current_state))
              previous_state = current_state
          self._messages.append(message)
    
      message_thread = threading.Thread(
          target=read_messages, name='wait_until_finish_read')
      message_thread.daemon = True
      message_thread.start()
    
      if duration:
        state_thread = threading.Thread(
            target=functools.partial(self._observe_state, message_thread),
            name='wait_until_finish_state_observer')
        state_thread.daemon = True
        state_thread.start()
        start_time = time.time()
        duration_secs = duration / 1000
        while (time.time() - start_time < duration_secs and
               state_thread.is_alive()):
          time.sleep(1)
      else:
        self._observe_state(message_thread)
    
      if self._runtime_exception:
>       raise self._runtime_exception
E       RuntimeError: Pipeline BeamApp-jenkins-1004182423-9cb4d906_c6c93379-db96-473a-b802-795ec2d1346e failed in state FAILED: java.lang.ClassCastException: org.apache.beam.sdk.coders.ByteArrayCoder cannot be cast to org.apache.beam.sdk.coders.KvCoder

apache_beam/runners/portability/portable_runner.py:600: RuntimeError
----------------------------- 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.
ERROR:root:java.lang.ClassCastException: org.apache.beam.sdk.coders.ByteArrayCoder cannot be cast to org.apache.beam.sdk.coders.KvCoder
------------------------------ 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.
ERROR    root:portable_runner.py:570 java.lang.ClassCastException: org.apache.beam.sdk.coders.ByteArrayCoder cannot be cast to org.apache.beam.sdk.coders.KvCoder
__________________ 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:596: in __exit__
    self.result = self.run()
apache_beam/testing/test_pipeline.py:116: in run
    state = result.wait_until_finish()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.portable_runner.PipelineResult object at 0x7f0c28fdec18>
duration = None

    def wait_until_finish(self, duration=None):
      """
      :param duration: The maximum time in milliseconds to wait for the result of
      the execution. If None or zero, will wait until the pipeline finishes.
      :return: The result of the pipeline, i.e. PipelineResult.
      """
      def read_messages():
        # type: () -> None
        previous_state = -1
        for message in self._message_stream:
          if message.HasField('message_response'):
            logging.log(
                MESSAGE_LOG_LEVELS[message.message_response.importance],
                "%s",
                message.message_response.message_text)
          else:
            current_state = message.state_response.state
            if current_state != previous_state:
              _LOGGER.info(
                  "Job state changed to %s",
                  self._runner_api_state_to_pipeline_state(current_state))
              previous_state = current_state
          self._messages.append(message)
    
      message_thread = threading.Thread(
          target=read_messages, name='wait_until_finish_read')
      message_thread.daemon = True
      message_thread.start()
    
      if duration:
        state_thread = threading.Thread(
            target=functools.partial(self._observe_state, message_thread),
            name='wait_until_finish_state_observer')
        state_thread.daemon = True
        state_thread.start()
        start_time = time.time()
        duration_secs = duration / 1000
        while (time.time() - start_time < duration_secs and
               state_thread.is_alive()):
          time.sleep(1)
      else:
        self._observe_state(message_thread)
    
      if self._runtime_exception:
>       raise self._runtime_exception
E       RuntimeError: Pipeline BeamApp-jenkins-1004182433-43d7f45b_c1630a15-ea23-4236-8830-19582b5d95a0 failed in state FAILED: java.lang.ClassCastException: org.apache.beam.sdk.coders.ByteArrayCoder cannot be cast to org.apache.beam.sdk.coders.KvCoder

apache_beam/runners/portability/portable_runner.py:600: RuntimeError
----------------------------- 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.
ERROR:root:java.lang.ClassCastException: org.apache.beam.sdk.coders.ByteArrayCoder cannot be cast to org.apache.beam.sdk.coders.KvCoder
------------------------------ 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.
ERROR    root:portable_runner.py:570 java.lang.ClassCastException: org.apache.beam.sdk.coders.ByteArrayCoder cannot be cast to org.apache.beam.sdk.coders.KvCoder
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Samza/ws/src/sdks/python/pytest_xlangSqlValidateRunner.xml> -
============ 6 failed, 3 passed, 5008 deselected in 141.43 seconds =============

> Task :runners:samza:job-server:validatesCrossLanguageRunnerPythonUsingSql FAILED

> Task :runners:samza:job-server:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 5936.
Stopping expansion service pid: 5939.

> Task :runners:samza:job-server:samzaJobServerCleanup
Stopping job server pid: 2981.

FAILURE: Build completed with 7 failures.

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

* What went wrong:
Execution failed for task ':runners:samza:job-server: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 ':runners:samza:job-server:validatesCrossLanguageRunnerJavaUsingJava'.
> There were failing tests. See the report at: file://<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Samza/ws/src/runners/samza/job-server/build/reports/tests/validatesCrossLanguageRunnerJavaUsingJava/index.html>

* 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.
==============================================================================

3: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':runners:samza:job-server:validatesCrossLanguageRunnerJavaUsingPython'.
> There were failing tests. See the report at: file://<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Samza/ws/src/runners/samza/job-server/build/reports/tests/validatesCrossLanguageRunnerJavaUsingPython/index.html>

* 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.
==============================================================================

4: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':runners:samza:job-server:validatesCrossLanguageRunnerJavaUsingPythonOnly'.
> There were failing tests. See the report at: file://<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Samza/ws/src/runners/samza/job-server/build/reports/tests/validatesCrossLanguageRunnerJavaUsingPythonOnly/index.html>

* 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.
==============================================================================

5: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':runners:samza:job-server:validatesCrossLanguageRunnerPythonUsingJava'.
> 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.
==============================================================================

6: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':runners:samza:job-server:validatesCrossLanguageRunnerPythonUsingPython'.
> 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.
==============================================================================

7: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':runners:samza: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.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 22m 37s
211 actionable tasks: 151 executed, 53 from cache, 7 up-to-date

Publishing build scan...
https://gradle.com/s/37gtfmnzdftew

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_Samza #306

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Samza/306/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_Samza #305

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

Changes:

[noreply] Merge pull request #15618 from [BEAM-12968] [Playground] Create README

[noreply] Merge pull request #15626 from [BEAM-12963] [Playground] Create base

[noreply] Merge pull request #15566 from [BEAM-12925] Correct behavior retrieving

[noreply] [BEAM-12911] Update schema translation (Java, Python) to log more

[noreply] Update CHANGES.md for JdbcIO breaking change (#15651)

[noreply] [BEAM-12513] Add Go SDK metrics content to BPG. (#15650)

[noreply] [BEAM-12996] Improve Error Logging in ConfigBuilder (#15646)


------------------------------------------
[...truncated 529.03 KB...]
      capabilities: "beam:protocol:multi_core_bundle_processing:v1"
      capabilities: "beam:version:sdk_base:go"
      capabilities: "beam:coder:bytes:v1"
      capabilities: "beam:coder:bool:v1"
      capabilities: "beam:coder:varint:v1"
      capabilities: "beam:coder:double:v1"
      capabilities: "beam:coder:string_utf8:v1"
      capabilities: "beam:coder:length_prefix:v1"
      capabilities: "beam:coder:kv:v1"
      capabilities: "beam:coder:iterable:v1"
      capabilities: "beam:coder:state_backed_iterable:v1"
      capabilities: "beam:coder:windowed_value:v1"
      capabilities: "beam:coder:global_window:v1"
      capabilities: "beam:coder:interval_window:v1"
      capabilities: "beam:coder:row:v1"
      dependencies: <
        type_urn: "beam:artifact:type:go_worker_binary:v1"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n\006worker"
      >
    >
  >
>
root_transform_ids: "s1"
--- FAIL: TestKafkaIO_BasicReadWrite (122.50s)
    ptest.go:98: Failed to execute job: 	connecting to job service
        failed to dial server at localhost:40857
        	caused by:
        context deadline exceeded
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	125.524s

> Task :runners:samza:job-server:validatesCrossLanguageRunnerGoUsingJava FAILED

> Task :runners:samza:job-server:validatesCrossLanguageRunnerJavaUsingJava

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > combineGloballyTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:259
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > partitionTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:316
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > coGroupByKeyTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:232
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > groupByKeyTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:200
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > combinePerKeyTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:277
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > flattenTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:297
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > singleInputOutputTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:158
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > multiInputOutputWithSideInputTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:180
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

8 tests completed, 8 failed

> Task :runners:samza:job-server:validatesCrossLanguageRunnerJavaUsingJava FAILED

> Task :runners:samza:job-server:validatesCrossLanguageRunnerJavaUsingPython

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > combineGloballyTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:259
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > partitionTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:316
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > coGroupByKeyTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:232
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > groupByKeyTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:200
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > combinePerKeyTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:277
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > flattenTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:297
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > singleInputOutputTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:158
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > multiInputOutputWithSideInputTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:180
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

8 tests completed, 8 failed

> Task :runners:samza:job-server:validatesCrossLanguageRunnerJavaUsingPython FAILED

> Task :runners:samza:job-server:validatesCrossLanguageRunnerJavaUsingPythonOnly

org.apache.beam.runners.core.construction.ValidateRunnerXlangTest > pythonDependenciesTest FAILED
    org.apache.beam.vendor.grpc.v1p36p0.io.grpc.StatusRuntimeException at ValidateRunnerXlangTest.java:340
        Caused by: org.apache.beam.vendor.grpc.v1p36p0.io.netty.channel.AbstractChannel$AnnotatedConnectException
            Caused by: java.net.ConnectException at Errors.java:124
    java.lang.NullPointerException at ValidateRunnerXlangTest.java:125

1 test completed, 1 failed

> Task :runners:samza:job-server:validatesCrossLanguageRunnerJavaUsingPythonOnly FAILED
> Task :runners:samza:job-server:validatesCrossLanguageRunnerPythonUsingJava FAILED
> Task :runners:samza:job-server:validatesCrossLanguageRunnerPythonUsingPython FAILED
> Task :runners:samza:job-server:validatesCrossLanguageRunnerPythonUsingSql
> Task :runners:samza:job-server:validatesCrossLanguageRunnerPythonUsingSql FAILED
> Task :runners:samza:job-server:validatesCrossLanguageRunnerCleanup
> Task :runners:samza:job-server:samzaJobServerCleanup

FAILURE: Build completed with 7 failures.

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

* What went wrong:
Execution failed for task ':runners:samza:job-server: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 ':runners:samza:job-server:validatesCrossLanguageRunnerJavaUsingJava'.
> There were failing tests. See the report at: file://<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Samza/ws/src/runners/samza/job-server/build/reports/tests/validatesCrossLanguageRunnerJavaUsingJava/index.html>

* 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.
==============================================================================

3: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':runners:samza:job-server:validatesCrossLanguageRunnerJavaUsingPython'.
> There were failing tests. See the report at: file://<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Samza/ws/src/runners/samza/job-server/build/reports/tests/validatesCrossLanguageRunnerJavaUsingPython/index.html>

* 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.
==============================================================================

4: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':runners:samza:job-server:validatesCrossLanguageRunnerJavaUsingPythonOnly'.
> There were failing tests. See the report at: file://<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Samza/ws/src/runners/samza/job-server/build/reports/tests/validatesCrossLanguageRunnerJavaUsingPythonOnly/index.html>

* 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.
==============================================================================

5: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':runners:samza:job-server:validatesCrossLanguageRunnerPythonUsingJava'.
> 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.
==============================================================================

6: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':runners:samza:job-server:validatesCrossLanguageRunnerPythonUsingPython'.
> 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.
==============================================================================

7: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':runners:samza: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.9.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 32m 36s
211 actionable tasks: 154 executed, 50 from cache, 7 up-to-date

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

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