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 2023/08/05 23:37:44 UTC

Build failed in Jenkins: beam_PostCommit_XVR_Direct #4439

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

Changes:


------------------------------------------
[...truncated 1.50 MB...]
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:165: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/pvalue.py:137: in __or__
    return self.pipeline.apply(ptransform, self)
apache_beam/pipeline.py:712: 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:678: in expand
    with ExternalTransform.service(expansion_service) as service:
/usr/lib/python3.8/contextlib.py:113: in __enter__
    return next(self.gen)
apache_beam/transforms/external.py:733: in service
    with expansion_service as stub:
apache_beam/transforms/external.py:944: 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 0x7f334d93e790>

    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:88: RuntimeError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:239 Using pre-built snapshot at <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.50.0-SNAPSHOT.jar>
INFO     root:external.py:929 Starting a JAR-based expansion service from 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.50.0-SNAPSHOT.jar> 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:116 Starting 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.50.0-SNAPSHOT.jar'> '50311' '--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.50.0-SNAPSHOT.jar']>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 Error: Invalid or corrupt jarfile <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.50.0-SNAPSHOT.jar>
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.50.0-SNAPSHOT.jar',> '50311', '--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.50.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 88, in start
    raise RuntimeError(
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:154: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/transforms/ptransform.py:614: in __ror__
    result = p.apply(self, pvalueish, label)
apache_beam/pipeline.py:712: 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:678: in expand
    with ExternalTransform.service(expansion_service) as service:
/usr/lib/python3.8/contextlib.py:113: in __enter__
    return next(self.gen)
apache_beam/transforms/external.py:733: in service
    with expansion_service as stub:
apache_beam/transforms/external.py:944: 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 0x7f33123f0e20>

    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:88: RuntimeError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:239 Using pre-built snapshot at <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.50.0-SNAPSHOT.jar>
INFO     root:external.py:929 Starting a JAR-based expansion service from 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.50.0-SNAPSHOT.jar> 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:116 Starting 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.50.0-SNAPSHOT.jar'> '53841' '--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.50.0-SNAPSHOT.jar']>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 Error: Invalid or corrupt jarfile <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.50.0-SNAPSHOT.jar>
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.50.0-SNAPSHOT.jar',> '53841', '--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.50.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 88, in start
    raise RuntimeError(
RuntimeError: Service failed to start up with error 1
=============================== warnings summary ===============================
../../build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

../../build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py:18
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py>:18: DeprecationWarning: pkg_resources is deprecated as an API. See https://setuptools.pypa.io/en/latest/pkg_resources.html
    import pkg_resources

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871: 20 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871: 16 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.cloud')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2350: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(parent)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.logging')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.iam')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py:20
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py>:20: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.rpc')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    pkg_resources.declare_namespace(__name__)

apache_beam/typehints/pandas_type_compatibility_test.py:67
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:67: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    }).set_index(pd.Int64Index(range(123, 223), name='an_index')),

apache_beam/typehints/pandas_type_compatibility_test.py:90
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:90: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    pd.Int64Index(range(123, 223), name='an_index'),

apache_beam/typehints/pandas_type_compatibility_test.py:91
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:91: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    pd.Int64Index(range(475, 575), name='another_index'),

apache_beam/transforms/sql_test.py::SqlTransformTest::test_agg
apache_beam/transforms/sql_test.py::SqlTransformTest::test_filter
apache_beam/transforms/sql_test.py::SqlTransformTest::test_generate_data
apache_beam/transforms/sql_test.py::SqlTransformTest::test_map
apache_beam/transforms/sql_test.py::SqlTransformTest::test_project
apache_beam/transforms/sql_test.py::SqlTransformTest::test_row
apache_beam/transforms/sql_test.py::SqlTransformTest::test_tagged_join
apache_beam/transforms/sql_test.py::SqlTransformTest::test_windowing_before_sql
apache_beam/transforms/sql_test.py::SqlTransformTest::test_zetasql_generate_data
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/transforms/external.py>:676: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    self._expansion_service, pipeline.options)

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/pytest_xlangSqlValidateRunner.xml> -
=========================== short test summary info ============================
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_agg - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_filter - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_generate_data - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_map - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_project - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_row - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_tagged_join - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_windowing_before_sql - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_zetasql_generate_data - RuntimeError: Service failed to start up with error 1
========= 9 failed, 14 skipped, 6945 deselected, 57 warnings in 20.76s =========

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

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

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

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.

* 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.6.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 13s
258 actionable tasks: 167 executed, 79 from cache, 12 up-to-date

Publishing build scan...
https://ge.apache.org/s/vcbrmktwmlxoe

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

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

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

Changes:


