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/01/04 06:27:28 UTC

Build failed in Jenkins: beam_PostCommit_XVR_Direct #2141

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

Changes:


------------------------------------------
[...truncated 517.60 KB...]
            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`"""))

apache_beam/transforms/sql_test.py:140: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/transforms/sql.py:87: in __init__
    ':sdks:java:extensions:sql:expansion-service:shadowJar')
apache_beam/transforms/external.py:733: in __init__
    gradle_target, gradle_appendix)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

cls = <class 'apache_beam.utils.subprocess_server.JavaJarServer'>
gradle_target = ':sdks:java:extensions:sql:expansion-service:shadowJar'
appendix = None, version = '2.37.0.dev'
artifact_id = 'beam-sdks-java-extensions-sql-expansion-service'

    @classmethod
    def path_to_beam_jar(
        cls,
        gradle_target,
        appendix=None,
        version=beam_version,
        artifact_id=None):
      if gradle_target in cls._BEAM_SERVICES.replacements:
        return cls._BEAM_SERVICES.replacements[gradle_target]
    
      gradle_package = gradle_target.strip(':').rsplit(':', 1)[0]
      if not artifact_id:
        artifact_id = 'beam-' + gradle_package.replace(':', '-')
      project_root = os.path.sep.join(
          os.path.abspath(__file__).split(os.path.sep)[:-5])
      local_path = os.path.join(
          project_root,
          gradle_package.replace(':', os.path.sep),
          'build',
          'libs',
          cls.jar_name(
              artifact_id,
              version.replace('.dev', ''),
              classifier='SNAPSHOT',
              appendix=appendix))
      if os.path.exists(local_path):
        _LOGGER.info('Using pre-built snapshot at %s', local_path)
        return local_path
      elif '.dev' in version:
        # TODO: Attempt to use nightly snapshots?
        raise RuntimeError(
            (
                '%s not found. '
                'Please build the server with \n  cd %s; ./gradlew %s') %
>           (local_path, os.path.abspath(project_root), gradle_target))
E       RuntimeError: <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.37.0-SNAPSHOT.jar> not found. Please build the server with 
E         cd <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src;> ./gradlew :sdks:java:extensions:sql:expansion-service:shadowJar

apache_beam/utils/subprocess_server.py:246: RuntimeError
__________________ 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/transforms/sql.py:87: in __init__
    ':sdks:java:extensions:sql:expansion-service:shadowJar')
apache_beam/transforms/external.py:733: in __init__
    gradle_target, gradle_appendix)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

cls = <class 'apache_beam.utils.subprocess_server.JavaJarServer'>
gradle_target = ':sdks:java:extensions:sql:expansion-service:shadowJar'
appendix = None, version = '2.37.0.dev'
artifact_id = 'beam-sdks-java-extensions-sql-expansion-service'

    @classmethod
    def path_to_beam_jar(
        cls,
        gradle_target,
        appendix=None,
        version=beam_version,
        artifact_id=None):
      if gradle_target in cls._BEAM_SERVICES.replacements:
        return cls._BEAM_SERVICES.replacements[gradle_target]
    
      gradle_package = gradle_target.strip(':').rsplit(':', 1)[0]
      if not artifact_id:
        artifact_id = 'beam-' + gradle_package.replace(':', '-')
      project_root = os.path.sep.join(
          os.path.abspath(__file__).split(os.path.sep)[:-5])
      local_path = os.path.join(
          project_root,
          gradle_package.replace(':', os.path.sep),
          'build',
          'libs',
          cls.jar_name(
              artifact_id,
              version.replace('.dev', ''),
              classifier='SNAPSHOT',
              appendix=appendix))
      if os.path.exists(local_path):
        _LOGGER.info('Using pre-built snapshot at %s', local_path)
        return local_path
      elif '.dev' in version:
        # TODO: Attempt to use nightly snapshots?
        raise RuntimeError(
            (
                '%s not found. '
                'Please build the server with \n  cd %s; ./gradlew %s') %
>           (local_path, os.path.abspath(project_root), gradle_target))
E       RuntimeError: <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.37.0-SNAPSHOT.jar> not found. Please build the server with 
E         cd <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src;> ./gradlew :sdks:java:extensions:sql:expansion-service:shadowJar

apache_beam/utils/subprocess_server.py:246: RuntimeError
_________________ 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/sql.py:87: in __init__
    ':sdks:java:extensions:sql:expansion-service:shadowJar')
apache_beam/transforms/external.py:733: in __init__
    gradle_target, gradle_appendix)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

cls = <class 'apache_beam.utils.subprocess_server.JavaJarServer'>
gradle_target = ':sdks:java:extensions:sql:expansion-service:shadowJar'
appendix = None, version = '2.37.0.dev'
artifact_id = 'beam-sdks-java-extensions-sql-expansion-service'

    @classmethod
    def path_to_beam_jar(
        cls,
        gradle_target,
        appendix=None,
        version=beam_version,
        artifact_id=None):
      if gradle_target in cls._BEAM_SERVICES.replacements:
        return cls._BEAM_SERVICES.replacements[gradle_target]
    
      gradle_package = gradle_target.strip(':').rsplit(':', 1)[0]
      if not artifact_id:
        artifact_id = 'beam-' + gradle_package.replace(':', '-')
      project_root = os.path.sep.join(
          os.path.abspath(__file__).split(os.path.sep)[:-5])
      local_path = os.path.join(
          project_root,
          gradle_package.replace(':', os.path.sep),
          'build',
          'libs',
          cls.jar_name(
              artifact_id,
              version.replace('.dev', ''),
              classifier='SNAPSHOT',
              appendix=appendix))
      if os.path.exists(local_path):
        _LOGGER.info('Using pre-built snapshot at %s', local_path)
        return local_path
      elif '.dev' in version:
        # TODO: Attempt to use nightly snapshots?
        raise RuntimeError(
            (
                '%s not found. '
                'Please build the server with \n  cd %s; ./gradlew %s') %
>           (local_path, os.path.abspath(project_root), gradle_target))
E       RuntimeError: <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.37.0-SNAPSHOT.jar> not found. Please build the server with 
E         cd <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src;> ./gradlew :sdks:java:extensions:sql:expansion-service:shadowJar

apache_beam/utils/subprocess_server.py:246: RuntimeError
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/pytest_xlangSqlValidateRunner.xml> -
================== 9 failed, 5139 deselected in 9.56 seconds ===================

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

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

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

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.3.2/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 26m 13s
169 actionable tasks: 108 executed, 52 from cache, 9 up-to-date

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

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 #2145

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

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

Changes:

[johnjcasey] [BEAM-12391] update avro sink to close the opened file handle, instead

[Robert Bradshaw] [BEAM-13482] Python fully qualified name external transforms.

[Robert Bradshaw] Add Python expansion service entry point.

[Kyle Weaver] [BEAM-13569] Change Spark dependencies to implementation.

[Kyle Weaver] remove redundant dependency

[wuren] [BEAM-13591] Bump log4j2 version to 2.17.1

[relax] Add Flink runner support for OrderedListState. This version reads the

[zyichi] Fix sdk_container_builder too many values to unpack error

[noreply] [BEAM-13480] Sickbay PubSubIntegrationTest.test_streaming_data_only on

[Kyle Weaver] remove redundant testImplementation dependencies

[noreply] [BEAM-13430] Swap to use "mainClass" instead of "main" since it was

[noreply] [BEAM-13430] Replace deprecated "appendix" with "archiveAppendix"

[noreply] [BEAM-13015] Add jamm as a java agent to the Java SDK harness container

[noreply] [BEAM-13430] Partially revert

[noreply] Merge pull request #15863 from [BEAM-13184] Autosharding for

[noreply] [BEAM-11936] Enable FloatingPointAssertionWithinEpsilon errorprone check

[noreply] [BEAM-11936] Enable LockNotBeforeTry errorprone check (#16259)

[noreply] [BEAM-11936] Enable errorprone unused checks (#16262)

[noreply] Add Nexmark Query 14 (#16337)

[noreply] [BEAM-13015] Migrate all user state and side implementations to support


------------------------------------------
[...truncated 493.77 KB...]
      urn: "beam:env:docker:v1"
      payload: "\n apache/beam_java8_sdk:2.37.0.dev"
      capabilities: "beam:coder:bytes:v1"
      capabilities: "beam:coder:bool:v1"
      capabilities: "beam:coder:varint:v1"
      capabilities: "beam:coder:string_utf8:v1"
      capabilities: "beam:coder:iterable:v1"
      capabilities: "beam:coder:timer:v1"
      capabilities: "beam:coder:kv:v1"
      capabilities: "beam:coder:length_prefix:v1"
      capabilities: "beam:coder:global_window:v1"
      capabilities: "beam:coder:interval_window:v1"
      capabilities: "beam:coder:custom_window:v1"
      capabilities: "beam:coder:windowed_value:v1"
      capabilities: "beam:coder:double:v1"
      capabilities: "beam:coder:row:v1"
      capabilities: "beam:coder:param_windowed_value:v1"
      capabilities: "beam:coder:state_backed_iterable:v1"
      capabilities: "beam:coder:sharded_key:v1"
      capabilities: "beam:protocol:multi_core_bundle_processing:v1"
      capabilities: "beam:protocol:progress_reporting:v1"
      capabilities: "beam:protocol:harness_monitoring_infos:v1"
      capabilities: "beam:protocol:control_request_elements_embedding:v1"
      capabilities: "beam:version:sdk_base:apache/beam_java8_sdk:2.37.0.dev"
      capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
      capabilities: "beam:transform:to_string:v1"
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nL/tmp/artifacts/icedtea-sound-Bdoi2wYa757-fzq5vconCy4SSQ22ZaOq7yuC98fKPs8.jar\022@05da22db061aef9efe7f3ab9bdca270b2e12490db665a3aaef2b82f7c7ca3ecf"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n=icedtea-sound-Bdoi2wYa757-fzq5vconCy4SSQ22ZaOq7yuC98fKPs8.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/jaccess-CMbK-IOdQPLKHEqCuDnE-yBk-VpbtVT-hgjbHRUGO78.jar\022@08c6caf8839d40f2ca1c4a82b839c4fb2064f95a5bb554fe8608db1d15063bbf"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7jaccess-CMbK-IOdQPLKHEqCuDnE-yBk-VpbtVT-hgjbHRUGO78.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nI/tmp/artifacts/localedata-ae5Z0L6ak4922fztWeWy7ajiWXdG3ubNrwerJRFoFj0.jar\022@69ee59d0be9a938f76d9fced59e5b2eda8e2597746dee6cdaf07ab251168163d"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n:localedata-ae5Z0L6ak4922fztWeWy7ajiWXdG3ubNrwerJRFoFj0.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/nashorn-XHtz_UehGpYcLTOrATrTnMNVUgEVa_ttoWkPxnVfqTo.jar\022@5c7b73fd47a11a961c2d33ab013ad39cc3555201156bfb6da1690fc6755fa93a"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7nashorn-XHtz_UehGpYcLTOrATrTnMNVUgEVa_ttoWkPxnVfqTo.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nG/tmp/artifacts/cldrdata-k07I6K9W3X5KTQbcDIEsqM0LXyM18f0eR6IaJw-P_xk.jar\022@934ec8e8af56dd7e4a4d06dc0c812ca8cd0b5f2335f1fd1e47a21a270f8fff19"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n8cldrdata-k07I6K9W3X5KTQbcDIEsqM0LXyM18f0eR6IaJw-P_xk.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nD/tmp/artifacts/dnsns-RGhCDg3GVOQVC2r6ka2N0hmI4eqQH6VobuoAnQ74MnE.jar\022@4468420e0dc654e4150b6afa91ad8dd21988e1ea901fa5686eea009d0ef83271"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n5dnsns-RGhCDg3GVOQVC2r6ka2N0hmI4eqQH6VobuoAnQ74MnE.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\n\214\001/tmp/artifacts/beam-sdks-java-testing-expansion-service-testExpansionService-2.37.0-SNAPSHOT-spndO6P8pPi-Efc10YAlvTks3t7HdnqxHPi7LSjUDSU.jar\022@b299dd3ba3fca4f8be11f735d18025bd392cdedec7767ab11cf8bb2d28d40d25"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n}beam-sdks-java-testing-expansion-service-testExpansionService-2.37.0-SNAPSHOT-spndO6P8pPi-Efc10YAlvTks3t7HdnqxHPi7LSjUDSU.jar"
      >
    >
  >
>
root_transform_ids: "e1"
root_transform_ids: "e2"
root_transform_ids: "s1"
root_transform_ids: "e5"
root_transform_ids: "s3"
root_transform_ids: "e4"
root_transform_ids: "s2"
2022/01/05 00:25:26 Prepared job with id: go-job-8-1641342326195721988-e8b5d4a9-498a-4a7d-83fd-55e97a1c3150 and staging token: go-job-8-1641342326195721988-e8b5d4a9-498a-4a7d-83fd-55e97a1c3150
2022/01/05 00:25:26 Cross-compiling <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/go/test/integration/xlang/xlang_test.go> as /tmp/worker-8-1641342326199549619
2022/01/05 00:25:29 Staged binary artifact with token: 
2022/01/05 00:25:29 Submitted job: go-job-8-1641342326195721988-e8b5d4a9-498a-4a7d-83fd-55e97a1c3150
2022/01/05 00:25:29 2022-01-05 00:25:29. (1): Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
2022/01/05 00:25:29 2022-01-05 00:25:29. (7): ==================== <function expand_sdf at 0x7fc035b707b8> ====================
2022/01/05 00:25:29 2022-01-05 00:25:29. (8): ==================== <function expand_gbk at 0x7fc035b70840> ====================
2022/01/05 00:25:29 2022-01-05 00:25:29. (9): ==================== <function sink_flattens at 0x7fc035b70950> ====================
2022/01/05 00:25:29 2022-01-05 00:25:29. (10): ==================== <function greedily_fuse at 0x7fc035b709d8> ====================
2022/01/05 00:25:29 2022-01-05 00:25:29. (11): ==================== <function read_to_impulse at 0x7fc035b70a60> ====================
2022/01/05 00:25:29 2022-01-05 00:25:29. (12): ==================== <function impulse_to_input at 0x7fc035b70ae8> ====================
2022/01/05 00:25:29 2022-01-05 00:25:29. (13): ==================== <function sort_stages at 0x7fc035b70d08> ====================
2022/01/05 00:25:29 2022-01-05 00:25:29. (14): ==================== <function setup_timer_mapping at 0x7fc035b70c80> ====================
2022/01/05 00:25:29 2022-01-05 00:25:29. (15): ==================== <function populate_data_channel_coders at 0x7fc035b70d90> ====================
2022/01/05 00:25:29 Job state: STOPPED
2022/01/05 00:25:29 Job state: STARTING
2022/01/05 00:25:29 Job state: RUNNING
2022/01/05 00:25:29 2022-01-05 00:25:29. (16): starting control server on port 38475
2022/01/05 00:25:29 2022-01-05 00:25:29. (17): starting data server on port 35959
2022/01/05 00:25:29 2022-01-05 00:25:29. (18): starting state server on port 44473
2022/01/05 00:25:29 2022-01-05 00:25:29. (19): starting logging server on port 36165
2022/01/05 00:25:29 2022-01-05 00:25:29. (20): Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7fc034339a90> for environment go (beam:env:docker:v1, b'\n\x16apache/beam_go_sdk:dev')
2022/01/05 00:25:29 2022-01-05 00:25:29. (21): Attempting to pull image apache/beam_go_sdk:dev
2022/01/05 00:25:29 2022-01-05 00:25:29. (22): Unable to pull image apache/beam_go_sdk:dev, defaulting to local image if it exists
2022/01/05 00:25:33 2022-01-05 00:25:33. (23): Waiting for docker to start up. Current status is running
2022/01/05 00:25:33 2022-01-05 00:25:33. (24): Docker container is running. container_id = b'5bcda7b5eba741065d4038205d47efe653c9e3071f5372e90e9c9b48538391d7', worker_id = worker_13
2022/01/05 00:25:35 2022-01-05 00:25:35. (25): Running ((e1)+(e2))+(n2/Write)
2022/01/05 00:25:35 2022-01-05 00:25:35. (26): Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7fc034319da0> for environment mMzxVLWIBtbeam:env:docker:v1 (beam:env:docker:v1, b'\n apache/beam_java8_sdk:2.37.0.dev')
2022/01/05 00:25:35 2022-01-05 00:25:35. (27): Attempting to pull image apache/beam_java8_sdk:2.37.0.dev
2022/01/05 00:25:35 2022-01-05 00:25:35. (28): Unable to pull image apache/beam_java8_sdk:2.37.0.dev, defaulting to local image if it exists
2022/01/05 00:25:36 2022-01-05 00:25:36. (29): Waiting for docker to start up. Current status is running
2022/01/05 00:25:36 2022-01-05 00:25:36. (30): Docker container is running. container_id = b'6d3e3ac4db7463825bdc5d53fba10bf455024f2e80654076e5b080ec0149ca18', worker_id = worker_14
2022/01/05 00:25:37 2022-01-05 00:25:37. (31): Running (((n2/Read)+(mMzxVLWIBtExternal-ParMultiDo-Partition-))+(mMzxVLWIBtExternal/ParMultiDo(Partition).out1/Write))+(mMzxVLWIBtExternal/ParMultiDo(Partition).out2/Write)
2022/01/05 00:25:41 2022-01-05 00:25:41. (32): Running (((mMzxVLWIBtExternal/ParMultiDo(Partition).out2/Read)+(e5))+(e15_keyed1))+(n6_keyede15_1/Write)
2022/01/05 00:25:41 2022-01-05 00:25:41. (33): Running (((e12)+(e13))+(e15_keyed2))+(n15_keyede15_2/Write)
2022/01/05 00:25:41 2022-01-05 00:25:41. (34): Running (((((((e14)+(e15))+(e17_keyed2))+(e17_keyed3))+(e17_keyed1))+(n19_keyede17_3/Write))+(n18_keyede17_2/Write))+(n17_keyede17_1/Write)
2022/01/05 00:25:41 2022-01-05 00:25:41. (35): Running (((e6)+(e7))+(e9_keyed2))+(n8_keyede9_2/Write)
2022/01/05 00:25:41 2022-01-05 00:25:41. (36): Running (((mMzxVLWIBtExternal/ParMultiDo(Partition).out1/Read)+(e4))+(e9_keyed1))+(n5_keyede9_1/Write)
2022/01/05 00:25:41 2022-01-05 00:25:41. (37): Running (((((((e8)+(e9))+(e11_keyed3))+(e11_keyed1))+(e11_keyed2))+(n12_keyede11_3/Write))+(n11_keyede11_2/Write))+(n10_keyede11_1/Write)
2022/01/05 00:25:41 2022-01-05 00:25:41. (38): Running (e10)+(e11)
2022/01/05 00:25:41 2022-01-05 00:25:41. (39): Running (e16)+(e17)
2022/01/05 00:25:43 2022-01-05 00:25:43. (40): Successfully completed job in 14.466496229171753 seconds.
2022/01/05 00:25:43 Job state: DONE
--- PASS: TestXLang_Partition (19.39s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	231.523s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:181: Test TestKafkaIO_BasicReadWrite is currently filtered for runner portable
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	3.038s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ exit 1
$ exit 1

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

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerPythonUsingJava
>>> RUNNING integration tests with pipeline options: --runner=PortableRunner --job_endpoint=localhost:40353 --environment_cache_millis=10000 --experiments=beam_fn_api
>>>   pytest options: 
>>>   collect markers: -m=xlang_transforms
============================= test session starts ==============================
platform linux -- Python 3.6.13, 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 5154 items / 5144 deselected / 10 selected

apache_beam/io/external/generate_sequence_test.py 
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerJavaUsingJava
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerJavaUsingPython
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerJavaUsingPythonOnly

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerPythonUsingJava
...                    [ 30%]
apache_beam/transforms/validate_runner_xlang_test.py .......             [100%]

=============================== warnings summary ===============================
apache_beam/io/filesystems_test.py:54
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/io/filesystems_test.py>:54: DeprecationWarning: invalid escape sequence \c
    self.assertIsNone(FileSystems.get_scheme('c:\\abc\cdf'))  # pylint: disable=anomalous-backslash-in-string

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

-- 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, 5144 deselected, 2 warnings in 195.02 seconds ===========

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerPythonUsingPython
>>> RUNNING integration tests with pipeline options: --runner=PortableRunner --job_endpoint=localhost:40353 --environment_cache_millis=10000 --experiments=beam_fn_api
>>>   pytest options: 
>>>   collect markers: -m=xlang_transforms
============================= test session starts ==============================
platform linux -- Python 3.6.13, 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 5154 items / 5144 deselected / 10 selected

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

- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/pytest_xlangValidateRunner.xml> -
============ 8 passed, 2 skipped, 5144 deselected in 98.34 seconds =============

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerPythonUsingSql
>>> RUNNING integration tests with pipeline options: --runner=PortableRunner --job_endpoint=localhost:40353 --environment_cache_millis=10000 --experiments=beam_fn_api
>>>   pytest options: 
>>>   collect markers: -m=xlang_sql_expansion_service
============================= test session starts ==============================
platform linux -- Python 3.6.13, 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 5154 items / 5145 deselected / 9 selected

apache_beam/transforms/sql_test.py .........                             [100%]

- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/pytest_xlangSqlValidateRunner.xml> -
================= 9 passed, 5145 deselected in 369.76 seconds ==================

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

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

FAILURE: Build 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: 170

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

* 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.3.2/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 47m 59s
169 actionable tasks: 134 executed, 27 from cache, 8 up-to-date

Publishing build scan...
https://gradle.com/s/4sortf5zmxwao

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_XVR_Direct #2143

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

Changes:

[noreply] Merge pull request #16404: [BEAM-13586] Fix NPE in


------------------------------------------
[...truncated 477.74 KB...]
      >
    >
  >
  coders: <
    key: "c0@BvHlaMWTNs"
    value: <
      spec: <
        urn: "beam:coder:varint:v1"
      >
    >
  >
  coders: <
    key: "c1"
    value: <
      spec: <
        urn: "beam:coder:global_window:v1"
      >
    >
  >
  coders: <
    key: "c1@BvHlaMWTNs"
    value: <
      spec: <
        urn: "beam:coder:global_window:v1"
      >
    >
  >
  coders: <
    key: "c2"
    value: <
      spec: <
        urn: "beam:coder:varint:v1"
      >
    >
  >
  coders: <
    key: "c3"
    value: <
      spec: <
        urn: "beam:coder:string_utf8:v1"
      >
    >
  >
  coders: <
    key: "c4"
    value: <
      spec: <
        urn: "beam:coder:kv:v1"
      >
      component_coder_ids: "c0"
      component_coder_ids: "c3"
    >
  >
  environments: <
    key: "BvHlaMWTNsbeam:env:docker:v1"
    value: <
      urn: "beam:env:docker:v1"
      payload: "\n apache/beam_java8_sdk:2.37.0.dev"
      capabilities: "beam:coder:bytes:v1"
      capabilities: "beam:coder:bool:v1"
      capabilities: "beam:coder:varint:v1"
      capabilities: "beam:coder:string_utf8:v1"
      capabilities: "beam:coder:iterable:v1"
      capabilities: "beam:coder:timer:v1"
      capabilities: "beam:coder:kv:v1"
      capabilities: "beam:coder:length_prefix:v1"
      capabilities: "beam:coder:global_window:v1"
      capabilities: "beam:coder:interval_window:v1"
      capabilities: "beam:coder:custom_window:v1"
      capabilities: "beam:coder:windowed_value:v1"
      capabilities: "beam:coder:double:v1"
      capabilities: "beam:coder:row:v1"
      capabilities: "beam:coder:param_windowed_value:v1"
      capabilities: "beam:coder:state_backed_iterable:v1"
      capabilities: "beam:coder:sharded_key:v1"
      capabilities: "beam:protocol:multi_core_bundle_processing:v1"
      capabilities: "beam:protocol:progress_reporting:v1"
      capabilities: "beam:protocol:harness_monitoring_infos:v1"
      capabilities: "beam:protocol:control_request_elements_embedding:v1"
      capabilities: "beam:version:sdk_base:apache/beam_java8_sdk:2.37.0.dev"
      capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
      capabilities: "beam:transform:to_string:v1"
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nL/tmp/artifacts/icedtea-sound-Bdoi2wYa757-fzq5vconCy4SSQ22ZaOq7yuC98fKPs8.jar\022@05da22db061aef9efe7f3ab9bdca270b2e12490db665a3aaef2b82f7c7ca3ecf"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n=icedtea-sound-Bdoi2wYa757-fzq5vconCy4SSQ22ZaOq7yuC98fKPs8.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/jaccess-CMbK-IOdQPLKHEqCuDnE-yBk-VpbtVT-hgjbHRUGO78.jar\022@08c6caf8839d40f2ca1c4a82b839c4fb2064f95a5bb554fe8608db1d15063bbf"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7jaccess-CMbK-IOdQPLKHEqCuDnE-yBk-VpbtVT-hgjbHRUGO78.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nI/tmp/artifacts/localedata-ae5Z0L6ak4922fztWeWy7ajiWXdG3ubNrwerJRFoFj0.jar\022@69ee59d0be9a938f76d9fced59e5b2eda8e2597746dee6cdaf07ab251168163d"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n:localedata-ae5Z0L6ak4922fztWeWy7ajiWXdG3ubNrwerJRFoFj0.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/nashorn-XHtz_UehGpYcLTOrATrTnMNVUgEVa_ttoWkPxnVfqTo.jar\022@5c7b73fd47a11a961c2d33ab013ad39cc3555201156bfb6da1690fc6755fa93a"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7nashorn-XHtz_UehGpYcLTOrATrTnMNVUgEVa_ttoWkPxnVfqTo.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nG/tmp/artifacts/cldrdata-k07I6K9W3X5KTQbcDIEsqM0LXyM18f0eR6IaJw-P_xk.jar\022@934ec8e8af56dd7e4a4d06dc0c812ca8cd0b5f2335f1fd1e47a21a270f8fff19"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n8cldrdata-k07I6K9W3X5KTQbcDIEsqM0LXyM18f0eR6IaJw-P_xk.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nD/tmp/artifacts/dnsns-RGhCDg3GVOQVC2r6ka2N0hmI4eqQH6VobuoAnQ74MnE.jar\022@4468420e0dc654e4150b6afa91ad8dd21988e1ea901fa5686eea009d0ef83271"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n5dnsns-RGhCDg3GVOQVC2r6ka2N0hmI4eqQH6VobuoAnQ74MnE.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\n\214\001/tmp/artifacts/beam-sdks-java-testing-expansion-service-testExpansionService-2.36.0-SNAPSHOT-E4BFXkctHbsFyaaU3gvHCclyvvdvrrpN9Sr0jQQWUg8.jar\022@1380455e472d1dbb05c9a694de0bc709c972bef76faeba4df52af48d0416520f"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n}beam-sdks-java-testing-expansion-service-testExpansionService-2.36.0-SNAPSHOT-E4BFXkctHbsFyaaU3gvHCclyvvdvrrpN9Sr0jQQWUg8.jar"
      >
    >
  >
  environments: <
    key: "go"
    value: <
      urn: "beam:env:docker:v1"
      payload: "\n\026apache/beam_go_sdk:dev"
      capabilities: "beam:protocol:progress_reporting:v0"
      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: "e1"
root_transform_ids: "e2"
root_transform_ids: "s1"
root_transform_ids: "e5"
root_transform_ids: "e4"
root_transform_ids: "s2"
root_transform_ids: "s3"
2022/01/04 18:16:20 Prepared job with id: go-job-8-1641320180894009252-bbc68f57-1f00-4b64-ac0a-ea47c7217cda and staging token: go-job-8-1641320180894009252-bbc68f57-1f00-4b64-ac0a-ea47c7217cda
2022/01/04 18:16:20 Cross-compiling <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/go/test/integration/xlang/xlang_test.go> as /tmp/worker-8-1641320180896747062
2022/01/04 18:16:22 Staged binary artifact with token: 
2022/01/04 18:16:22 Submitted job: go-job-8-1641320180894009252-bbc68f57-1f00-4b64-ac0a-ea47c7217cda
2022/01/04 18:16:22 2022-01-04 18:16:22. (1): Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
2022/01/04 18:16:22 2022-01-04 18:16:22. (11): ==================== <function read_to_impulse at 0x7fea4394b8c8> ====================
2022/01/04 18:16:22 2022-01-04 18:16:22. (12): ==================== <function impulse_to_input at 0x7fea4394b950> ====================
2022/01/04 18:16:22 2022-01-04 18:16:22. (13): ==================== <function sort_stages at 0x7fea4394bb70> ====================
2022/01/04 18:16:22 2022-01-04 18:16:22. (14): ==================== <function setup_timer_mapping at 0x7fea4394bae8> ====================
2022/01/04 18:16:22 2022-01-04 18:16:22. (15): ==================== <function populate_data_channel_coders at 0x7fea4394bbf8> ====================
2022/01/04 18:16:22 2022-01-04 18:16:22. (16): starting control server on port 34833
2022/01/04 18:16:22 2022-01-04 18:16:22. (17): starting data server on port 38121
2022/01/04 18:16:22 2022-01-04 18:16:22. (18): starting state server on port 36121
2022/01/04 18:16:22 2022-01-04 18:16:22. (19): starting logging server on port 46141
2022/01/04 18:16:22 Job state: STOPPED
2022/01/04 18:16:22 Job state: STARTING
2022/01/04 18:16:22 Job state: RUNNING
2022/01/04 18:16:22 2022-01-04 18:16:22. (20): Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7fea403910b8> for environment go (beam:env:docker:v1, b'\n\x16apache/beam_go_sdk:dev')
2022/01/04 18:16:22 2022-01-04 18:16:22. (21): Attempting to pull image apache/beam_go_sdk:dev
2022/01/04 18:16:23 2022-01-04 18:16:23. (22): Unable to pull image apache/beam_go_sdk:dev, defaulting to local image if it exists
2022/01/04 18:16:25 2022-01-04 18:16:25. (23): Waiting for docker to start up. Current status is running
2022/01/04 18:16:25 2022-01-04 18:16:25. (24): Docker container is running. container_id = b'9e6f6026c6392942f9b829a8cb05ff365c661e771e779498473d446d35c16939', worker_id = worker_13
2022/01/04 18:16:26 2022-01-04 18:16:26. (25): Running ((e1)+(e2))+(n2/Write)
2022/01/04 18:16:26 2022-01-04 18:16:26. (26): Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7fea40322400> for environment BvHlaMWTNsbeam:env:docker:v1 (beam:env:docker:v1, b'\n apache/beam_java8_sdk:2.37.0.dev')
2022/01/04 18:16:26 2022-01-04 18:16:26. (27): Attempting to pull image apache/beam_java8_sdk:2.37.0.dev
2022/01/04 18:16:27 2022-01-04 18:16:27. (28): Unable to pull image apache/beam_java8_sdk:2.37.0.dev, defaulting to local image if it exists
2022/01/04 18:16:28 2022-01-04 18:16:28. (29): Waiting for docker to start up. Current status is running
2022/01/04 18:16:28 2022-01-04 18:16:28. (30): Docker container is running. container_id = b'a48511f05053be2ac01adde24f6990d692ad259c7d54c019465518ad2b1c23b3', worker_id = worker_14
2022/01/04 18:16:29 2022-01-04 18:16:29. (31): Running (((n2/Read)+(BvHlaMWTNsExternal-ParMultiDo-Partition-))+(BvHlaMWTNsExternal/ParMultiDo(Partition).out2/Write))+(BvHlaMWTNsExternal/ParMultiDo(Partition).out1/Write)
2022/01/04 18:16:31 2022-01-04 18:16:31. (32): Running (((BvHlaMWTNsExternal/ParMultiDo(Partition).out1/Read)+(e4))+(e9_keyed1))+(n5_keyede9_1/Write)
2022/01/04 18:16:31 2022-01-04 18:16:31. (33): Running (((BvHlaMWTNsExternal/ParMultiDo(Partition).out2/Read)+(e5))+(e15_keyed1))+(n6_keyede15_1/Write)
2022/01/04 18:16:31 2022-01-04 18:16:31. (34): Running (((e12)+(e13))+(e15_keyed2))+(n15_keyede15_2/Write)
2022/01/04 18:16:31 2022-01-04 18:16:31. (35): Running (((((((e14)+(e15))+(e17_keyed2))+(e17_keyed3))+(e17_keyed1))+(n19_keyede17_3/Write))+(n18_keyede17_2/Write))+(n17_keyede17_1/Write)
2022/01/04 18:16:31 2022-01-04 18:16:31. (36): Running (e16)+(e17)
2022/01/04 18:16:31 2022-01-04 18:16:31. (37): Running (((e6)+(e7))+(e9_keyed2))+(n8_keyede9_2/Write)
2022/01/04 18:16:31 2022-01-04 18:16:31. (38): Running (((((((e8)+(e9))+(e11_keyed2))+(e11_keyed3))+(e11_keyed1))+(n12_keyede11_3/Write))+(n11_keyede11_2/Write))+(n10_keyede11_1/Write)
2022/01/04 18:16:31 2022-01-04 18:16:31. (39): Running (e10)+(e11)
2022/01/04 18:16:32 2022-01-04 18:16:32. (40): Successfully completed job in 9.990108728408813 seconds.
2022/01/04 18:16:32 Job state: DONE
--- PASS: TestXLang_Partition (13.16s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/xlang	108.660s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:181: Test TestKafkaIO_BasicReadWrite is currently filtered for runner portable
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	3.048s

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerJavaUsingJava
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerJavaUsingPython
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerJavaUsingPythonOnly
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerPythonUsingJava
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerPythonUsingPython
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerPythonUsingSql FAILED
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerCleanup
> Task :sdks:python:test-suites:direct:xlang:fnApiJobServerCleanup

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.3.2/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 29m 16s
169 actionable tasks: 107 executed, 53 from cache, 9 up-to-date

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

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_XVR_Direct #2142

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

Changes:


------------------------------------------
[...truncated 836.51 KB...]
    value: <
      spec: <
        urn: "beam:coder:global_window:v1"
      >
    >
  >
  coders: <
    key: "c1@tbuHkIrfub"
    value: <
      spec: <
        urn: "beam:coder:global_window:v1"
      >
    >
  >
  coders: <
    key: "c2"
    value: <
      spec: <
        urn: "beam:coder:varint:v1"
      >
    >
  >
  coders: <
    key: "c3"
    value: <
      spec: <
        urn: "beam:coder:string_utf8:v1"
      >
    >
  >
  coders: <
    key: "c4"
    value: <
      spec: <
        urn: "beam:coder:kv:v1"
      >
      component_coder_ids: "c0"
      component_coder_ids: "c3"
    >
  >
  coders: <
    key: "tbuHkIrfubVoidCoder"
    value: <
      spec: <
        urn: "beam:coders:javasdk:0.1"
        payload: "\202SNAPPY\000\000\000\000\001\000\000\000\001\000\000\000\210\326\001\350\254\355\000\005sr\000$org.apache.beam.sdk.coders.VoidCoder\271\277U\233\350\r\257U\002\000\000xr\000&j3\000\024Atomic\0055 \307\354\265\314\205tPF\002\0055\000*j5\000$Structured\0059\034s\277\022\016\325\3246\021\t9\000 j9\000\005/0C\335\325\211\256\274~\370\002\000\000xp"
      >
    >
  >
  environments: <
    key: "go"
    value: <
      urn: "beam:env:docker:v1"
      payload: "\n\026apache/beam_go_sdk:dev"
      capabilities: "beam:protocol:progress_reporting:v0"
      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"
      >
    >
  >
  environments: <
    key: "tbuHkIrfubbeam:env:docker:v1"
    value: <
      urn: "beam:env:docker:v1"
      payload: "\n apache/beam_java8_sdk:2.37.0.dev"
      capabilities: "beam:coder:bytes:v1"
      capabilities: "beam:coder:bool:v1"
      capabilities: "beam:coder:varint:v1"
      capabilities: "beam:coder:string_utf8:v1"
      capabilities: "beam:coder:iterable:v1"
      capabilities: "beam:coder:timer:v1"
      capabilities: "beam:coder:kv:v1"
      capabilities: "beam:coder:length_prefix:v1"
      capabilities: "beam:coder:global_window:v1"
      capabilities: "beam:coder:interval_window:v1"
      capabilities: "beam:coder:custom_window:v1"
      capabilities: "beam:coder:windowed_value:v1"
      capabilities: "beam:coder:double:v1"
      capabilities: "beam:coder:row:v1"
      capabilities: "beam:coder:param_windowed_value:v1"
      capabilities: "beam:coder:state_backed_iterable:v1"
      capabilities: "beam:coder:sharded_key:v1"
      capabilities: "beam:protocol:multi_core_bundle_processing:v1"
      capabilities: "beam:protocol:progress_reporting:v1"
      capabilities: "beam:protocol:harness_monitoring_infos:v1"
      capabilities: "beam:protocol:control_request_elements_embedding:v1"
      capabilities: "beam:version:sdk_base:apache/beam_java8_sdk:2.37.0.dev"
      capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
      capabilities: "beam:transform:to_string:v1"
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nL/tmp/artifacts/icedtea-sound-Bdoi2wYa757-fzq5vconCy4SSQ22ZaOq7yuC98fKPs8.jar\022@05da22db061aef9efe7f3ab9bdca270b2e12490db665a3aaef2b82f7c7ca3ecf"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n=icedtea-sound-Bdoi2wYa757-fzq5vconCy4SSQ22ZaOq7yuC98fKPs8.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/jaccess-CMbK-IOdQPLKHEqCuDnE-yBk-VpbtVT-hgjbHRUGO78.jar\022@08c6caf8839d40f2ca1c4a82b839c4fb2064f95a5bb554fe8608db1d15063bbf"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7jaccess-CMbK-IOdQPLKHEqCuDnE-yBk-VpbtVT-hgjbHRUGO78.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nI/tmp/artifacts/localedata-ae5Z0L6ak4922fztWeWy7ajiWXdG3ubNrwerJRFoFj0.jar\022@69ee59d0be9a938f76d9fced59e5b2eda8e2597746dee6cdaf07ab251168163d"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n:localedata-ae5Z0L6ak4922fztWeWy7ajiWXdG3ubNrwerJRFoFj0.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/nashorn-XHtz_UehGpYcLTOrATrTnMNVUgEVa_ttoWkPxnVfqTo.jar\022@5c7b73fd47a11a961c2d33ab013ad39cc3555201156bfb6da1690fc6755fa93a"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7nashorn-XHtz_UehGpYcLTOrATrTnMNVUgEVa_ttoWkPxnVfqTo.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nG/tmp/artifacts/cldrdata-k07I6K9W3X5KTQbcDIEsqM0LXyM18f0eR6IaJw-P_xk.jar\022@934ec8e8af56dd7e4a4d06dc0c812ca8cd0b5f2335f1fd1e47a21a270f8fff19"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n8cldrdata-k07I6K9W3X5KTQbcDIEsqM0LXyM18f0eR6IaJw-P_xk.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nD/tmp/artifacts/dnsns-RGhCDg3GVOQVC2r6ka2N0hmI4eqQH6VobuoAnQ74MnE.jar\022@4468420e0dc654e4150b6afa91ad8dd21988e1ea901fa5686eea009d0ef83271"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n5dnsns-RGhCDg3GVOQVC2r6ka2N0hmI4eqQH6VobuoAnQ74MnE.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\n\214\001/tmp/artifacts/beam-sdks-java-testing-expansion-service-testExpansionService-2.36.0-SNAPSHOT-E4BFXkctHbsFyaaU3gvHCclyvvdvrrpN9Sr0jQQWUg8.jar\022@1380455e472d1dbb05c9a694de0bc709c972bef76faeba4df52af48d0416520f"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n}beam-sdks-java-testing-expansion-service-testExpansionService-2.36.0-SNAPSHOT-E4BFXkctHbsFyaaU3gvHCclyvvdvrrpN9Sr0jQQWUg8.jar"
      >
    >
  >
>
root_transform_ids: "e1"
root_transform_ids: "e2"
root_transform_ids: "s1"
root_transform_ids: "e5"
root_transform_ids: "s3"
root_transform_ids: "e4"
root_transform_ids: "s2"
2022/01/04 12:14:06 Prepared job with id: go-job-8-1641298446852080849-2f717746-f857-44cb-bc89-cdf60e9d4c9b and staging token: go-job-8-1641298446852080849-2f717746-f857-44cb-bc89-cdf60e9d4c9b
2022/01/04 12:14:06 Cross-compiling <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/go/test/integration/xlang/xlang_test.go> as /tmp/worker-8-1641298446854647805
2022/01/04 12:14:08 Staged binary artifact with token: 
2022/01/04 12:14:08 Submitted job: go-job-8-1641298446852080849-2f717746-f857-44cb-bc89-cdf60e9d4c9b
2022/01/04 12:14:08 2022-01-04 12:14:08. (1): Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
2022/01/04 12:14:08 2022-01-04 12:14:08. (7): ==================== <function expand_sdf at 0x7f3fcd96f620> ====================
2022/01/04 12:14:08 2022-01-04 12:14:08. (8): ==================== <function expand_gbk at 0x7f3fcd96f6a8> ====================
2022/01/04 12:14:08 2022-01-04 12:14:08. (9): ==================== <function sink_flattens at 0x7f3fcd96f7b8> ====================
2022/01/04 12:14:08 2022-01-04 12:14:08. (10): ==================== <function greedily_fuse at 0x7f3fcd96f840> ====================
2022/01/04 12:14:08 2022-01-04 12:14:08. (11): ==================== <function read_to_impulse at 0x7f3fcd96f8c8> ====================
2022/01/04 12:14:08 2022-01-04 12:14:08. (12): ==================== <function impulse_to_input at 0x7f3fcd96f950> ====================
2022/01/04 12:14:08 2022-01-04 12:14:08. (13): ==================== <function sort_stages at 0x7f3fcd96fb70> ====================
2022/01/04 12:14:08 2022-01-04 12:14:08. (14): ==================== <function setup_timer_mapping at 0x7f3fcd96fae8> ====================
2022/01/04 12:14:08 2022-01-04 12:14:08. (15): ==================== <function populate_data_channel_coders at 0x7f3fcd96fbf8> ====================
2022/01/04 12:14:08 Job state: STOPPED
2022/01/04 12:14:08 Job state: STARTING
2022/01/04 12:14:08 Job state: RUNNING
2022/01/04 12:14:08 2022-01-04 12:14:08. (16): starting control server on port 44081
2022/01/04 12:14:08 2022-01-04 12:14:08. (17): starting data server on port 45395
2022/01/04 12:14:08 2022-01-04 12:14:08. (18): starting state server on port 46607
2022/01/04 12:14:08 2022-01-04 12:14:08. (19): starting logging server on port 37983
2022/01/04 12:14:08 2022-01-04 12:14:08. (20): Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f3fcc1abcf8> for environment go (beam:env:docker:v1, b'\n\x16apache/beam_go_sdk:dev')
2022/01/04 12:14:08 2022-01-04 12:14:08. (21): Attempting to pull image apache/beam_go_sdk:dev
2022/01/04 12:14:09 2022-01-04 12:14:09. (22): Unable to pull image apache/beam_go_sdk:dev, defaulting to local image if it exists
2022/01/04 12:14:11 2022-01-04 12:14:11. (23): Waiting for docker to start up. Current status is running
2022/01/04 12:14:11 2022-01-04 12:14:11. (24): Docker container is running. container_id = b'3ddda03c5240c4ac5ba885e8293fc22635b1f0eb579d1b82cb7d4349dc8592e0', worker_id = worker_13
2022/01/04 12:14:12 2022-01-04 12:14:12. (25): Running ((e1)+(e2))+(n2/Write)
2022/01/04 12:14:12 2022-01-04 12:14:12. (26): Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f3fcc170828> for environment tbuHkIrfubbeam:env:docker:v1 (beam:env:docker:v1, b'\n apache/beam_java8_sdk:2.37.0.dev')
2022/01/04 12:14:12 2022-01-04 12:14:12. (27): Attempting to pull image apache/beam_java8_sdk:2.37.0.dev
2022/01/04 12:14:13 2022-01-04 12:14:13. (28): Unable to pull image apache/beam_java8_sdk:2.37.0.dev, defaulting to local image if it exists
2022/01/04 12:14:14 2022-01-04 12:14:14. (29): Waiting for docker to start up. Current status is running
2022/01/04 12:14:14 2022-01-04 12:14:14. (30): Docker container is running. container_id = b'256d98407c6c3e255b954970be1617806f040f8d95456353401d88fdd54cd0fd', worker_id = worker_14
2022/01/04 12:14:15 2022-01-04 12:14:15. (31): Running (((n2/Read)+(tbuHkIrfubExternal-ParMultiDo-Partition-))+(tbuHkIrfubExternal/ParMultiDo(Partition).out1/Write))+(tbuHkIrfubExternal/ParMultiDo(Partition).out2/Write)
2022/01/04 12:14:17 2022-01-04 12:14:17. (32): Running (((e12)+(e13))+(e15_keyed2))+(n15_keyede15_2/Write)
2022/01/04 12:14:18 2022-01-04 12:14:18. (33): Running (((tbuHkIrfubExternal/ParMultiDo(Partition).out2/Read)+(e5))+(e15_keyed1))+(n6_keyede15_1/Write)
2022/01/04 12:14:18 2022-01-04 12:14:18. (34): Running (((((((e14)+(e15))+(e17_keyed1))+(e17_keyed2))+(e17_keyed3))+(n19_keyede17_3/Write))+(n18_keyede17_2/Write))+(n17_keyede17_1/Write)
2022/01/04 12:14:18 2022-01-04 12:14:18. (35): Running (((tbuHkIrfubExternal/ParMultiDo(Partition).out1/Read)+(e4))+(e9_keyed1))+(n5_keyede9_1/Write)
2022/01/04 12:14:18 2022-01-04 12:14:18. (36): Running (((e6)+(e7))+(e9_keyed2))+(n8_keyede9_2/Write)
2022/01/04 12:14:18 2022-01-04 12:14:18. (37): Running (((((((e8)+(e9))+(e11_keyed1))+(e11_keyed3))+(e11_keyed2))+(n12_keyede11_3/Write))+(n11_keyede11_2/Write))+(n10_keyede11_1/Write)
2022/01/04 12:14:18 2022-01-04 12:14:18. (38): Running (e10)+(e11)
2022/01/04 12:14:18 2022-01-04 12:14:18. (39): Running (e16)+(e17)
2022/01/04 12:14:19 2022-01-04 12:14:19. (40): Successfully completed job in 11.023703813552856 seconds.
2022/01/04 12:14:19 Job state: DONE
--- PASS: TestXLang_Partition (14.41s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/xlang	116.023s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:181: Test TestKafkaIO_BasicReadWrite is currently filtered for runner portable
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	3.023s

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerJavaUsingJava
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerJavaUsingPython
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerJavaUsingPythonOnly
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerPythonUsingJava
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerPythonUsingPython
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerPythonUsingSql FAILED
> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerCleanup
> Task :sdks:python:test-suites:direct:xlang:fnApiJobServerCleanup

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.3.2/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 27m 9s
169 actionable tasks: 107 executed, 53 from cache, 9 up-to-date

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

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