------------------------------------------
[...truncated 1.32 MB...]
      component_coder_ids: "nEsyGtOMlIVarIntCoder"
      component_coder_ids: "nEsyGtOMlIIterableCoder"
    >
  >
  coders: <
    key: "nEsyGtOMlIRowCoder"
    value: <
      spec: <
        urn: "beam:coder:row:v1"
        payload: "\n\r\n\007role_id\032\002\020\004\022$9382b28c-74bc-4bd9-befd-6be465ef8528"
      >
    >
  >
  coders: <
    key: "nEsyGtOMlITimestampedValueCoder"
    value: <
      spec: <
        urn: "beam:coders:javasdk:0.1"
        payload: "\202SNAPPY\000\000\000\000\001\000\000\000\001\000\000\006]\313\026\270\254\355\000\005sr\000Aorg.apache.beam.sdk.values.TimestampedV\001\022\000$>\021\000HCoder\364\376\202p\274iX-\002\000\001L\000\n\005;\005\030\034t\000\"Lorg/\t]\000/\001]\024/sdk/c\0015\004s/\005$\020;xr\000*N\202\000\t%(.Structured\005/8s\277\022\016\325\3246\021\002\000\000xr\000 j9\000\005/\034C\335\325\211\256\274~\370\001/\020psr\000#j1\000\010Row\0054\034\254\236\213\244M\203\363\250\0014\010r\000'N2\000 schemas.S\005\010\0056|\023\226L\354\244P\260l\002\000\004L\000\017fromRowFunctiont\0005R\t\001Xtransforms/Serializable\0217\014;L\000\006\tk\010t\000$RA\000\t\036\004s/\t\211\024;L\000\rto\035x`q\000~\000\007L\000\016typeDescriptort\000+RM\000%\271\010s/T2-\000!\240\000&N\004\001-\240\024Custom%\003\034j\260\010\235\013;\035\013!9\001z\020\003sr\000=N;\000\031\367\000.N\367\000Ds$Identity\033n\367C9'S\320\001R!\277\000\"NN\000-\004-\215d\203\254\323C\026X\\\367\002\000\007Z\000\033encodingPosi!\211DsOverriddenI\000\010hash\001\272\010L\000\021B)\000\220t\000\017Ljava/util/Map;L\000\014fieldIndicest\000HL>\335\002 vendor/gu\0019Lv26_0_jre/com/google\001\0134mon/collect/Bi\tZ\000\006\005Z\014st\000\020\035u$List;L\000\007op\005\273\010t\000,R\267\001-\000M\004\004$O\t.\034;L\000\004uuid6S\000<UUID;xp\000\376\246N\037sr\000\021\001\342\000.\001\342\360I.HashMap\005\007\332\301\303\026`\321\003\000\002F\000\nloadFactorI\000\tthresholdxp?@\000\000\000\000\000\014w\010\000\000\000\020\000\000\000\001t\000\007role_id\025Wdlang.Integer\022\342\240\244\367\201\2078\002\000\001I\000\005Ei\014xr\000\020\005\177\005(4Number\206\254\225\035\013\224\340\213%\360\001b\020xsr\000J>\365\001)f\000.%f\000.5f\020.com.)f\001\013\014mon.-f\000.\001\334%j\001S\001\001(\003\000\000xpw\004\000\000\000\001A\251\000\027\001\005\000\032\001l\000\023\005\222%\021\020Array!\203 x\201\322\035\231\307a\235\003\001\274\024\004sizex\001I\000\001\t@\014sr\0002>\241\000\241A-\226\024.AutoV\241;\000_i\244\004_FAD\034\303\343i\345\363l$\364\205.\004\013dm\233\205*\000\022I\002!\026\030/String!\313\014name\001\246\010 L\000Q\020\001\017\014\022L\000\004a\335\010t\000.\216\034\002\005|a\340a\326\000(n\267\000\t\255\t1\034\263\021\225\3324!\217\246%\226\010t\000\000\001y\004\027sZ\267\005\021\370\rA\000OI\216\034\367\031\n\2336X\271\227\305\".\301\000\014\017xps\001P\004\025?IS\004\000wQS%\374\0006n\244\000V[\001\001\33749\304m\364S\243\227P\002\000\010L\000\025M\007$ionElement\001#\001u(!L\000\013logical\001\023\010t\0000\216E\001\000L\0312$;L\000\nmapKey\001@\rS\014\014map%\362\035\024 \010metadata\001$\034\017L\000\010null\241\353\010t\000\023=\3604Boolean;L\000\trow)C\0012\014\010L\000\010!\347\030Namet\000-\216\246\000\001}\001/!\352\000,nF\001\tf)\352\0015\034\013PLl[\357\3103%\356\001\001\014sr\000\036y\027\000C\211\272Lions$EmptyMapY6\024\205Z\334\347\265\247\211WA\302\000.\r\3224\315 r\200\325\234\372\356\002\000\001Z\000\005\211\000\030p\000p~r\000+\212\234\000\001\227\001\314a\273\001\001\000\022\345\375\000\016\005\225\005f\014Enum\001\031\001\001\001\035$pt\000\005INT64xE]\000%\005\006Zc\002\tGe\363\241\036x\274\231\003\367\230m\205/\002\000\002J\000\014leastSigBitsJ\000\013mo\025\016Dxp\226\005.\t\313_\010\035\370\017\362\331\261\226@\223\005e\014\014sr\000Ro\001\005\364\004s.\001\313\371\212(s$9z\2164\213\005/\271\347!o\010r\000)N\016\001R;\000\034x\237G[\330\210\240{eR \005tokent\000LB\032\002\251,\212\222\006\010ref\305\222\001\241\000T\001N\000;\345r\000Z>\221\000\tQ\212}\005\rQ\005\362\005Q\024$Simple\026\005\020!\255\001\001\t\372\346\346\005Bi\000\0342{#\261\276\3768|%\033\030\013runtim\005w\010t\000\030}m\r8\005\362\030;xpvr\000\036>\355\000\241\311-~(Row\032Q\006\2060\230\247\034\005X4\006schemaq\000~\000\010xp"
      >
    >
  >
  coders: <
    key: "nEsyGtOMlIVarIntCoder"
    value: <
      spec: <
        urn: "beam:coders:javasdk:0.1"
        payload: "\202SNAPPY\000\000\000\000\001\000\000\000\001\000\000\000\210\330\001\350\254\355\000\005sr\000&org.apache.beam.sdk.coders.VarIntCoder\300K2\332\251KVh\002\000\000xrr5\000\024Atomic\0055 \307\354\265\314\205tPF\002\0055\000*jj\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"
      >
    >
  >
  coders: <
    key: "nEsyGtOMlIVoidCoder"
    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:v1"
      capabilities: "beam:protocol:multi_core_bundle_processing:v1"
      capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
      capabilities: "beam:protocol:worker_status:v1"
      capabilities: "beam:protocol:monitoring_info_short_ids:v1"
      capabilities: "beam:version:sdk_base:go:apache/beam_go_sdk:2.50.0.dev"
      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"
      capabilities: "beam:coder:nullable:v1"
      capabilities: "beam:coder:timer:v1"
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        role_urn: "beam:artifact:role:go_worker_binary:v1"
      >
    >
  >
  environments: <
    key: "nEsyGtOMlIbeam:env:docker:v1"
    value: <
      urn: "beam:env:docker:v1"
      payload: "\n apache/beam_java8_sdk:2.50.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:coder:nullable: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:protocol:state_caching:v1"
      capabilities: "beam:version:sdk_base:apache/beam_java8_sdk:2.50.0.dev"
      capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
      capabilities: "beam:transform:to_string:v1"
      capabilities: "beam:protocol:data_sampling:v1"
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nL/tmp/artifacts/icedtea-sound-uoIQCGhMffp0D_gc1dkBtXBGXr18Bkb5Qx-e-CvP00s.jar\022@ba821008684c7dfa740ff81cd5d901b570465ebd7c0646f9431f9ef82bcfd34b"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n=icedtea-sound-uoIQCGhMffp0D_gc1dkBtXBGXr18Bkb5Qx-e-CvP00s.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/jaccess-T1qVdaqZDj2uNq1tdHEk1lwFMYQiwMhYa0jqGU9fUMg.jar\022@4f5a9575aa990e3dae36ad6d747124d65c05318422c0c8586b48ea194f5f50c8"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7jaccess-T1qVdaqZDj2uNq1tdHEk1lwFMYQiwMhYa0jqGU9fUMg.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nI/tmp/artifacts/localedata-dQT9YOGvbd1zEqcZsyJ1W4l8jNhxoX3b1nmMhdIbCb8.jar\022@7504fd60e1af6ddd7312a719b322755b897c8cd871a17ddbd6798c85d21b09bf"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n:localedata-dQT9YOGvbd1zEqcZsyJ1W4l8jNhxoX3b1nmMhdIbCb8.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/nashorn-gZxbPAWCb1KP7OCbxUu1prmT4YMEDX-mGdJFjkB3pfs.jar\022@819c5b3c05826f528fece09bc54bb5a6b993e183040d7fa619d2458e4077a5fb"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7nashorn-gZxbPAWCb1KP7OCbxUu1prmT4YMEDX-mGdJFjkB3pfs.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nG/tmp/artifacts/cldrdata-_GVjPlS0invvNh7wlTfv_CNVOxTj3Y-xvSW1Xw2r_-4.jar\022@fc65633e54b48a7bef361ef09537effc23553b14e3dd8fb1bd25b55f0dabffee"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n8cldrdata-_GVjPlS0invvNh7wlTfv_CNVOxTj3Y-xvSW1Xw2r_-4.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nD/tmp/artifacts/dnsns-lI-xDSEZtu3C8A4-qt_7RcyP_ql7OU0LNZreNR5piTU.jar\022@948fb10d2119b6edc2f00e3eaadffb45cc8ffea97b394d0b359ade351e698935"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n5dnsns-lI-xDSEZtu3C8A4-qt_7RcyP_ql7OU0LNZreNR5piTU.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\n\203\001/tmp/artifacts/beam-sdks-java-extensions-schemaio-expansion-service-2.50.0-SNAPSHOT-jIXX3Rozz32D18oqHlnUNYhR3H5BoqbviS0QWrzwAUs.jar\022@8c85d7dd1a33cf7d83d7ca2a1e59d4358851dc7e41a2a6ef892d105abcf0014b"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\ntbeam-sdks-java-extensions-schemaio-expansion-service-2.50.0-SNAPSHOT-jIXX3Rozz32D18oqHlnUNYhR3H5BoqbviS0QWrzwAUs.jar"
      >
    >
  >
>
root_transform_ids: "s1"
root_transform_ids: "e2"
root_transform_ids: "e3"
root_transform_ids: "s3"
2023/08/07 11:22:21 Cross-compiling <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/go/test/integration/io/xlang/jdbc/jdbc_test.go> with GOOS=linux GOARCH=amd64 CGO_ENABLED=0 as /tmp/worker-4-1691407341266853859
2023/08/07 11:22:24 Prepared job with id: go-testjdbcio_postgresreadwrite-641-cef2d267-1e93-4896-bb8b-ca9bf78ffa4a and staging token: go-testjdbcio_postgresreadwrite-641-cef2d267-1e93-4896-bb8b-ca9bf78ffa4a
2023/08/07 11:22:24 Staged binary artifact with token: 
2023/08/07 11:22:24 Submitted job: go-testjdbcio_postgresreadwrite-641-cef2d267-1e93-4896-bb8b-ca9bf78ffa4a
2023/08/07 11:22:24 2023-08-07 11:22:24. (1): ==================== <function annotate_downstream_side_inputs at 0x7f32eab15b80> ====================
2023/08/07 11:22:24 2023-08-07 11:22:24. (2): ==================== <function fix_side_input_pcoll_coders at 0x7f32eab15ca0> ====================
2023/08/07 11:22:24 2023-08-07 11:22:24. (3): ==================== <function pack_combiners at 0x7f32eaa971f0> ====================
2023/08/07 11:22:24 2023-08-07 11:22:24. (4): ==================== <function lift_combiners at 0x7f32eaa97280> ====================
2023/08/07 11:22:24 2023-08-07 11:22:24. (5): ==================== <function expand_sdf at 0x7f32eaa97430> ====================
2023/08/07 11:22:24 2023-08-07 11:22:24. (6): ==================== <function expand_gbk at 0x7f32eaa974c0> ====================
2023/08/07 11:22:24 2023-08-07 11:22:24. (7): ==================== <function sink_flattens at 0x7f32eaa975e0> ====================
2023/08/07 11:22:24 2023-08-07 11:22:24. (8): ==================== <function greedily_fuse at 0x7f32eaa97670> ====================
2023/08/07 11:22:24 Job state: STOPPED
2023/08/07 11:22:24 Job state: STARTING
2023/08/07 11:22:24 Job state: RUNNING
2023/08/07 11:22:24 2023-08-07 11:22:24. (9): ==================== <function read_to_impulse at 0x7f32eaa97700> ====================
2023/08/07 11:22:24 2023-08-07 11:22:24. (10): ==================== <function impulse_to_input at 0x7f32eaa97790> ====================
2023/08/07 11:22:24 2023-08-07 11:22:24. (11): ==================== <function sort_stages at 0x7f32eaa979d0> ====================
2023/08/07 11:22:24 2023-08-07 11:22:24. (12): ==================== <function add_impulse_to_dangling_transforms at 0x7f32eaa97af0> ====================
2023/08/07 11:22:24 2023-08-07 11:22:24. (13): ==================== <function setup_timer_mapping at 0x7f32eaa97940> ====================
2023/08/07 11:22:24 2023-08-07 11:22:24. (14): ==================== <function populate_data_channel_coders at 0x7f32eaa97a60> ====================
2023/08/07 11:22:24 2023-08-07 11:22:24. (15): starting control server on port 46509
2023/08/07 11:22:24 2023-08-07 11:22:24. (16): starting data server on port 42525
2023/08/07 11:22:24 2023-08-07 11:22:24. (17): starting state server on port 45457
2023/08/07 11:22:24 2023-08-07 11:22:24. (18): starting logging server on port 33465
2023/08/07 11:22:24 2023-08-07 11:22:24. (19): Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f32e8153c70> for environment go (beam:env:docker:v1, b'\n\x16apache/beam_go_sdk:dev')
2023/08/07 11:22:27 2023-08-07 11:22:27. (20): Attempting to pull image apache/beam_go_sdk:dev
2023/08/07 11:22:28 2023-08-07 11:22:28. (21): Unable to pull image apache/beam_go_sdk:dev, defaulting to local image if it exists
2023/08/07 11:22:29 2023-08-07 11:22:29. (22): Waiting for docker to start up. Current status is running
2023/08/07 11:22:29 2023-08-07 11:22:29. (23): Docker container is running. container_id = b'477729a1205062a457022c9d67399f39d0c105b5c36dddbae6da71e2af973875', worker_id = worker_15
2023/08/07 11:22:30 2023-08-07 11:22:30. (24): Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f332082d220> for environment nEsyGtOMlIbeam:env:docker:v1 (beam:env:docker:v1, b'\n apache/beam_java8_sdk:2.50.0.dev')
2023/08/07 11:22:33 2023-08-07 11:22:33. (25): Attempting to pull image apache/beam_java8_sdk:2.50.0.dev
2023/08/07 11:22:33 2023-08-07 11:22:33. (26): Unable to pull image apache/beam_java8_sdk:2.50.0.dev, defaulting to local image if it exists
2023/08/07 11:22:35 2023-08-07 11:22:35. (27): Waiting for docker to start up. Current status is running
2023/08/07 11:22:35 2023-08-07 11:22:35. (28): Docker container is running. container_id = b'236b9c11baaa2401fab41d93d0e43512f61728b05891b3be0bcde932c68ea9e3', worker_id = worker_17
2023/08/07 11:22:41 2023-08-07 11:22:41. (29): Completed job in 16.44404673576355 seconds with state DONE.
2023/08/07 11:22:41 Job state: DONE
2023/08/07 11:22:41 🐳 Terminating container: 0583673d6473
2023/08/07 11:22:41 🚫 Container terminated: 0583673d6473
--- PASS: TestJDBCIO_PostgresReadWrite (47.28s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	119.229s
2023/08/07 11:21:33 StructWrapper for beam.createFn already registered. Overwriting.
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:352: 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	6.039s

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerJavaUsingPython
INFO:root:No image given, using default Python SDK image
INFO:root:Python SDK container image set to "apache/beam_python3.8_sdk:2.49.0" for Docker environment
INFO:__main__:Listening for expansion requests at 43883
INFO:root:Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
INFO:__main__:Shutting down expansion service.
INFO:apache_beam.runners.portability.stager:Executing command: ['/home/jenkins/.apache_beam/cache/venvs/py-3.8-beam-2.49.0-743bdccef67087512a7a190820e727aab7bdcb14/bin/python', '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', '/tmp/tmpdwcq6css/tmp_requirements.txt', '--exists-action', 'i', '--no-deps', '--implementation', 'cp', '--abi', 'cp38', '--platform', 'manylinux2014_x86_64']
INFO:root:No image given, using default Python SDK image
INFO:root:Python SDK container image set to "apache/beam_python3.8_sdk:2.49.0" for Docker environment
INFO:__main__:Listening for expansion requests at 34083
INFO:root:Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
INFO:__main__:Shutting down expansion service.

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

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.

* 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.6.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 32m 27s
258 actionable tasks: 167 executed, 79 from cache, 12 up-to-date

Publishing build scan...
https://ge.apache.org/s/ngiooypfldurc

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

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

Changes:


------------------------------------------
[...truncated 1.36 MB...]
      spec: <
        urn: "beam:coders:javasdk:0.1"
        payload: "\202SNAPPY\000\000\000\000\001\000\000\000\001\000\000\000\210\330\001\350\254\355\000\005sr\000&org.apache.beam.sdk.coders.VarIntCoder\300K2\332\251KVh\002\000\000xrr5\000\024Atomic\0055 \307\354\265\314\205tPF\002\0055\000*jj\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"
      >
    >
  >
  coders: <
    key: "ILRLzxwwWHVoidCoder"
    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"
      >
    >
  >
  coders: <
    key: "c0"
    value: <
      spec: <
        urn: "beam:coder:bytes:v1"
      >
    >
  >
  coders: <
    key: "c1"
    value: <
      spec: <
        urn: "beam:coder:global_window:v1"
      >
    >
  >
  coders: <
    key: "c2"
    value: <
      spec: <
        urn: "beam:coder:row:v1"
        payload: "\n\r\n\007role_id\032\002\020\003\022$abc5e222-ab8f-4f6f-800a-a58bb0f45675"
      >
    >
  >
  environments: <
    key: "ILRLzxwwWHbeam:env:docker:v1"
    value: <
      urn: "beam:env:docker:v1"
      payload: "\n apache/beam_java8_sdk:2.50.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:coder:nullable: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:protocol:state_caching:v1"
      capabilities: "beam:version:sdk_base:apache/beam_java8_sdk:2.50.0.dev"
      capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
      capabilities: "beam:transform:to_string:v1"
      capabilities: "beam:protocol:data_sampling:v1"
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nL/tmp/artifacts/icedtea-sound-uoIQCGhMffp0D_gc1dkBtXBGXr18Bkb5Qx-e-CvP00s.jar\022@ba821008684c7dfa740ff81cd5d901b570465ebd7c0646f9431f9ef82bcfd34b"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n=icedtea-sound-uoIQCGhMffp0D_gc1dkBtXBGXr18Bkb5Qx-e-CvP00s.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/jaccess-T1qVdaqZDj2uNq1tdHEk1lwFMYQiwMhYa0jqGU9fUMg.jar\022@4f5a9575aa990e3dae36ad6d747124d65c05318422c0c8586b48ea194f5f50c8"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7jaccess-T1qVdaqZDj2uNq1tdHEk1lwFMYQiwMhYa0jqGU9fUMg.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nI/tmp/artifacts/localedata-dQT9YOGvbd1zEqcZsyJ1W4l8jNhxoX3b1nmMhdIbCb8.jar\022@7504fd60e1af6ddd7312a719b322755b897c8cd871a17ddbd6798c85d21b09bf"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n:localedata-dQT9YOGvbd1zEqcZsyJ1W4l8jNhxoX3b1nmMhdIbCb8.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/nashorn-gZxbPAWCb1KP7OCbxUu1prmT4YMEDX-mGdJFjkB3pfs.jar\022@819c5b3c05826f528fece09bc54bb5a6b993e183040d7fa619d2458e4077a5fb"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7nashorn-gZxbPAWCb1KP7OCbxUu1prmT4YMEDX-mGdJFjkB3pfs.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nG/tmp/artifacts/cldrdata-_GVjPlS0invvNh7wlTfv_CNVOxTj3Y-xvSW1Xw2r_-4.jar\022@fc65633e54b48a7bef361ef09537effc23553b14e3dd8fb1bd25b55f0dabffee"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n8cldrdata-_GVjPlS0invvNh7wlTfv_CNVOxTj3Y-xvSW1Xw2r_-4.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nD/tmp/artifacts/dnsns-lI-xDSEZtu3C8A4-qt_7RcyP_ql7OU0LNZreNR5piTU.jar\022@948fb10d2119b6edc2f00e3eaadffb45cc8ffea97b394d0b359ade351e698935"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n5dnsns-lI-xDSEZtu3C8A4-qt_7RcyP_ql7OU0LNZreNR5piTU.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\n\203\001/tmp/artifacts/beam-sdks-java-extensions-schemaio-expansion-service-2.50.0-SNAPSHOT-jIXX3Rozz32D18oqHlnUNYhR3H5BoqbviS0QWrzwAUs.jar\022@8c85d7dd1a33cf7d83d7ca2a1e59d4358851dc7e41a2a6ef892d105abcf0014b"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\ntbeam-sdks-java-extensions-schemaio-expansion-service-2.50.0-SNAPSHOT-jIXX3Rozz32D18oqHlnUNYhR3H5BoqbviS0QWrzwAUs.jar"
      >
    >
  >
  environments: <
    key: "go"
    value: <
      urn: "beam:env:docker:v1"
      payload: "\n\026apache/beam_go_sdk:dev"
      capabilities: "beam:protocol:progress_reporting:v1"
      capabilities: "beam:protocol:multi_core_bundle_processing:v1"
      capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
      capabilities: "beam:protocol:worker_status:v1"
      capabilities: "beam:protocol:monitoring_info_short_ids:v1"
      capabilities: "beam:version:sdk_base:go:apache/beam_go_sdk:2.50.0.dev"
      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"
      capabilities: "beam:coder:nullable:v1"
      capabilities: "beam:coder:timer:v1"
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        role_urn: "beam:artifact:role:go_worker_binary:v1"
      >
    >
  >
>
root_transform_ids: "s1"
root_transform_ids: "e2"
root_transform_ids: "e3"
root_transform_ids: "s3"
2023/08/07 05:25:03 Cross-compiling <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/go/test/integration/io/xlang/jdbc/jdbc_test.go> with GOOS=linux GOARCH=amd64 CGO_ENABLED=0 as /tmp/worker-4-1691385903688451559
2023/08/07 05:25:06 Prepared job with id: go-testjdbcio_postgresreadwrite-119-de900e76-4766-40f4-bc0b-18b095656a02 and staging token: go-testjdbcio_postgresreadwrite-119-de900e76-4766-40f4-bc0b-18b095656a02
2023/08/07 05:25:07 Staged binary artifact with token: 
2023/08/07 05:25:07 Submitted job: go-testjdbcio_postgresreadwrite-119-de900e76-4766-40f4-bc0b-18b095656a02
2023/08/07 05:25:07 Job state: STOPPED
2023/08/07 05:25:07 Job state: STARTING
2023/08/07 05:25:07 Job state: RUNNING
2023/08/07 05:25:07 2023-08-07 05:25:07. (1): ==================== <function annotate_downstream_side_inputs at 0x7f3608d35b80> ====================
2023/08/07 05:25:07 2023-08-07 05:25:07. (2): ==================== <function fix_side_input_pcoll_coders at 0x7f3608d35ca0> ====================
2023/08/07 05:25:07 2023-08-07 05:25:07. (3): ==================== <function pack_combiners at 0x7f3608cb71f0> ====================
2023/08/07 05:25:07 2023-08-07 05:25:07. (4): ==================== <function lift_combiners at 0x7f3608cb7280> ====================
2023/08/07 05:25:07 2023-08-07 05:25:07. (5): ==================== <function expand_sdf at 0x7f3608cb7430> ====================
2023/08/07 05:25:07 2023-08-07 05:25:07. (6): ==================== <function expand_gbk at 0x7f3608cb74c0> ====================
2023/08/07 05:25:07 2023-08-07 05:25:07. (7): ==================== <function sink_flattens at 0x7f3608cb75e0> ====================
2023/08/07 05:25:07 2023-08-07 05:25:07. (8): ==================== <function greedily_fuse at 0x7f3608cb7670> ====================
2023/08/07 05:25:07 2023-08-07 05:25:07. (9): ==================== <function read_to_impulse at 0x7f3608cb7700> ====================
2023/08/07 05:25:07 2023-08-07 05:25:07. (10): ==================== <function impulse_to_input at 0x7f3608cb7790> ====================
2023/08/07 05:25:07 2023-08-07 05:25:07. (11): ==================== <function sort_stages at 0x7f3608cb79d0> ====================
2023/08/07 05:25:07 2023-08-07 05:25:07. (12): ==================== <function add_impulse_to_dangling_transforms at 0x7f3608cb7af0> ====================
2023/08/07 05:25:07 2023-08-07 05:25:07. (13): ==================== <function setup_timer_mapping at 0x7f3608cb7940> ====================
2023/08/07 05:25:07 2023-08-07 05:25:07. (14): ==================== <function populate_data_channel_coders at 0x7f3608cb7a60> ====================
2023/08/07 05:25:07 2023-08-07 05:25:07. (15): starting control server on port 39519
2023/08/07 05:25:07 2023-08-07 05:25:07. (16): starting data server on port 45695
2023/08/07 05:25:07 2023-08-07 05:25:07. (17): starting state server on port 44279
2023/08/07 05:25:07 2023-08-07 05:25:07. (18): starting logging server on port 34567
2023/08/07 05:25:07 2023-08-07 05:25:07. (19): Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f3608c20280> for environment ILRLzxwwWHbeam:env:docker:v1 (beam:env:docker:v1, b'\n apache/beam_java8_sdk:2.50.0.dev')
2023/08/07 05:25:10 2023-08-07 05:25:10. (20): Attempting to pull image apache/beam_java8_sdk:2.50.0.dev
2023/08/07 05:25:11 2023-08-07 05:25:11. (21): Unable to pull image apache/beam_java8_sdk:2.50.0.dev, defaulting to local image if it exists
2023/08/07 05:25:12 2023-08-07 05:25:12. (22): Waiting for docker to start up. Current status is running
2023/08/07 05:25:12 2023-08-07 05:25:12. (23): Docker container is running. container_id = b'5dff6c6732f5f226092ec781edf8a9aeac136f541d592fd34848ae4d2c3a6940', worker_id = worker_15
2023/08/07 05:25:13 2023-08-07 05:25:13. (24): Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f363eaa1880> for environment go (beam:env:docker:v1, b'\n\x16apache/beam_go_sdk:dev')
2023/08/07 05:25:15 2023-08-07 05:25:15. (25): Attempting to pull image apache/beam_go_sdk:dev
2023/08/07 05:25:15 2023-08-07 05:25:15. (26): Unable to pull image apache/beam_go_sdk:dev, defaulting to local image if it exists
2023/08/07 05:25:17 2023-08-07 05:25:17. (27): Waiting for docker to start up. Current status is running
2023/08/07 05:25:17 2023-08-07 05:25:17. (28): Docker container is running. container_id = b'b34841351839abcdf6f8a82ec4aae3b6ff5cc579f8b6c25d7ee2068078f44d1a', worker_id = worker_17
2023/08/07 05:25:20 2023-08-07 05:25:20. (29): Completed job in 13.811839818954468 seconds with state DONE.
2023/08/07 05:25:20 Job state: DONE
2023/08/07 05:25:20 🐳 Terminating container: 0c2cb20d3601
2023/08/07 05:25:21 🚫 Container terminated: 0c2cb20d3601
--- PASS: TestJDBCIO_PostgresReadWrite (39.13s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	91.803s
2023/08/07 05:24:21 StructWrapper for beam.createFn already registered. Overwriting.
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:352: 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	6.033s

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerJavaUsingPython
INFO:root:No image given, using default Python SDK image
INFO:root:Python SDK container image set to "apache/beam_python3.8_sdk:2.49.0" for Docker environment
INFO:__main__:Listening for expansion requests at 37683
INFO:root:Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
INFO:__main__:Shutting down expansion service.
INFO:apache_beam.runners.portability.stager:Executing command: ['/home/jenkins/.apache_beam/cache/venvs/py-3.8-beam-2.49.0-743bdccef67087512a7a190820e727aab7bdcb14/bin/python', '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', '/tmp/tmppqp1zr6r/tmp_requirements.txt', '--exists-action', 'i', '--no-deps', '--implementation', 'cp', '--abi', 'cp38', '--platform', 'manylinux2014_x86_64']
INFO:root:No image given, using default Python SDK image
INFO:root:Python SDK container image set to "apache/beam_python3.8_sdk:2.49.0" for Docker environment
INFO:__main__:Listening for expansion requests at 43885
INFO:root:Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
INFO:__main__:Shutting down expansion service.

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

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.

* 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.6.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 56s
258 actionable tasks: 167 executed, 79 from cache, 12 up-to-date

Publishing build scan...
https://ge.apache.org/s/drrlajwf5fzkm

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

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

Changes:


------------------------------------------
[...truncated 1.47 MB...]
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:165: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/pvalue.py:137: in __or__
    return self.pipeline.apply(ptransform, self)
apache_beam/pipeline.py:712: 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:678: in expand
    with ExternalTransform.service(expansion_service) as service:
/usr/lib/python3.8/contextlib.py:113: in __enter__
    return next(self.gen)
apache_beam/transforms/external.py:733: in service
    with expansion_service as stub:
apache_beam/transforms/external.py:944: 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 0x7f6df969e3a0>

    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:88: RuntimeError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:239 Using pre-built snapshot at <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.50.0-SNAPSHOT.jar>
INFO     root:external.py:929 Starting a JAR-based expansion service from 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.50.0-SNAPSHOT.jar> 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:116 Starting 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.50.0-SNAPSHOT.jar'> '57885' '--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.50.0-SNAPSHOT.jar']>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 Error: Invalid or corrupt jarfile <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.50.0-SNAPSHOT.jar>
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.50.0-SNAPSHOT.jar',> '57885', '--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.50.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 88, in start
    raise RuntimeError(
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:154: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/transforms/ptransform.py:614: in __ror__
    result = p.apply(self, pvalueish, label)
apache_beam/pipeline.py:712: 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:678: in expand
    with ExternalTransform.service(expansion_service) as service:
/usr/lib/python3.8/contextlib.py:113: in __enter__
    return next(self.gen)
apache_beam/transforms/external.py:733: in service
    with expansion_service as stub:
apache_beam/transforms/external.py:944: 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 0x7f6df9597850>

    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:88: RuntimeError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:239 Using pre-built snapshot at <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.50.0-SNAPSHOT.jar>
INFO     root:external.py:929 Starting a JAR-based expansion service from 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.50.0-SNAPSHOT.jar> 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:116 Starting 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.50.0-SNAPSHOT.jar'> '32933' '--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.50.0-SNAPSHOT.jar']>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 Error: Invalid or corrupt jarfile <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.50.0-SNAPSHOT.jar>
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.50.0-SNAPSHOT.jar',> '32933', '--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.50.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 88, in start
    raise RuntimeError(
RuntimeError: Service failed to start up with error 1
=============================== warnings summary ===============================
../../build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

../../build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py:18
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py>:18: DeprecationWarning: pkg_resources is deprecated as an API. See https://setuptools.pypa.io/en/latest/pkg_resources.html
    import pkg_resources

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871: 20 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871: 16 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.cloud')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2350: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(parent)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.logging')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.iam')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py:20
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py>:20: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.rpc')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    pkg_resources.declare_namespace(__name__)

apache_beam/typehints/pandas_type_compatibility_test.py:67
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:67: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    }).set_index(pd.Int64Index(range(123, 223), name='an_index')),

apache_beam/typehints/pandas_type_compatibility_test.py:90
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:90: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    pd.Int64Index(range(123, 223), name='an_index'),

apache_beam/typehints/pandas_type_compatibility_test.py:91
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:91: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    pd.Int64Index(range(475, 575), name='another_index'),

apache_beam/transforms/sql_test.py::SqlTransformTest::test_agg
apache_beam/transforms/sql_test.py::SqlTransformTest::test_filter
apache_beam/transforms/sql_test.py::SqlTransformTest::test_generate_data
apache_beam/transforms/sql_test.py::SqlTransformTest::test_map
apache_beam/transforms/sql_test.py::SqlTransformTest::test_project
apache_beam/transforms/sql_test.py::SqlTransformTest::test_row
apache_beam/transforms/sql_test.py::SqlTransformTest::test_tagged_join
apache_beam/transforms/sql_test.py::SqlTransformTest::test_windowing_before_sql
apache_beam/transforms/sql_test.py::SqlTransformTest::test_zetasql_generate_data
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/transforms/external.py>:676: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    self._expansion_service, pipeline.options)

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/pytest_xlangSqlValidateRunner.xml> -
=========================== short test summary info ============================
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_agg - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_filter - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_generate_data - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_map - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_project - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_row - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_tagged_join - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_windowing_before_sql - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_zetasql_generate_data - RuntimeError: Service failed to start up with error 1
========= 9 failed, 14 skipped, 6945 deselected, 57 warnings in 17.34s =========

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

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

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

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.

* 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.6.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 28m 29s
258 actionable tasks: 167 executed, 79 from cache, 12 up-to-date

Publishing build scan...
https://ge.apache.org/s/fst6jgjcfzp6i

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

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

Changes:


------------------------------------------
[...truncated 1.46 MB...]
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:165: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/pvalue.py:137: in __or__
    return self.pipeline.apply(ptransform, self)
apache_beam/pipeline.py:712: 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:678: in expand
    with ExternalTransform.service(expansion_service) as service:
/usr/lib/python3.8/contextlib.py:113: in __enter__
    return next(self.gen)
apache_beam/transforms/external.py:733: in service
    with expansion_service as stub:
apache_beam/transforms/external.py:944: 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 0x7f0ca556a310>

    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:88: RuntimeError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:239 Using pre-built snapshot at <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.50.0-SNAPSHOT.jar>
INFO     root:external.py:929 Starting a JAR-based expansion service from 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.50.0-SNAPSHOT.jar> 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:116 Starting 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.50.0-SNAPSHOT.jar'> '50755' '--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.50.0-SNAPSHOT.jar']>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 Error: Invalid or corrupt jarfile <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.50.0-SNAPSHOT.jar>
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.50.0-SNAPSHOT.jar',> '50755', '--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.50.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 88, in start
    raise RuntimeError(
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:154: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/transforms/ptransform.py:614: in __ror__
    result = p.apply(self, pvalueish, label)
apache_beam/pipeline.py:712: 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:678: in expand
    with ExternalTransform.service(expansion_service) as service:
/usr/lib/python3.8/contextlib.py:113: in __enter__
    return next(self.gen)
apache_beam/transforms/external.py:733: in service
    with expansion_service as stub:
apache_beam/transforms/external.py:944: 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 0x7f0ca4fed130>

    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:88: RuntimeError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:239 Using pre-built snapshot at <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.50.0-SNAPSHOT.jar>
INFO     root:external.py:929 Starting a JAR-based expansion service from 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.50.0-SNAPSHOT.jar> 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:116 Starting 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.50.0-SNAPSHOT.jar'> '52737' '--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.50.0-SNAPSHOT.jar']>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 Error: Invalid or corrupt jarfile <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.50.0-SNAPSHOT.jar>
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.50.0-SNAPSHOT.jar',> '52737', '--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.50.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 88, in start
    raise RuntimeError(
RuntimeError: Service failed to start up with error 1
=============================== warnings summary ===============================
../../build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

../../build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py:18
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py>:18: DeprecationWarning: pkg_resources is deprecated as an API. See https://setuptools.pypa.io/en/latest/pkg_resources.html
    import pkg_resources

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871: 20 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871: 16 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.cloud')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2350: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(parent)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.logging')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.iam')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py:20
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py>:20: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.rpc')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    pkg_resources.declare_namespace(__name__)

apache_beam/typehints/pandas_type_compatibility_test.py:67
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:67: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    }).set_index(pd.Int64Index(range(123, 223), name='an_index')),

apache_beam/typehints/pandas_type_compatibility_test.py:90
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:90: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    pd.Int64Index(range(123, 223), name='an_index'),

apache_beam/typehints/pandas_type_compatibility_test.py:91
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:91: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    pd.Int64Index(range(475, 575), name='another_index'),

apache_beam/transforms/sql_test.py::SqlTransformTest::test_agg
apache_beam/transforms/sql_test.py::SqlTransformTest::test_filter
apache_beam/transforms/sql_test.py::SqlTransformTest::test_generate_data
apache_beam/transforms/sql_test.py::SqlTransformTest::test_map
apache_beam/transforms/sql_test.py::SqlTransformTest::test_project
apache_beam/transforms/sql_test.py::SqlTransformTest::test_row
apache_beam/transforms/sql_test.py::SqlTransformTest::test_tagged_join
apache_beam/transforms/sql_test.py::SqlTransformTest::test_windowing_before_sql
apache_beam/transforms/sql_test.py::SqlTransformTest::test_zetasql_generate_data
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/transforms/external.py>:676: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    self._expansion_service, pipeline.options)

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/pytest_xlangSqlValidateRunner.xml> -
=========================== short test summary info ============================
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_agg - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_filter - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_generate_data - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_map - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_project - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_row - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_tagged_join - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_windowing_before_sql - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_zetasql_generate_data - RuntimeError: Service failed to start up with error 1
========= 9 failed, 14 skipped, 6945 deselected, 57 warnings in 9.64s ==========

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

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

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

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.

* 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.6.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 24m 58s
258 actionable tasks: 167 executed, 79 from cache, 12 up-to-date

Publishing build scan...
https://ge.apache.org/s/fvam4vjmgo5rg

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

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

Changes:


------------------------------------------
[...truncated 1.31 MB...]
      component_coder_ids: "pCoAfdQWDoVarIntCoder"
      component_coder_ids: "pCoAfdQWDoIterableCoder"
    >
  >
  coders: <
    key: "pCoAfdQWDoRowCoder"
    value: <
      spec: <
        urn: "beam:coder:row:v1"
        payload: "\n\r\n\007role_id\032\002\020\004\022$1f56b17d-e67f-4011-8844-e1f31696f45c"
      >
    >
  >
  coders: <
    key: "pCoAfdQWDoTimestampedValueCoder"
    value: <
      spec: <
        urn: "beam:coders:javasdk:0.1"
        payload: "\202SNAPPY\000\000\000\000\001\000\000\000\001\000\000\006]\313\026\270\254\355\000\005sr\000Aorg.apache.beam.sdk.values.TimestampedV\001\022\000$>\021\000HCoder\364\376\202p\274iX-\002\000\001L\000\n\005;\005\030\034t\000\"Lorg/\t]\000/\001]\024/sdk/c\0015\004s/\005$\020;xr\000*N\202\000\t%(.Structured\005/8s\277\022\016\325\3246\021\002\000\000xr\000 j9\000\005/\034C\335\325\211\256\274~\370\001/\020psr\000#j1\000\010Row\0054\034\254\236\213\244M\203\363\250\0014\010r\000'N2\000 schemas.S\005\010\0056|\023\226L\354\244P\260l\002\000\004L\000\017fromRowFunctiont\0005R\t\001Xtransforms/Serializable\0217\014;L\000\006\tk\010t\000$RA\000\t\036\004s/\t\211\024;L\000\rto\035x`q\000~\000\007L\000\016typeDescriptort\000+RM\000%\271\010s/T2-\000!\240\000&N\004\001-\240\024Custom%\003\034j\260\010\235\013;\035\013!9\001z\020\003sr\000=N;\000\031\367\000.N\367\000Ds$Identity\033n\367C9'S\320\001R!\277\000\"NN\000-\004-\215d\203\254\323C\026X\\\367\002\000\007Z\000\033encodingPosi!\211DsOverriddenI\000\010hash\001\272\010L\000\021B)\000\220t\000\017Ljava/util/Map;L\000\014fieldIndicest\000HL>\335\002 vendor/gu\0019Lv26_0_jre/com/google\001\0134mon/collect/Bi\tZ\000\006\005Z\014st\000\020\035u$List;L\000\007op\005\273\010t\000,R\267\001-\000M\004\004$O\t.\034;L\000\004uuid6S\000<UUID;xp\000\026\2012\033sr\000\021\001\342\000.\001\342\360I.HashMap\005\007\332\301\303\026`\321\003\000\002F\000\nloadFactorI\000\tthresholdxp?@\000\000\000\000\000\014w\010\000\000\000\020\000\000\000\001t\000\007role_id\025Wdlang.Integer\022\342\240\244\367\201\2078\002\000\001I\000\005Ei\014xr\000\020\005\177\005(4Number\206\254\225\035\013\224\340\213%\360\001b\020xsr\000J>\365\001)f\000.%f\000.5f\020.com.)f\001\013\014mon.-f\000.\001\334%j\001S\001\001(\003\000\000xpw\004\000\000\000\001A\251\000\027\001\005\000\032\001l\000\023\005\222%\021\020Array!\203 x\201\322\035\231\307a\235\003\001\274\024\004sizex\001I\000\001\t@\014sr\0002>\241\000\241A-\226\024.AutoV\241;\000_i\244\004_FAD\034\303\343i\345\363l$\364\205.\004\013dm\233\205*\000\022I\002!\026\030/String!\313\014name\001\246\010 L\000Q\020\001\017\014\022L\000\004a\335\010t\000.\216\034\002\005|a\340a\326\000(n\267\000\t\255\t1\034\263\021\225\3324!\217\246%\226\010t\000\000\001y\004\027sZ\267\005\021\370\rA\000OI\216\034\367\031\n\2336X\271\227\305\".\301\000\014\017xps\001P\004\025?IS\004\000wQS%\374\0006n\244\000V[\001\001\33749\304m\364S\243\227P\002\000\010L\000\025M\007$ionElement\001#\001u(!L\000\013logical\001\023\010t\0000\216E\001\000L\0312$;L\000\nmapKey\001@\rS\014\014map%\362\035\024 \010metadata\001$\034\017L\000\010null\241\353\010t\000\023=\3604Boolean;L\000\trow)C\0012\014\010L\000\010!\347\030Namet\000-\216\246\000\001}\001/!\352\000,nF\001\tf)\352\0015\034\013PLl[\357\3103%\356\001\001\014sr\000\036y\027\000C\211\272Lions$EmptyMapY6\024\205Z\334\347\265\247\211WA\302\000.\r\3224\315 r\200\325\234\372\356\002\000\001Z\000\005\211\000\030p\000p~r\000+\212\234\000\001\227\001\314a\273\001\001\000\022\345\375\000\016\005\225\005f\014Enum\001\031\001\001\001\035$pt\000\005INT64xE]\000%\005\006Zc\002\tGe\363\241\036x\274\231\003\367\230m\205/\002\000\002J\000\014leastSigBitsJ\000\013mo\025\016Dxp\273\321\371\354\246\3324bI\367\272\215\343\337B\035\005e\014\014sr\000Ro\001\005\364\004s.\001\313\371\212(s$9z\2164\213\005/\271\347!o\010r\000)N\016\001R;\000\034x\237G[\330\210\240{eR \005tokent\000LB\032\002\251,\212\222\006\010ref\305\222\001\241\000T\001N\000;\345r\000Z>\221\000\tQ\212}\005\rQ\005\362\005Q\024$Simple\026\005\020!\255\001\001\t\372\346\346\005Bi\000\0342{#\261\276\3768|%\033\030\013runtim\005w\010t\000\030}m\r8\005\362\030;xpvr\000\036>\355\000\241\311-~(Row\032Q\006\2060\230\247\034\005X4\006schemaq\000~\000\010xp"
      >
    >
  >
  coders: <
    key: "pCoAfdQWDoVarIntCoder"
    value: <
      spec: <
        urn: "beam:coders:javasdk:0.1"
        payload: "\202SNAPPY\000\000\000\000\001\000\000\000\001\000\000\000\210\330\001\350\254\355\000\005sr\000&org.apache.beam.sdk.coders.VarIntCoder\300K2\332\251KVh\002\000\000xrr5\000\024Atomic\0055 \307\354\265\314\205tPF\002\0055\000*jj\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"
      >
    >
  >
  coders: <
    key: "pCoAfdQWDoVoidCoder"
    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:v1"
      capabilities: "beam:protocol:multi_core_bundle_processing:v1"
      capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
      capabilities: "beam:protocol:worker_status:v1"
      capabilities: "beam:protocol:monitoring_info_short_ids:v1"
      capabilities: "beam:version:sdk_base:go:apache/beam_go_sdk:2.50.0.dev"
      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"
      capabilities: "beam:coder:nullable:v1"
      capabilities: "beam:coder:timer:v1"
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        role_urn: "beam:artifact:role:go_worker_binary:v1"
      >
    >
  >
  environments: <
    key: "pCoAfdQWDobeam:env:docker:v1"
    value: <
      urn: "beam:env:docker:v1"
      payload: "\n apache/beam_java8_sdk:2.50.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:coder:nullable: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:protocol:state_caching:v1"
      capabilities: "beam:version:sdk_base:apache/beam_java8_sdk:2.50.0.dev"
      capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
      capabilities: "beam:transform:to_string:v1"
      capabilities: "beam:protocol:data_sampling:v1"
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nL/tmp/artifacts/icedtea-sound-uoIQCGhMffp0D_gc1dkBtXBGXr18Bkb5Qx-e-CvP00s.jar\022@ba821008684c7dfa740ff81cd5d901b570465ebd7c0646f9431f9ef82bcfd34b"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n=icedtea-sound-uoIQCGhMffp0D_gc1dkBtXBGXr18Bkb5Qx-e-CvP00s.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/jaccess-T1qVdaqZDj2uNq1tdHEk1lwFMYQiwMhYa0jqGU9fUMg.jar\022@4f5a9575aa990e3dae36ad6d747124d65c05318422c0c8586b48ea194f5f50c8"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7jaccess-T1qVdaqZDj2uNq1tdHEk1lwFMYQiwMhYa0jqGU9fUMg.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nI/tmp/artifacts/localedata-dQT9YOGvbd1zEqcZsyJ1W4l8jNhxoX3b1nmMhdIbCb8.jar\022@7504fd60e1af6ddd7312a719b322755b897c8cd871a17ddbd6798c85d21b09bf"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n:localedata-dQT9YOGvbd1zEqcZsyJ1W4l8jNhxoX3b1nmMhdIbCb8.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/nashorn-gZxbPAWCb1KP7OCbxUu1prmT4YMEDX-mGdJFjkB3pfs.jar\022@819c5b3c05826f528fece09bc54bb5a6b993e183040d7fa619d2458e4077a5fb"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7nashorn-gZxbPAWCb1KP7OCbxUu1prmT4YMEDX-mGdJFjkB3pfs.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nG/tmp/artifacts/cldrdata-_GVjPlS0invvNh7wlTfv_CNVOxTj3Y-xvSW1Xw2r_-4.jar\022@fc65633e54b48a7bef361ef09537effc23553b14e3dd8fb1bd25b55f0dabffee"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n8cldrdata-_GVjPlS0invvNh7wlTfv_CNVOxTj3Y-xvSW1Xw2r_-4.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nD/tmp/artifacts/dnsns-lI-xDSEZtu3C8A4-qt_7RcyP_ql7OU0LNZreNR5piTU.jar\022@948fb10d2119b6edc2f00e3eaadffb45cc8ffea97b394d0b359ade351e698935"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n5dnsns-lI-xDSEZtu3C8A4-qt_7RcyP_ql7OU0LNZreNR5piTU.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\n\203\001/tmp/artifacts/beam-sdks-java-extensions-schemaio-expansion-service-2.50.0-SNAPSHOT-jIXX3Rozz32D18oqHlnUNYhR3H5BoqbviS0QWrzwAUs.jar\022@8c85d7dd1a33cf7d83d7ca2a1e59d4358851dc7e41a2a6ef892d105abcf0014b"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\ntbeam-sdks-java-extensions-schemaio-expansion-service-2.50.0-SNAPSHOT-jIXX3Rozz32D18oqHlnUNYhR3H5BoqbviS0QWrzwAUs.jar"
      >
    >
  >
>
root_transform_ids: "e2"
root_transform_ids: "e3"
root_transform_ids: "s1"
root_transform_ids: "s3"
2023/08/06 11:22:03 Cross-compiling <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/go/test/integration/io/xlang/jdbc/jdbc_test.go> with GOOS=linux GOARCH=amd64 CGO_ENABLED=0 as /tmp/worker-4-1691320923871527976
2023/08/06 11:22:06 Prepared job with id: go-testjdbcio_postgresreadwrite-830-503f212d-eee1-47c5-b7b0-5e9fc879a07a and staging token: go-testjdbcio_postgresreadwrite-830-503f212d-eee1-47c5-b7b0-5e9fc879a07a
2023/08/06 11:22:07 Staged binary artifact with token: 
2023/08/06 11:22:07 Submitted job: go-testjdbcio_postgresreadwrite-830-503f212d-eee1-47c5-b7b0-5e9fc879a07a
2023/08/06 11:22:07 Job state: STOPPED
2023/08/06 11:22:07 Job state: STARTING
2023/08/06 11:22:07 Job state: RUNNING
2023/08/06 11:22:07 2023-08-06 11:22:07. (1): ==================== <function annotate_downstream_side_inputs at 0x7f79964b3b80> ====================
2023/08/06 11:22:07 2023-08-06 11:22:07. (2): ==================== <function fix_side_input_pcoll_coders at 0x7f79964b3ca0> ====================
2023/08/06 11:22:07 2023-08-06 11:22:07. (3): ==================== <function pack_combiners at 0x7f79964351f0> ====================
2023/08/06 11:22:07 2023-08-06 11:22:07. (4): ==================== <function lift_combiners at 0x7f7996435280> ====================
2023/08/06 11:22:07 2023-08-06 11:22:07. (5): ==================== <function expand_sdf at 0x7f7996435430> ====================
2023/08/06 11:22:07 2023-08-06 11:22:07. (6): ==================== <function expand_gbk at 0x7f79964354c0> ====================
2023/08/06 11:22:07 2023-08-06 11:22:07. (7): ==================== <function sink_flattens at 0x7f79964355e0> ====================
2023/08/06 11:22:07 2023-08-06 11:22:07. (8): ==================== <function greedily_fuse at 0x7f7996435670> ====================
2023/08/06 11:22:07 2023-08-06 11:22:07. (9): ==================== <function read_to_impulse at 0x7f7996435700> ====================
2023/08/06 11:22:07 2023-08-06 11:22:07. (10): ==================== <function impulse_to_input at 0x7f7996435790> ====================
2023/08/06 11:22:07 2023-08-06 11:22:07. (11): ==================== <function sort_stages at 0x7f79964359d0> ====================
2023/08/06 11:22:07 2023-08-06 11:22:07. (12): ==================== <function add_impulse_to_dangling_transforms at 0x7f7996435af0> ====================
2023/08/06 11:22:07 2023-08-06 11:22:07. (13): ==================== <function setup_timer_mapping at 0x7f7996435940> ====================
2023/08/06 11:22:07 2023-08-06 11:22:07. (14): ==================== <function populate_data_channel_coders at 0x7f7996435a60> ====================
2023/08/06 11:22:07 2023-08-06 11:22:07. (15): starting control server on port 45635
2023/08/06 11:22:07 2023-08-06 11:22:07. (16): starting data server on port 44059
2023/08/06 11:22:07 2023-08-06 11:22:07. (17): starting state server on port 38079
2023/08/06 11:22:07 2023-08-06 11:22:07. (18): starting logging server on port 33959
2023/08/06 11:22:07 2023-08-06 11:22:07. (19): Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f79cb9ce3d0> for environment pCoAfdQWDobeam:env:docker:v1 (beam:env:docker:v1, b'\n apache/beam_java8_sdk:2.50.0.dev')
2023/08/06 11:22:07 2023-08-06 11:22:07. (20): Attempting to pull image apache/beam_java8_sdk:2.50.0.dev
2023/08/06 11:22:07 2023-08-06 11:22:07. (21): Unable to pull image apache/beam_java8_sdk:2.50.0.dev, defaulting to local image if it exists
2023/08/06 11:22:10 2023-08-06 11:22:10. (22): Waiting for docker to start up. Current status is running
2023/08/06 11:22:10 2023-08-06 11:22:10. (23): Docker container is running. container_id = b'126d5f6525201350022421cea5de1f00bc4e8c86ab2f81591a5128d4e7fe4e9a', worker_id = worker_15
2023/08/06 11:22:11 2023-08-06 11:22:11. (24): Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f79cb5f6550> for environment go (beam:env:docker:v1, b'\n\x16apache/beam_go_sdk:dev')
2023/08/06 11:22:13 2023-08-06 11:22:13. (25): Attempting to pull image apache/beam_go_sdk:dev
2023/08/06 11:22:14 2023-08-06 11:22:14. (26): Unable to pull image apache/beam_go_sdk:dev, defaulting to local image if it exists
2023/08/06 11:22:14 2023-08-06 11:22:14. (27): Waiting for docker to start up. Current status is running
2023/08/06 11:22:14 2023-08-06 11:22:14. (28): Docker container is running. container_id = b'ee170a0242549eb4180fe896e4157b3039be52079f60294ad43700ce8c9127d9', worker_id = worker_17
2023/08/06 11:22:18 2023-08-06 11:22:18. (29): Completed job in 11.545498371124268 seconds with state DONE.
2023/08/06 11:22:18 Job state: DONE
2023/08/06 11:22:18 🐳 Terminating container: a5ce4f220c75
2023/08/06 11:22:18 🚫 Container terminated: a5ce4f220c75
--- PASS: TestJDBCIO_PostgresReadWrite (42.14s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	103.841s
2023/08/06 11:21:21 StructWrapper for beam.createFn already registered. Overwriting.
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:352: 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	6.026s

> Task :sdks:python:test-suites:direct:xlang:validatesCrossLanguageRunnerJavaUsingPython
INFO:root:No image given, using default Python SDK image
INFO:root:Python SDK container image set to "apache/beam_python3.8_sdk:2.49.0" for Docker environment
INFO:__main__:Listening for expansion requests at 43515
INFO:root:Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
INFO:__main__:Shutting down expansion service.
INFO:apache_beam.runners.portability.stager:Executing command: ['/home/jenkins/.apache_beam/cache/venvs/py-3.8-beam-2.49.0-743bdccef67087512a7a190820e727aab7bdcb14/bin/python', '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', '/tmp/tmpc7jk4n73/tmp_requirements.txt', '--exists-action', 'i', '--no-deps', '--implementation', 'cp', '--abi', 'cp38', '--platform', 'manylinux2014_x86_64']
INFO:root:No image given, using default Python SDK image
INFO:root:Python SDK container image set to "apache/beam_python3.8_sdk:2.49.0" for Docker environment
INFO:__main__:Listening for expansion requests at 42083
INFO:root:Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
INFO:__main__:Shutting down expansion service.

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

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.

* 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.6.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 31m 27s
258 actionable tasks: 167 executed, 79 from cache, 12 up-to-date

Publishing build scan...
https://ge.apache.org/s/xz2mzs2pcfhh4

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

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

Changes:


------------------------------------------
[...truncated 1.46 MB...]
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:165: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/pvalue.py:137: in __or__
    return self.pipeline.apply(ptransform, self)
apache_beam/pipeline.py:712: 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:678: in expand
    with ExternalTransform.service(expansion_service) as service:
/usr/lib/python3.8/contextlib.py:113: in __enter__
    return next(self.gen)
apache_beam/transforms/external.py:733: in service
    with expansion_service as stub:
apache_beam/transforms/external.py:944: 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 0x7f389be57370>

    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:88: RuntimeError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:239 Using pre-built snapshot at <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.50.0-SNAPSHOT.jar>
INFO     root:external.py:929 Starting a JAR-based expansion service from 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.50.0-SNAPSHOT.jar> 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:116 Starting 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.50.0-SNAPSHOT.jar'> '52323' '--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.50.0-SNAPSHOT.jar']>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 Error: Invalid or corrupt jarfile <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.50.0-SNAPSHOT.jar>
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.50.0-SNAPSHOT.jar',> '52323', '--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.50.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 88, in start
    raise RuntimeError(
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:154: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/transforms/ptransform.py:614: in __ror__
    result = p.apply(self, pvalueish, label)
apache_beam/pipeline.py:712: 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:678: in expand
    with ExternalTransform.service(expansion_service) as service:
/usr/lib/python3.8/contextlib.py:113: in __enter__
    return next(self.gen)
apache_beam/transforms/external.py:733: in service
    with expansion_service as stub:
apache_beam/transforms/external.py:944: 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 0x7f389be0eaf0>

    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:88: RuntimeError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:239 Using pre-built snapshot at <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.50.0-SNAPSHOT.jar>
INFO     root:external.py:929 Starting a JAR-based expansion service from 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.50.0-SNAPSHOT.jar> 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:116 Starting 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.50.0-SNAPSHOT.jar'> '52241' '--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.50.0-SNAPSHOT.jar']>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 Error: Invalid or corrupt jarfile <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.50.0-SNAPSHOT.jar>
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.50.0-SNAPSHOT.jar',> '52241', '--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.50.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 88, in start
    raise RuntimeError(
RuntimeError: Service failed to start up with error 1
=============================== warnings summary ===============================
../../build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

../../build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py:18
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py>:18: DeprecationWarning: pkg_resources is deprecated as an API. See https://setuptools.pypa.io/en/latest/pkg_resources.html
    import pkg_resources

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871: 20 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871: 16 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.cloud')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2350
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2350: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(parent)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.logging')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py:2871
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/pkg_resources/__init__.py>:2871: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.iam')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    declare_namespace(pkg)

../../build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py:20
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/google/rpc/__init__.py>:20: DeprecationWarning: Deprecated call to `pkg_resources.declare_namespace('google.rpc')`.
  Implementing implicit namespace packages (as specified in PEP 420) is preferred to `pkg_resources.declare_namespace`. See https://setuptools.pypa.io/en/latest/references/keywords.html#keyword-namespace-packages
    pkg_resources.declare_namespace(__name__)

apache_beam/typehints/pandas_type_compatibility_test.py:67
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:67: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    }).set_index(pd.Int64Index(range(123, 223), name='an_index')),

apache_beam/typehints/pandas_type_compatibility_test.py:90
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:90: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    pd.Int64Index(range(123, 223), name='an_index'),

apache_beam/typehints/pandas_type_compatibility_test.py:91
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:91: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    pd.Int64Index(range(475, 575), name='another_index'),

apache_beam/transforms/sql_test.py::SqlTransformTest::test_agg
apache_beam/transforms/sql_test.py::SqlTransformTest::test_filter
apache_beam/transforms/sql_test.py::SqlTransformTest::test_generate_data
apache_beam/transforms/sql_test.py::SqlTransformTest::test_map
apache_beam/transforms/sql_test.py::SqlTransformTest::test_project
apache_beam/transforms/sql_test.py::SqlTransformTest::test_row
apache_beam/transforms/sql_test.py::SqlTransformTest::test_tagged_join
apache_beam/transforms/sql_test.py::SqlTransformTest::test_windowing_before_sql
apache_beam/transforms/sql_test.py::SqlTransformTest::test_zetasql_generate_data
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/apache_beam/transforms/external.py>:676: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    self._expansion_service, pipeline.options)

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Direct/ws/src/sdks/python/pytest_xlangSqlValidateRunner.xml> -
=========================== short test summary info ============================
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_agg - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_filter - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_generate_data - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_map - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_project - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_row - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_tagged_join - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_windowing_before_sql - RuntimeError: Service failed to start up with error 1
FAILED apache_beam/transforms/sql_test.py::SqlTransformTest::test_zetasql_generate_data - RuntimeError: Service failed to start up with error 1
========= 9 failed, 14 skipped, 6945 deselected, 57 warnings in 29.71s =========

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

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

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

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.

* 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.6.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 28m 42s
258 actionable tasks: 167 executed, 79 from cache, 12 up-to-date

Publishing build scan...
https://ge.apache.org/s/uf3b3lspcvoj4

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