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/06 21:49:40 UTC

Build failed in Jenkins: beam_PostCommit_TransformService_Direct #4

See <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/4/display/redirect>

Changes:


------------------------------------------
Started by user Chamikara Madhusanka Jayalath
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-1 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Using shallow clone with depth 1
Avoid fetching tags
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.25.1'
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Using shallow fetch with depth 1
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse refs/remotes/origin/pr/27578/head^{commit} # timeout=10
 > git rev-parse origin/pr/27578/head^{commit} # timeout=10
ERROR: Couldn't find any revision to build. Verify the repository and branch configuration for this job.

---------------------------------------------------------------------
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_TransformService_Direct #24

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/24/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_TransformService_Direct #23

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

Changes:


------------------------------------------
[...truncated 753.60 KB...]
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:206: in run_pipeline
    _ = (
apache_beam/pipeline.py:600: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:577: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/direct/test_direct_runner.py:42: in run_pipeline
    self.result = super().run_pipeline(pipeline, options)
apache_beam/runners/direct/direct_runner.py:128: in run_pipeline
    return runner.run_pipeline(pipeline, options)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:202: in run_pipeline
    self._latest_run_result = self.run_via_runner_api(
apache_beam/runners/portability/fn_api_runner/fn_runner.py:224: in run_via_runner_api
    return self.run_stages(stage_context, stages)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:430: in run_stages
    runner_execution_context.setup()
apache_beam/runners/portability/fn_api_runner/execution.py:811: in setup
    self._enqueue_stage_initial_inputs(stage)
apache_beam/runners/portability/fn_api_runner/execution.py:840: in _enqueue_stage_initial_inputs
    bundle_manager.data_api_service_descriptor())
apache_beam/runners/portability/fn_api_runner/execution.py:1064: in data_api_service_descriptor
    return self.worker_handlers[0].data_api_service_descriptor()
apache_beam/runners/portability/fn_api_runner/execution.py:1056: in worker_handlers
    self.execution_context.worker_handler_manager.get_worker_handlers(
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:911: in get_worker_handlers
    worker_handler.start_worker()
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:770: in start_worker
    self._container_id = subprocess.check_output([
/usr/lib/python3.8/subprocess.py:415: in check_output
    return run(*popenargs, stdout=PIPE, timeout=timeout, check=True,
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

input = None, capture_output = False, timeout = None, check = True
popenargs = (['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_10', ...],)
kwargs = {'stdout': -1}, process = <subprocess.Popen object at 0x7f57d5a992e0>
stdout = b'', stderr = None, retcode = 125

    def run(*popenargs,
            input=None, capture_output=False, timeout=None, check=False, **kwargs):
        """Run command with arguments and return a CompletedProcess instance.
    
        The returned instance will have attributes args, returncode, stdout and
        stderr. By default, stdout and stderr are not captured, and those attributes
        will be None. Pass stdout=PIPE and/or stderr=PIPE in order to capture them.
    
        If check is True and the exit code was non-zero, it raises a
        CalledProcessError. The CalledProcessError object will have the return code
        in the returncode attribute, and output & stderr attributes if those streams
        were captured.
    
        If timeout is given, and the process takes too long, a TimeoutExpired
        exception will be raised.
    
        There is an optional argument "input", allowing you to
        pass bytes or a string to the subprocess's stdin.  If you use this argument
        you may not also use the Popen constructor's "stdin" argument, as
        it will be used internally.
    
        By default, all communication is in bytes, and therefore any "input" should
        be bytes, and the stdout and stderr will be bytes. If in text mode, any
        "input" should be a string, and stdout and stderr will be strings decoded
        according to locale encoding, or by "encoding" if set. Text mode is
        triggered by setting any of text, encoding, errors or universal_newlines.
    
        The other arguments are the same as for the Popen constructor.
        """
        if input is not None:
            if kwargs.get('stdin') is not None:
                raise ValueError('stdin and input arguments may not both be used.')
            kwargs['stdin'] = PIPE
    
        if capture_output:
            if kwargs.get('stdout') is not None or kwargs.get('stderr') is not None:
                raise ValueError('stdout and stderr arguments may not be used '
                                 'with capture_output.')
            kwargs['stdout'] = PIPE
            kwargs['stderr'] = PIPE
    
        with Popen(*popenargs, **kwargs) as process:
            try:
                stdout, stderr = process.communicate(input, timeout=timeout)
            except TimeoutExpired as exc:
                process.kill()
                if _mswindows:
                    # Windows accumulates the output in a single blocking
                    # read() call run on child threads, with the timeout
                    # being done in a join() on those threads.  communicate()
                    # _after_ kill() is required to collect that and add it
                    # to the exception.
                    exc.stdout, exc.stderr = process.communicate()
                else:
                    # POSIX _communicate already populated the output so
                    # far into the TimeoutExpired exception.
                    process.wait()
                raise
            except:  # Including KeyboardInterrupt, communicate handled that.
                process.kill()
                # We don't call process.wait() as .__exit__ does that for us.
                raise
            retcode = process.poll()
            if check and retcode:
>               raise CalledProcessError(retcode, process.args,
                                         output=stdout, stderr=stderr)
E               subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_10', '--logging_endpoint=localhost:39707', '--control_endpoint=localhost:43431', '--artifact_endpoint=localhost:43431', '--provision_endpoint=localhost:43431']' returned non-zero exit status 125.

/usr/lib/python3.8/subprocess.py:516: CalledProcessError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:186 Created table [test-table-1692399126-7adfd1]
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function annotate_downstream_side_inputs at 0x7f57a0d21ee0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function fix_side_input_pcoll_coders at 0x7f57a0d23040> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function pack_combiners at 0x7f57a0d23550> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function lift_combiners at 0x7f57a0d235e0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_sdf at 0x7f57a0d23790> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_gbk at 0x7f57a0d23820> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sink_flattens at 0x7f57a0d23940> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function greedily_fuse at 0x7f57a0d239d0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function read_to_impulse at 0x7f57a0d23a60> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function impulse_to_input at 0x7f57a0d23af0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sort_stages at 0x7f57a0d23d30> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function add_impulse_to_dangling_transforms at 0x7f57a0d23e50> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function setup_timer_mapping at 0x7f57a0d23ca0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function populate_data_channel_coders at 0x7f57a0d23dc0> ====================
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 104857600
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.EmbeddedWorkerHandler object at 0x7f57d5949730> for environment ref_Environment_default_environment_2 (beam:env:embedded_python:v1, b'')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:510 starting control server on port 43431
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:511 starting data server on port 41657
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:512 starting state server on port 41037
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:513 starting logging server on port 39707
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f57d5a99820> for environment external_6beam:env:docker:v1 (beam:env:docker:v1, b'\n!apache/beam_java11_sdk:2.51.0.dev')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:764 Attempting to pull image apache/beam_java11_sdk:2.51.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:767 Unable to pull image apache/beam_java11_sdk:2.51.0.dev, defaulting to local image if it exists
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:190 Deleting table [test-table-1692399126-7adfd1]
---------------------------- Captured log teardown -----------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:198 Deleting instance [bt-write-xlang-1692399085-2ae980]
=============================== warnings summary ===============================
../../build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py:28
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py>:28: 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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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_TransformService_Direct/ws/src/sdks/python/pytest_transformService.xml> -
=========================== short test summary info ============================
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_0', '--logging_endpoint=localhost:35171', '--control_endpoint=localhost:45665', '--artifact_endpoint=localhost:45665', '--provision_endpoint=localhost:45665']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_2', '--logging_endpoint=localhost:45633', '--control_endpoint=localhost:34101', '--artifact_endpoint=localhost:34101', '--provision_endpoint=localhost:34101']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_4', '--logging_endpoint=localhost:43681', '--control_endpoint=localhost:39429', '--artifact_endpoint=localhost:39429', '--provision_endpoint=localhost:39429']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_6', '--logging_endpoint=localhost:42081', '--control_endpoint=localhost:40853', '--artifact_endpoint=localhost:40853', '--provision_endpoint=localhost:40853']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_8', '--logging_endpoint=localhost:42287', '--control_endpoint=localhost:45453', '--artifact_endpoint=localhost:45453', '--provision_endpoint=localhost:45453']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_10', '--logging_endpoint=localhost:39707', '--control_endpoint=localhost:43431', '--artifact_endpoint=localhost:43431', '--provision_endpoint=localhost:43431']' returned non-zero exit status 125.
==== 6 failed, 15 skipped, 6960 deselected, 51 warnings in 82.85s (0:01:22) ====

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

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

> Task :sdks:python:test-suites:direct:xlang:transformServiceCleanup
Stopping the transform service for project xlang at port 37009 for Beam version 2.51.0.dev  transform service startup jar is <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/java/transform-service/launcher/build/libs/beam-sdks-java-transform-service-launcher-2.51.0-SNAPSHOT.jar>

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava'.
> 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 10m 2s
159 actionable tasks: 112 executed, 38 from cache, 9 up-to-date

Publishing build scan...

Publishing failed.

The response from https://ge.apache.org/scans/publish/gradle/3.13.2/token was not from Gradle Enterprise.
The specified server address may be incorrect, or your network environment may be interfering.

Please report this problem to your Gradle Enterprise administrator via https://ge.apache.org/help and include the following via copy/paste:

----------
Gradle version: 7.6.2
Plugin version: 3.13.2
Request URL: https://ge.apache.org/scans/publish/gradle/3.13.2/token
Request ID: 40dfd114-20d4-482d-b90f-1f4ed5897857
Response status code: 502
Response content type: text/html
----------

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_TransformService_Direct #22

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

Changes:

[noreply] Add Java IO Direct jobs: JDBC, Jms, Snowflake (#28021)


------------------------------------------
[...truncated 651.01 KB...]
#9 443.5 cloudpickle==2.2.1
#9 443.5 crcmod==1.7
#9 443.5 cryptography==41.0.3
#9 443.5 Cython==0.29.36
#9 443.5 deprecation==2.1.0
#9 443.5 dill==0.3.1.1
#9 443.5 dnspython==2.4.2
#9 443.5 docker==6.1.3
#9 443.5 docopt==0.6.2
#9 443.5 exceptiongroup==1.1.2
#9 443.5 execnet==2.0.2
#9 443.5 fastavro==1.8.2
#9 443.5 fasteners==0.18
#9 443.5 flatbuffers==23.5.26
#9 443.5 freezegun==1.2.2
#9 443.5 future==0.18.3
#9 443.5 gast==0.4.0
#9 443.5 google-api-core==2.11.1
#9 443.5 google-api-python-client==2.96.0
#9 443.5 google-apitools==0.5.31
#9 443.5 google-auth==2.22.0
#9 443.5 google-auth-httplib2==0.1.0
#9 443.5 google-auth-oauthlib==1.0.0
#9 443.5 google-cloud-aiplatform==1.29.0
#9 443.5 google-cloud-bigquery==3.11.4
#9 443.5 google-cloud-bigquery-storage==2.22.0
#9 443.5 google-cloud-bigtable==2.21.0
#9 443.5 google-cloud-core==2.3.3
#9 443.5 google-cloud-datastore==2.17.0
#9 443.5 google-cloud-dlp==3.12.2
#9 443.5 google-cloud-language==2.10.1
#9 443.5 google-cloud-profiler==4.0.0
#9 443.5 google-cloud-pubsub==2.18.2
#9 443.5 google-cloud-pubsublite==1.8.3
#9 443.5 google-cloud-recommendations-ai==0.10.4
#9 443.5 google-cloud-resource-manager==1.10.3
#9 443.5 google-cloud-spanner==3.40.0
#9 443.5 google-cloud-storage==2.10.0
#9 443.5 google-cloud-videointelligence==2.11.3
#9 443.5 google-cloud-vision==3.4.4
#9 443.5 google-crc32c==1.5.0
#9 443.5 google-pasta==0.2.0
#9 443.5 google-resumable-media==2.5.0
#9 443.5 googleapis-common-protos==1.60.0
#9 443.5 greenlet==2.0.2
#9 443.5 grpc-google-iam-v1==0.12.6
#9 443.5 grpcio==1.56.2
#9 443.5 grpcio-status==1.56.2
#9 443.5 guppy3==3.1.3
#9 443.5 h5py==3.9.0
#9 443.5 hdfs==2.7.2
#9 443.5 httplib2==0.22.0
#9 443.5 hypothesis==6.82.3
#9 443.5 idna==3.4
#9 443.5 importlib-metadata==6.8.0
#9 443.5 iniconfig==2.0.0
#9 443.5 joblib==1.3.2
#9 443.5 keras==2.13.1
#9 443.5 libclang==16.0.6
#9 443.5 Markdown==3.4.4
#9 443.5 MarkupSafe==2.1.3
#9 443.5 mmh3==4.0.1
#9 443.5 mock==5.1.0
#9 443.5 nltk==3.8.1
#9 443.5 nose==1.3.7
#9 443.5 numpy==1.24.3
#9 443.5 oauth2client==4.1.3
#9 443.5 oauthlib==3.2.2
#9 443.5 objsize==0.6.1
#9 443.5 opt-einsum==3.3.0
#9 443.5 orjson==3.9.4
#9 443.5 overrides==6.5.0
#9 443.5 packaging==23.1
#9 443.5 pandas==1.5.3
#9 443.5 parameterized==0.9.0
#9 443.5 pip==23.0.1
#9 443.5 pluggy==1.2.0
#9 443.5 proto-plus==1.22.3
#9 443.5 protobuf==4.23.4
#9 443.5 psycopg2-binary==2.9.7
#9 443.5 pyarrow==11.0.0
#9 443.5 pyasn1==0.5.0
#9 443.5 pyasn1-modules==0.3.0
#9 443.5 pycparser==2.21
#9 443.5 pydot==1.4.2
#9 443.5 PyHamcrest==2.0.4
#9 443.5 pymongo==4.4.1
#9 443.5 PyMySQL==1.1.0
#9 443.5 pyparsing==3.1.1
#9 443.5 pytest==7.4.0
#9 443.5 pytest-timeout==2.1.0
#9 443.5 pytest-xdist==3.3.1
#9 443.5 python-dateutil==2.8.2
#9 443.5 python-snappy==0.6.1
#9 443.5 pytz==2023.3
#9 443.5 PyYAML==6.0.1
#9 443.5 regex==2023.8.8
#9 443.5 requests==2.31.0
#9 443.5 requests-mock==1.11.0
#9 443.5 requests-oauthlib==1.3.1
#9 443.5 rsa==4.9
#9 443.5 scikit-learn==1.3.0
#9 443.5 scipy==1.10.1
#9 443.5 setuptools==68.1.2
#9 443.5 Shapely==1.8.5.post1
#9 443.5 six==1.16.0
#9 443.5 sortedcontainers==2.4.0
#9 443.5 soupsieve==2.4.1
#9 443.5 SQLAlchemy==1.4.49
#9 443.5 sqlparse==0.4.4
#9 443.5 tenacity==8.2.2
#9 443.5 tensorboard==2.13.0
#9 443.5 tensorboard-data-server==0.7.1
#9 443.5 tensorflow==2.13.0
#9 443.5 tensorflow-estimator==2.13.0
#9 443.5 tensorflow-io-gcs-filesystem==0.33.0
#9 443.5 termcolor==2.3.0
#9 443.5 testcontainers==3.7.1
#9 443.5 threadpoolctl==3.2.0
#9 443.5 tomli==2.0.1
#9 443.5 tqdm==4.66.0
#9 443.5 typing_extensions==4.5.0
#9 443.5 uritemplate==4.1.1
#9 443.5 urllib3==1.26.16
#9 443.5 websocket-client==1.6.1
#9 443.5 Werkzeug==2.3.6
#9 443.5 wheel==0.41.1
#9 443.5 wrapt==1.15.0
#9 443.5 zipp==3.16.2
#9 443.5 zstandard==0.21.0
#9 DONE 444.6s

#10 [third_party_licenses 1/4] COPY target/license_scripts /tmp/license_scripts/
#10 DONE 0.1s

#11 [third_party_licenses 2/4] COPY  target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
#11 DONE 0.1s

#12 [third_party_licenses 3/4] COPY target/license_scripts /tmp/license_scripts/
#12 DONE 0.1s

#13 [third_party_licenses 4/4] RUN if [ "true" = "true" ] ; then       pip install 'pip-licenses<5' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
#13 1.120 Collecting pip-licenses<5
#13 1.187   Downloading pip_licenses-4.3.2-py3-none-any.whl (19 kB)
#13 1.196 Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0.1)
#13 1.197 Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (8.2.2)
#13 1.264 Collecting prettytable>=2.3.0
#13 1.280   Downloading prettytable-3.8.0-py3-none-any.whl (27 kB)
#13 1.343 Collecting wcwidth
#13 1.359   Downloading wcwidth-0.2.6-py2.py3-none-any.whl (29 kB)
#13 2.715 Installing collected packages: wcwidth, prettytable, pip-licenses
#13 2.901 Successfully installed pip-licenses-4.3.2 prettytable-3.8.0 wcwidth-0.2.6
#13 2.902 WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
#13 3.115 
#13 3.115 [notice] A new release of pip is available: 23.0.1 -> 23.2.1
#13 3.115 [notice] To update, run: pip install --upgrade pip
#13 9.670 INFO:root:Successfully pulled licenses for 137 dependencies
#13 9.670 Skip pulling license for  bs4
#13 DONE 9.8s

#14 [stage-2 1/2] COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
#14 DONE 0.1s

#15 [stage-2 2/2] RUN if [ "true" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
#15 DONE 0.4s

#16 exporting to image
#16 exporting layers
#16 exporting layers 24.9s done
#16 writing image sha256:a8132bc9f9f0ead93d3418f9dacd9c50566b1bdad8159cf7a80c113e06246fd2 done
#16 naming to docker.io/apache/beam_python3.8_sdk:2.51.0.dev
#16 naming to docker.io/apache/beam_python3.8_sdk:2.51.0.dev done
#16 DONE 24.9s

> Task :sdks:python:test-suites:direct:xlang:transformServiceSetup
> Task :sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava
Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown
Unable to find image 'apache/beam_java11_sdk:2.51.0.dev' locally
docker: Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown.
See 'docker run --help'.
Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown
Unable to find image 'apache/beam_java11_sdk:2.51.0.dev' locally
docker: Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown.
See 'docker run --help'.
Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown
Unable to find image 'apache/beam_java11_sdk:2.51.0.dev' locally
docker: Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown.
See 'docker run --help'.
Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown
Unable to find image 'apache/beam_java11_sdk:2.51.0.dev' locally
docker: Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown.
See 'docker run --help'.
Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown
Unable to find image 'apache/beam_java11_sdk:2.51.0.dev' locally
docker: Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown.
See 'docker run --help'.
Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown
Unable to find image 'apache/beam_java11_sdk:2.51.0.dev' locally
docker: Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown.
See 'docker run --help'.

> Task :sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava FAILED
> Task :sdks:python:test-suites:direct:xlang:fnApiJobServerCleanup
> Task :sdks:python:test-suites:direct:xlang:transformServiceCleanup

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava'.
> 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 10m 47s
159 actionable tasks: 112 executed, 38 from cache, 9 up-to-date

Publishing build scan...

Publishing failed.

The response from https://ge.apache.org/scans/publish/gradle/3.13.2/token was not from Gradle Enterprise.
The specified server address may be incorrect, or your network environment may be interfering.

Please report this problem to your Gradle Enterprise administrator via https://ge.apache.org/help and include the following via copy/paste:

----------
Gradle version: 7.6.2
Plugin version: 3.13.2
Request URL: https://ge.apache.org/scans/publish/gradle/3.13.2/token
Request ID: 931bc268-81de-4d79-a1c2-7279347a5c57
Response status code: 502
Response content type: text/html
----------

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_TransformService_Direct #21

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

Changes:


------------------------------------------
[...truncated 782.17 KB...]
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:206: in run_pipeline
    _ = (
apache_beam/pipeline.py:600: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:577: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/direct/test_direct_runner.py:42: in run_pipeline
    self.result = super().run_pipeline(pipeline, options)
apache_beam/runners/direct/direct_runner.py:128: in run_pipeline
    return runner.run_pipeline(pipeline, options)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:202: in run_pipeline
    self._latest_run_result = self.run_via_runner_api(
apache_beam/runners/portability/fn_api_runner/fn_runner.py:224: in run_via_runner_api
    return self.run_stages(stage_context, stages)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:430: in run_stages
    runner_execution_context.setup()
apache_beam/runners/portability/fn_api_runner/execution.py:811: in setup
    self._enqueue_stage_initial_inputs(stage)
apache_beam/runners/portability/fn_api_runner/execution.py:840: in _enqueue_stage_initial_inputs
    bundle_manager.data_api_service_descriptor())
apache_beam/runners/portability/fn_api_runner/execution.py:1064: in data_api_service_descriptor
    return self.worker_handlers[0].data_api_service_descriptor()
apache_beam/runners/portability/fn_api_runner/execution.py:1056: in worker_handlers
    self.execution_context.worker_handler_manager.get_worker_handlers(
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:911: in get_worker_handlers
    worker_handler.start_worker()
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:770: in start_worker
    self._container_id = subprocess.check_output([
/usr/lib/python3.8/subprocess.py:415: in check_output
    return run(*popenargs, stdout=PIPE, timeout=timeout, check=True,
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

input = None, capture_output = False, timeout = None, check = True
popenargs = (['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_11', ...],)
kwargs = {'stdout': -1}, process = <subprocess.Popen object at 0x7fc02993d2e0>
stdout = b'', stderr = None, retcode = 125

    def run(*popenargs,
            input=None, capture_output=False, timeout=None, check=False, **kwargs):
        """Run command with arguments and return a CompletedProcess instance.
    
        The returned instance will have attributes args, returncode, stdout and
        stderr. By default, stdout and stderr are not captured, and those attributes
        will be None. Pass stdout=PIPE and/or stderr=PIPE in order to capture them.
    
        If check is True and the exit code was non-zero, it raises a
        CalledProcessError. The CalledProcessError object will have the return code
        in the returncode attribute, and output & stderr attributes if those streams
        were captured.
    
        If timeout is given, and the process takes too long, a TimeoutExpired
        exception will be raised.
    
        There is an optional argument "input", allowing you to
        pass bytes or a string to the subprocess's stdin.  If you use this argument
        you may not also use the Popen constructor's "stdin" argument, as
        it will be used internally.
    
        By default, all communication is in bytes, and therefore any "input" should
        be bytes, and the stdout and stderr will be bytes. If in text mode, any
        "input" should be a string, and stdout and stderr will be strings decoded
        according to locale encoding, or by "encoding" if set. Text mode is
        triggered by setting any of text, encoding, errors or universal_newlines.
    
        The other arguments are the same as for the Popen constructor.
        """
        if input is not None:
            if kwargs.get('stdin') is not None:
                raise ValueError('stdin and input arguments may not both be used.')
            kwargs['stdin'] = PIPE
    
        if capture_output:
            if kwargs.get('stdout') is not None or kwargs.get('stderr') is not None:
                raise ValueError('stdout and stderr arguments may not be used '
                                 'with capture_output.')
            kwargs['stdout'] = PIPE
            kwargs['stderr'] = PIPE
    
        with Popen(*popenargs, **kwargs) as process:
            try:
                stdout, stderr = process.communicate(input, timeout=timeout)
            except TimeoutExpired as exc:
                process.kill()
                if _mswindows:
                    # Windows accumulates the output in a single blocking
                    # read() call run on child threads, with the timeout
                    # being done in a join() on those threads.  communicate()
                    # _after_ kill() is required to collect that and add it
                    # to the exception.
                    exc.stdout, exc.stderr = process.communicate()
                else:
                    # POSIX _communicate already populated the output so
                    # far into the TimeoutExpired exception.
                    process.wait()
                raise
            except:  # Including KeyboardInterrupt, communicate handled that.
                process.kill()
                # We don't call process.wait() as .__exit__ does that for us.
                raise
            retcode = process.poll()
            if check and retcode:
>               raise CalledProcessError(retcode, process.args,
                                         output=stdout, stderr=stderr)
E               subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_11', '--logging_endpoint=localhost:33253', '--control_endpoint=localhost:33521', '--artifact_endpoint=localhost:33521', '--provision_endpoint=localhost:33521']' returned non-zero exit status 125.

/usr/lib/python3.8/subprocess.py:516: CalledProcessError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:186 Created table [test-table-1692355917-71de07]
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function annotate_downstream_side_inputs at 0x7fbff57b4ca0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function fix_side_input_pcoll_coders at 0x7fbff57b4dc0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function pack_combiners at 0x7fbff579c310> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function lift_combiners at 0x7fbff579c3a0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_sdf at 0x7fbff579c550> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_gbk at 0x7fbff579c5e0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sink_flattens at 0x7fbff579c700> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function greedily_fuse at 0x7fbff579c790> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function read_to_impulse at 0x7fbff579c820> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function impulse_to_input at 0x7fbff579c8b0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sort_stages at 0x7fbff579caf0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function add_impulse_to_dangling_transforms at 0x7fbff579cc10> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function setup_timer_mapping at 0x7fbff579ca60> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function populate_data_channel_coders at 0x7fbff579cb80> ====================
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 104857600
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.EmbeddedWorkerHandler object at 0x7fbfdd518430> for environment ref_Environment_default_environment_2 (beam:env:embedded_python:v1, b'')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:510 starting control server on port 33521
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:511 starting data server on port 44089
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:512 starting state server on port 36671
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:513 starting logging server on port 33253
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7fc029a80160> for environment external_6beam:env:docker:v1 (beam:env:docker:v1, b'\n!apache/beam_java11_sdk:2.51.0.dev')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:764 Attempting to pull image apache/beam_java11_sdk:2.51.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:767 Unable to pull image apache/beam_java11_sdk:2.51.0.dev, defaulting to local image if it exists
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:190 Deleting table [test-table-1692355917-71de07]
---------------------------- Captured log teardown -----------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:198 Deleting instance [bt-write-xlang-1692355880-5b79f0]
=============================== warnings summary ===============================
../../build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py:28
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py>:28: 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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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_TransformService_Direct/ws/src/sdks/python/pytest_transformService.xml> -
=========================== short test summary info ============================
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_1', '--logging_endpoint=localhost:45109', '--control_endpoint=localhost:35457', '--artifact_endpoint=localhost:35457', '--provision_endpoint=localhost:35457']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_3', '--logging_endpoint=localhost:37099', '--control_endpoint=localhost:46515', '--artifact_endpoint=localhost:46515', '--provision_endpoint=localhost:46515']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_5', '--logging_endpoint=localhost:40341', '--control_endpoint=localhost:43335', '--artifact_endpoint=localhost:43335', '--provision_endpoint=localhost:43335']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_7', '--logging_endpoint=localhost:39759', '--control_endpoint=localhost:43427', '--artifact_endpoint=localhost:43427', '--provision_endpoint=localhost:43427']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_9', '--logging_endpoint=localhost:45437', '--control_endpoint=localhost:40465', '--artifact_endpoint=localhost:40465', '--provision_endpoint=localhost:40465']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_11', '--logging_endpoint=localhost:33253', '--control_endpoint=localhost:33521', '--artifact_endpoint=localhost:33521', '--provision_endpoint=localhost:33521']' returned non-zero exit status 125.
==== 6 failed, 15 skipped, 6954 deselected, 51 warnings in 73.78s (0:01:13) ====

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

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

> Task :sdks:python:test-suites:direct:xlang:transformServiceCleanup
Stopping the transform service for project xlang at port 46099 for Beam version 2.51.0.dev  transform service startup jar is <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/java/transform-service/launcher/build/libs/beam-sdks-java-transform-service-launcher-2.51.0-SNAPSHOT.jar>

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava'.
> 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 9m 43s
159 actionable tasks: 112 executed, 38 from cache, 9 up-to-date

Publishing build scan...

Publishing failed.

The response from https://ge.apache.org/scans/publish/gradle/3.13.2/token was not from Gradle Enterprise.
The specified server address may be incorrect, or your network environment may be interfering.

Please report this problem to your Gradle Enterprise administrator via https://ge.apache.org/help and include the following via copy/paste:

----------
Gradle version: 7.6.2
Plugin version: 3.13.2
Request URL: https://ge.apache.org/scans/publish/gradle/3.13.2/token
Request ID: 5b40cf52-1851-40f9-9c50-206170bce1f9
Response status code: 502
Response content type: text/html
----------

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_TransformService_Direct #20

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

Changes:


------------------------------------------
[...truncated 650.53 KB...]
#9 415.0 click==8.1.6
#9 415.0 cloudpickle==2.2.1
#9 415.0 crcmod==1.7
#9 415.0 cryptography==41.0.3
#9 415.0 Cython==0.29.36
#9 415.0 deprecation==2.1.0
#9 415.0 dill==0.3.1.1
#9 415.0 dnspython==2.4.2
#9 415.0 docker==6.1.3
#9 415.0 docopt==0.6.2
#9 415.0 exceptiongroup==1.1.2
#9 415.0 execnet==2.0.2
#9 415.0 fastavro==1.8.2
#9 415.0 fasteners==0.18
#9 415.0 flatbuffers==23.5.26
#9 415.0 freezegun==1.2.2
#9 415.0 future==0.18.3
#9 415.0 gast==0.4.0
#9 415.0 google-api-core==2.11.1
#9 415.0 google-api-python-client==2.96.0
#9 415.0 google-apitools==0.5.31
#9 415.0 google-auth==2.22.0
#9 415.0 google-auth-httplib2==0.1.0
#9 415.0 google-auth-oauthlib==1.0.0
#9 415.0 google-cloud-aiplatform==1.29.0
#9 415.0 google-cloud-bigquery==3.11.4
#9 415.0 google-cloud-bigquery-storage==2.22.0
#9 415.0 google-cloud-bigtable==2.21.0
#9 415.0 google-cloud-core==2.3.3
#9 415.0 google-cloud-datastore==2.17.0
#9 415.0 google-cloud-dlp==3.12.2
#9 415.0 google-cloud-language==2.10.1
#9 415.0 google-cloud-profiler==4.0.0
#9 415.0 google-cloud-pubsub==2.18.2
#9 415.0 google-cloud-pubsublite==1.8.3
#9 415.0 google-cloud-recommendations-ai==0.10.4
#9 415.0 google-cloud-resource-manager==1.10.3
#9 415.0 google-cloud-spanner==3.40.0
#9 415.0 google-cloud-storage==2.10.0
#9 415.0 google-cloud-videointelligence==2.11.3
#9 415.0 google-cloud-vision==3.4.4
#9 415.0 google-crc32c==1.5.0
#9 415.0 google-pasta==0.2.0
#9 415.0 google-resumable-media==2.5.0
#9 415.0 googleapis-common-protos==1.60.0
#9 415.0 greenlet==2.0.2
#9 415.0 grpc-google-iam-v1==0.12.6
#9 415.0 grpcio==1.56.2
#9 415.0 grpcio-status==1.56.2
#9 415.0 guppy3==3.1.3
#9 415.0 h5py==3.9.0
#9 415.0 hdfs==2.7.2
#9 415.0 httplib2==0.22.0
#9 415.0 hypothesis==6.82.3
#9 415.0 idna==3.4
#9 415.0 importlib-metadata==6.8.0
#9 415.0 iniconfig==2.0.0
#9 415.0 joblib==1.3.2
#9 415.0 keras==2.13.1
#9 415.0 libclang==16.0.6
#9 415.0 Markdown==3.4.4
#9 415.0 MarkupSafe==2.1.3
#9 415.0 mmh3==4.0.1
#9 415.0 mock==5.1.0
#9 415.0 nltk==3.8.1
#9 415.0 nose==1.3.7
#9 415.0 numpy==1.24.3
#9 415.0 oauth2client==4.1.3
#9 415.0 oauthlib==3.2.2
#9 415.0 objsize==0.6.1
#9 415.0 opt-einsum==3.3.0
#9 415.0 orjson==3.9.4
#9 415.0 overrides==6.5.0
#9 415.0 packaging==23.1
#9 415.0 pandas==1.5.3
#9 415.0 parameterized==0.9.0
#9 415.0 pip==23.0.1
#9 415.0 pluggy==1.2.0
#9 415.0 proto-plus==1.22.3
#9 415.0 protobuf==4.23.4
#9 415.0 psycopg2-binary==2.9.7
#9 415.0 pyarrow==11.0.0
#9 415.0 pyasn1==0.5.0
#9 415.0 pyasn1-modules==0.3.0
#9 415.0 pycparser==2.21
#9 415.0 pydot==1.4.2
#9 415.0 PyHamcrest==2.0.4
#9 415.0 pymongo==4.4.1
#9 415.0 PyMySQL==1.1.0
#9 415.0 pyparsing==3.1.1
#9 415.0 pytest==7.4.0
#9 415.0 pytest-timeout==2.1.0
#9 415.0 pytest-xdist==3.3.1
#9 415.0 python-dateutil==2.8.2
#9 415.0 python-snappy==0.6.1
#9 415.0 pytz==2023.3
#9 415.0 PyYAML==6.0.1
#9 415.0 regex==2023.8.8
#9 415.0 requests==2.31.0
#9 415.0 requests-mock==1.11.0
#9 415.0 requests-oauthlib==1.3.1
#9 415.0 rsa==4.9
#9 415.0 scikit-learn==1.3.0
#9 415.0 scipy==1.10.1
#9 415.0 setuptools==68.1.0
#9 415.0 Shapely==1.8.5.post1
#9 415.0 six==1.16.0
#9 415.0 sortedcontainers==2.4.0
#9 415.0 soupsieve==2.4.1
#9 415.0 SQLAlchemy==1.4.49
#9 415.0 sqlparse==0.4.4
#9 415.0 tenacity==8.2.2
#9 415.0 tensorboard==2.13.0
#9 415.0 tensorboard-data-server==0.7.1
#9 415.0 tensorflow==2.13.0
#9 415.0 tensorflow-estimator==2.13.0
#9 415.0 tensorflow-io-gcs-filesystem==0.33.0
#9 415.0 termcolor==2.3.0
#9 415.0 testcontainers==3.7.1
#9 415.0 threadpoolctl==3.2.0
#9 415.0 tomli==2.0.1
#9 415.0 tqdm==4.66.0
#9 415.0 typing_extensions==4.5.0
#9 415.0 uritemplate==4.1.1
#9 415.0 urllib3==1.26.16
#9 415.0 websocket-client==1.6.1
#9 415.0 Werkzeug==2.3.6
#9 415.0 wheel==0.41.1
#9 415.0 wrapt==1.15.0
#9 415.0 zipp==3.16.2
#9 415.0 zstandard==0.21.0
#9 DONE 416.1s

#10 [third_party_licenses 1/4] COPY target/license_scripts /tmp/license_scripts/
#10 DONE 0.0s

#11 [third_party_licenses 2/4] COPY  target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
#11 DONE 0.1s

#12 [third_party_licenses 3/4] COPY target/license_scripts /tmp/license_scripts/
#12 DONE 0.1s

#13 [third_party_licenses 4/4] RUN if [ "true" = "true" ] ; then       pip install 'pip-licenses<5' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
#13 1.177 Collecting pip-licenses<5
#13 1.245   Downloading pip_licenses-4.3.2-py3-none-any.whl (19 kB)
#13 1.257 Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0.1)
#13 1.258 Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (8.2.2)
#13 1.342 Collecting prettytable>=2.3.0
#13 1.358   Downloading prettytable-3.8.0-py3-none-any.whl (27 kB)
#13 1.435 Collecting wcwidth
#13 1.450   Downloading wcwidth-0.2.6-py2.py3-none-any.whl (29 kB)
#13 2.834 Installing collected packages: wcwidth, prettytable, pip-licenses
#13 2.997 Successfully installed pip-licenses-4.3.2 prettytable-3.8.0 wcwidth-0.2.6
#13 2.998 WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
#13 3.149 
#13 3.149 [notice] A new release of pip is available: 23.0.1 -> 23.2.1
#13 3.149 [notice] To update, run: pip install --upgrade pip
#13 14.54 INFO:root:Successfully pulled licenses for 137 dependencies
#13 14.54 Skip pulling license for  bs4
#13 DONE 14.6s

#14 [stage-2 1/2] COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
#14 DONE 0.1s

#15 [stage-2 2/2] RUN if [ "true" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
#15 DONE 0.3s

#16 exporting to image
#16 exporting layers
#16 exporting layers 23.0s done
#16 writing image sha256:de1a3526e19041bbad8f6fe5dd64e565695753e948fed25ffe4cf34d521f931a done
#16 naming to docker.io/apache/beam_python3.8_sdk:2.51.0.dev done
#16 DONE 23.0s

> Task :sdks:python:test-suites:direct:xlang:transformServiceSetup
> Task :sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava
Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown
Unable to find image 'apache/beam_java11_sdk:2.51.0.dev' locally
docker: Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown.
See 'docker run --help'.
Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown
Unable to find image 'apache/beam_java11_sdk:2.51.0.dev' locally
docker: Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown.
See 'docker run --help'.
Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown
Unable to find image 'apache/beam_java11_sdk:2.51.0.dev' locally
docker: Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown.
See 'docker run --help'.
Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown
Unable to find image 'apache/beam_java11_sdk:2.51.0.dev' locally
docker: Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown.
See 'docker run --help'.
Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown
Unable to find image 'apache/beam_java11_sdk:2.51.0.dev' locally
docker: Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown.
See 'docker run --help'.
Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown
Unable to find image 'apache/beam_java11_sdk:2.51.0.dev' locally
docker: Error response from daemon: manifest for apache/beam_java11_sdk:2.51.0.dev not found: manifest unknown: manifest unknown.
See 'docker run --help'.

> Task :sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava FAILED
> Task :sdks:python:test-suites:direct:xlang:fnApiJobServerCleanup
> Task :sdks:python:test-suites:direct:xlang:transformServiceCleanup

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava'.
> 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 10m 15s
159 actionable tasks: 112 executed, 38 from cache, 9 up-to-date

Publishing build scan...

Publishing failed.

The response from https://ge.apache.org/scans/publish/gradle/3.13.2/token was not from Gradle Enterprise.
The specified server address may be incorrect, or your network environment may be interfering.

Please report this problem to your Gradle Enterprise administrator via https://ge.apache.org/help and include the following via copy/paste:

----------
Gradle version: 7.6.2
Plugin version: 3.13.2
Request URL: https://ge.apache.org/scans/publish/gradle/3.13.2/token
Request ID: 5f4509e0-d3d3-4fef-aeba-731fc8f145ef
Response status code: 502
Response content type: text/html
----------

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_TransformService_Direct #19

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

Changes:


------------------------------------------
[...truncated 774.19 KB...]
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:206: in run_pipeline
    _ = (
apache_beam/pipeline.py:600: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:577: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/direct/test_direct_runner.py:42: in run_pipeline
    self.result = super().run_pipeline(pipeline, options)
apache_beam/runners/direct/direct_runner.py:128: in run_pipeline
    return runner.run_pipeline(pipeline, options)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:202: in run_pipeline
    self._latest_run_result = self.run_via_runner_api(
apache_beam/runners/portability/fn_api_runner/fn_runner.py:224: in run_via_runner_api
    return self.run_stages(stage_context, stages)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:430: in run_stages
    runner_execution_context.setup()
apache_beam/runners/portability/fn_api_runner/execution.py:811: in setup
    self._enqueue_stage_initial_inputs(stage)
apache_beam/runners/portability/fn_api_runner/execution.py:840: in _enqueue_stage_initial_inputs
    bundle_manager.data_api_service_descriptor())
apache_beam/runners/portability/fn_api_runner/execution.py:1064: in data_api_service_descriptor
    return self.worker_handlers[0].data_api_service_descriptor()
apache_beam/runners/portability/fn_api_runner/execution.py:1056: in worker_handlers
    self.execution_context.worker_handler_manager.get_worker_handlers(
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:911: in get_worker_handlers
    worker_handler.start_worker()
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:770: in start_worker
    self._container_id = subprocess.check_output([
/usr/lib/python3.8/subprocess.py:415: in check_output
    return run(*popenargs, stdout=PIPE, timeout=timeout, check=True,
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

input = None, capture_output = False, timeout = None, check = True
popenargs = (['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_10', ...],)
kwargs = {'stdout': -1}, process = <subprocess.Popen object at 0x7f243080a0d0>
stdout = b'', stderr = None, retcode = 125

    def run(*popenargs,
            input=None, capture_output=False, timeout=None, check=False, **kwargs):
        """Run command with arguments and return a CompletedProcess instance.
    
        The returned instance will have attributes args, returncode, stdout and
        stderr. By default, stdout and stderr are not captured, and those attributes
        will be None. Pass stdout=PIPE and/or stderr=PIPE in order to capture them.
    
        If check is True and the exit code was non-zero, it raises a
        CalledProcessError. The CalledProcessError object will have the return code
        in the returncode attribute, and output & stderr attributes if those streams
        were captured.
    
        If timeout is given, and the process takes too long, a TimeoutExpired
        exception will be raised.
    
        There is an optional argument "input", allowing you to
        pass bytes or a string to the subprocess's stdin.  If you use this argument
        you may not also use the Popen constructor's "stdin" argument, as
        it will be used internally.
    
        By default, all communication is in bytes, and therefore any "input" should
        be bytes, and the stdout and stderr will be bytes. If in text mode, any
        "input" should be a string, and stdout and stderr will be strings decoded
        according to locale encoding, or by "encoding" if set. Text mode is
        triggered by setting any of text, encoding, errors or universal_newlines.
    
        The other arguments are the same as for the Popen constructor.
        """
        if input is not None:
            if kwargs.get('stdin') is not None:
                raise ValueError('stdin and input arguments may not both be used.')
            kwargs['stdin'] = PIPE
    
        if capture_output:
            if kwargs.get('stdout') is not None or kwargs.get('stderr') is not None:
                raise ValueError('stdout and stderr arguments may not be used '
                                 'with capture_output.')
            kwargs['stdout'] = PIPE
            kwargs['stderr'] = PIPE
    
        with Popen(*popenargs, **kwargs) as process:
            try:
                stdout, stderr = process.communicate(input, timeout=timeout)
            except TimeoutExpired as exc:
                process.kill()
                if _mswindows:
                    # Windows accumulates the output in a single blocking
                    # read() call run on child threads, with the timeout
                    # being done in a join() on those threads.  communicate()
                    # _after_ kill() is required to collect that and add it
                    # to the exception.
                    exc.stdout, exc.stderr = process.communicate()
                else:
                    # POSIX _communicate already populated the output so
                    # far into the TimeoutExpired exception.
                    process.wait()
                raise
            except:  # Including KeyboardInterrupt, communicate handled that.
                process.kill()
                # We don't call process.wait() as .__exit__ does that for us.
                raise
            retcode = process.poll()
            if check and retcode:
>               raise CalledProcessError(retcode, process.args,
                                         output=stdout, stderr=stderr)
E               subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_10', '--logging_endpoint=localhost:45821', '--control_endpoint=localhost:40621', '--artifact_endpoint=localhost:40621', '--provision_endpoint=localhost:40621']' returned non-zero exit status 125.

/usr/lib/python3.8/subprocess.py:516: CalledProcessError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:186 Created table [test-table-1692312732-eeca02]
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function annotate_downstream_side_inputs at 0x7f23fc0a8ca0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function fix_side_input_pcoll_coders at 0x7f23fc0a8dc0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function pack_combiners at 0x7f23fc0a9310> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function lift_combiners at 0x7f23fc0a93a0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_sdf at 0x7f23fc0a9550> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_gbk at 0x7f23fc0a95e0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sink_flattens at 0x7f23fc0a9700> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function greedily_fuse at 0x7f23fc0a9790> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function read_to_impulse at 0x7f23fc0a9820> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function impulse_to_input at 0x7f23fc0a98b0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sort_stages at 0x7f23fc0a9af0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function add_impulse_to_dangling_transforms at 0x7f23fc0a9c10> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function setup_timer_mapping at 0x7f23fc0a9a60> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function populate_data_channel_coders at 0x7f23fc0a9b80> ====================
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 104857600
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.EmbeddedWorkerHandler object at 0x7f23df05ed30> for environment ref_Environment_default_environment_2 (beam:env:embedded_python:v1, b'')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:510 starting control server on port 40621
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:511 starting data server on port 44055
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:512 starting state server on port 41493
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:513 starting logging server on port 45821
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f23df02a820> for environment external_6beam:env:docker:v1 (beam:env:docker:v1, b'\n!apache/beam_java11_sdk:2.51.0.dev')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:764 Attempting to pull image apache/beam_java11_sdk:2.51.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:767 Unable to pull image apache/beam_java11_sdk:2.51.0.dev, defaulting to local image if it exists
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:190 Deleting table [test-table-1692312732-eeca02]
---------------------------- Captured log teardown -----------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:198 Deleting instance [bt-write-xlang-1692312691-2e9848]
=============================== warnings summary ===============================
../../build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py:28
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py>:28: 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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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_TransformService_Direct/ws/src/sdks/python/pytest_transformService.xml> -
=========================== short test summary info ============================
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_0', '--logging_endpoint=localhost:44365', '--control_endpoint=localhost:38707', '--artifact_endpoint=localhost:38707', '--provision_endpoint=localhost:38707']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_2', '--logging_endpoint=localhost:32853', '--control_endpoint=localhost:46789', '--artifact_endpoint=localhost:46789', '--provision_endpoint=localhost:46789']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_4', '--logging_endpoint=localhost:33929', '--control_endpoint=localhost:40647', '--artifact_endpoint=localhost:40647', '--provision_endpoint=localhost:40647']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_6', '--logging_endpoint=localhost:35017', '--control_endpoint=localhost:44679', '--artifact_endpoint=localhost:44679', '--provision_endpoint=localhost:44679']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_8', '--logging_endpoint=localhost:45213', '--control_endpoint=localhost:33511', '--artifact_endpoint=localhost:33511', '--provision_endpoint=localhost:33511']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_10', '--logging_endpoint=localhost:45821', '--control_endpoint=localhost:40621', '--artifact_endpoint=localhost:40621', '--provision_endpoint=localhost:40621']' returned non-zero exit status 125.
==== 6 failed, 15 skipped, 6954 deselected, 51 warnings in 80.67s (0:01:20) ====

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

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

> Task :sdks:python:test-suites:direct:xlang:transformServiceCleanup
Stopping the transform service for project xlang at port 39841 for Beam version 2.51.0.dev  transform service startup jar is <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/java/transform-service/launcher/build/libs/beam-sdks-java-transform-service-launcher-2.51.0-SNAPSHOT.jar>

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava'.
> 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 9m 59s
159 actionable tasks: 112 executed, 38 from cache, 9 up-to-date

Publishing build scan...

Publishing failed.

The response from https://ge.apache.org/scans/publish/gradle/3.13.2/token was not from Gradle Enterprise.
The specified server address may be incorrect, or your network environment may be interfering.

Please report this problem to your Gradle Enterprise administrator via https://ge.apache.org/help and include the following via copy/paste:

----------
Gradle version: 7.6.2
Plugin version: 3.13.2
Request URL: https://ge.apache.org/scans/publish/gradle/3.13.2/token
Request ID: 56945ae4-4abb-45ef-8d64-9c497b0b5c2d
Response status code: 502
Response content type: text/html
----------

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_TransformService_Direct #18

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

Changes:

[noreply] Bump cloud.google.com/go/storage from 1.31.0 to 1.32.0 in /sdks (#28019)


------------------------------------------
[...truncated 754.69 KB...]
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:206: in run_pipeline
    _ = (
apache_beam/pipeline.py:600: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:577: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/direct/test_direct_runner.py:42: in run_pipeline
    self.result = super().run_pipeline(pipeline, options)
apache_beam/runners/direct/direct_runner.py:128: in run_pipeline
    return runner.run_pipeline(pipeline, options)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:202: in run_pipeline
    self._latest_run_result = self.run_via_runner_api(
apache_beam/runners/portability/fn_api_runner/fn_runner.py:224: in run_via_runner_api
    return self.run_stages(stage_context, stages)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:430: in run_stages
    runner_execution_context.setup()
apache_beam/runners/portability/fn_api_runner/execution.py:811: in setup
    self._enqueue_stage_initial_inputs(stage)
apache_beam/runners/portability/fn_api_runner/execution.py:840: in _enqueue_stage_initial_inputs
    bundle_manager.data_api_service_descriptor())
apache_beam/runners/portability/fn_api_runner/execution.py:1064: in data_api_service_descriptor
    return self.worker_handlers[0].data_api_service_descriptor()
apache_beam/runners/portability/fn_api_runner/execution.py:1056: in worker_handlers
    self.execution_context.worker_handler_manager.get_worker_handlers(
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:911: in get_worker_handlers
    worker_handler.start_worker()
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:770: in start_worker
    self._container_id = subprocess.check_output([
/usr/lib/python3.8/subprocess.py:415: in check_output
    return run(*popenargs, stdout=PIPE, timeout=timeout, check=True,
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

input = None, capture_output = False, timeout = None, check = True
popenargs = (['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_11', ...],)
kwargs = {'stdout': -1}, process = <subprocess.Popen object at 0x7f1a32760070>
stdout = b'', stderr = None, retcode = 125

    def run(*popenargs,
            input=None, capture_output=False, timeout=None, check=False, **kwargs):
        """Run command with arguments and return a CompletedProcess instance.
    
        The returned instance will have attributes args, returncode, stdout and
        stderr. By default, stdout and stderr are not captured, and those attributes
        will be None. Pass stdout=PIPE and/or stderr=PIPE in order to capture them.
    
        If check is True and the exit code was non-zero, it raises a
        CalledProcessError. The CalledProcessError object will have the return code
        in the returncode attribute, and output & stderr attributes if those streams
        were captured.
    
        If timeout is given, and the process takes too long, a TimeoutExpired
        exception will be raised.
    
        There is an optional argument "input", allowing you to
        pass bytes or a string to the subprocess's stdin.  If you use this argument
        you may not also use the Popen constructor's "stdin" argument, as
        it will be used internally.
    
        By default, all communication is in bytes, and therefore any "input" should
        be bytes, and the stdout and stderr will be bytes. If in text mode, any
        "input" should be a string, and stdout and stderr will be strings decoded
        according to locale encoding, or by "encoding" if set. Text mode is
        triggered by setting any of text, encoding, errors or universal_newlines.
    
        The other arguments are the same as for the Popen constructor.
        """
        if input is not None:
            if kwargs.get('stdin') is not None:
                raise ValueError('stdin and input arguments may not both be used.')
            kwargs['stdin'] = PIPE
    
        if capture_output:
            if kwargs.get('stdout') is not None or kwargs.get('stderr') is not None:
                raise ValueError('stdout and stderr arguments may not be used '
                                 'with capture_output.')
            kwargs['stdout'] = PIPE
            kwargs['stderr'] = PIPE
    
        with Popen(*popenargs, **kwargs) as process:
            try:
                stdout, stderr = process.communicate(input, timeout=timeout)
            except TimeoutExpired as exc:
                process.kill()
                if _mswindows:
                    # Windows accumulates the output in a single blocking
                    # read() call run on child threads, with the timeout
                    # being done in a join() on those threads.  communicate()
                    # _after_ kill() is required to collect that and add it
                    # to the exception.
                    exc.stdout, exc.stderr = process.communicate()
                else:
                    # POSIX _communicate already populated the output so
                    # far into the TimeoutExpired exception.
                    process.wait()
                raise
            except:  # Including KeyboardInterrupt, communicate handled that.
                process.kill()
                # We don't call process.wait() as .__exit__ does that for us.
                raise
            retcode = process.poll()
            if check and retcode:
>               raise CalledProcessError(retcode, process.args,
                                         output=stdout, stderr=stderr)
E               subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_11', '--logging_endpoint=localhost:41829', '--control_endpoint=localhost:40969', '--artifact_endpoint=localhost:40969', '--provision_endpoint=localhost:40969']' returned non-zero exit status 125.

/usr/lib/python3.8/subprocess.py:516: CalledProcessError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:186 Created table [test-table-1692291138-131155]
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function annotate_downstream_side_inputs at 0x7f19ffdf1ca0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function fix_side_input_pcoll_coders at 0x7f19ffdf1dc0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function pack_combiners at 0x7f19ffdf4310> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function lift_combiners at 0x7f19ffdf43a0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_sdf at 0x7f19ffdf4550> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_gbk at 0x7f19ffdf45e0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sink_flattens at 0x7f19ffdf4700> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function greedily_fuse at 0x7f19ffdf4790> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function read_to_impulse at 0x7f19ffdf4820> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function impulse_to_input at 0x7f19ffdf48b0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sort_stages at 0x7f19ffdf4af0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function add_impulse_to_dangling_transforms at 0x7f19ffdf4c10> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function setup_timer_mapping at 0x7f19ffdf4a60> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function populate_data_channel_coders at 0x7f19ffdf4b80> ====================
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 104857600
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.EmbeddedWorkerHandler object at 0x7f19e4dadb80> for environment ref_Environment_default_environment_2 (beam:env:embedded_python:v1, b'')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:510 starting control server on port 40969
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:511 starting data server on port 39287
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:512 starting state server on port 35351
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:513 starting logging server on port 41829
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f1a329d6af0> for environment external_6beam:env:docker:v1 (beam:env:docker:v1, b'\n!apache/beam_java11_sdk:2.51.0.dev')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:764 Attempting to pull image apache/beam_java11_sdk:2.51.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:767 Unable to pull image apache/beam_java11_sdk:2.51.0.dev, defaulting to local image if it exists
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:190 Deleting table [test-table-1692291138-131155]
---------------------------- Captured log teardown -----------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:198 Deleting instance [bt-write-xlang-1692291096-df700f]
=============================== warnings summary ===============================
../../build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py:28
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py>:28: 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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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_TransformService_Direct/ws/src/sdks/python/pytest_transformService.xml> -
=========================== short test summary info ============================
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_1', '--logging_endpoint=localhost:36251', '--control_endpoint=localhost:46315', '--artifact_endpoint=localhost:46315', '--provision_endpoint=localhost:46315']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_3', '--logging_endpoint=localhost:41749', '--control_endpoint=localhost:46825', '--artifact_endpoint=localhost:46825', '--provision_endpoint=localhost:46825']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_5', '--logging_endpoint=localhost:33457', '--control_endpoint=localhost:40599', '--artifact_endpoint=localhost:40599', '--provision_endpoint=localhost:40599']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_7', '--logging_endpoint=localhost:33183', '--control_endpoint=localhost:38479', '--artifact_endpoint=localhost:38479', '--provision_endpoint=localhost:38479']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_9', '--logging_endpoint=localhost:46437', '--control_endpoint=localhost:34989', '--artifact_endpoint=localhost:34989', '--provision_endpoint=localhost:34989']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_11', '--logging_endpoint=localhost:41829', '--control_endpoint=localhost:40969', '--artifact_endpoint=localhost:40969', '--provision_endpoint=localhost:40969']' returned non-zero exit status 125.
==== 6 failed, 15 skipped, 6954 deselected, 51 warnings in 83.28s (0:01:23) ====

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

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

> Task :sdks:python:test-suites:direct:xlang:transformServiceCleanup
Stopping the transform service for project xlang at port 46823 for Beam version 2.51.0.dev  transform service startup jar is <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/java/transform-service/launcher/build/libs/beam-sdks-java-transform-service-launcher-2.51.0-SNAPSHOT.jar>

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava'.
> 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 10m 1s
159 actionable tasks: 112 executed, 38 from cache, 9 up-to-date

Publishing build scan...

Publishing failed.

The response from https://ge.apache.org/scans/publish/gradle/3.13.2/token was not from Gradle Enterprise.
The specified server address may be incorrect, or your network environment may be interfering.

Please report this problem to your Gradle Enterprise administrator via https://ge.apache.org/help and include the following via copy/paste:

----------
Gradle version: 7.6.2
Plugin version: 3.13.2
Request URL: https://ge.apache.org/scans/publish/gradle/3.13.2/token
Request ID: 8ec7e2b7-d46e-401a-8cc7-dbd2662ce648
Response status code: 502
Response content type: text/html
----------

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_TransformService_Direct #17

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

Changes:


------------------------------------------
[...truncated 775.01 KB...]
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:206: in run_pipeline
    _ = (
apache_beam/pipeline.py:600: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:577: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/direct/test_direct_runner.py:42: in run_pipeline
    self.result = super().run_pipeline(pipeline, options)
apache_beam/runners/direct/direct_runner.py:128: in run_pipeline
    return runner.run_pipeline(pipeline, options)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:202: in run_pipeline
    self._latest_run_result = self.run_via_runner_api(
apache_beam/runners/portability/fn_api_runner/fn_runner.py:224: in run_via_runner_api
    return self.run_stages(stage_context, stages)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:430: in run_stages
    runner_execution_context.setup()
apache_beam/runners/portability/fn_api_runner/execution.py:811: in setup
    self._enqueue_stage_initial_inputs(stage)
apache_beam/runners/portability/fn_api_runner/execution.py:840: in _enqueue_stage_initial_inputs
    bundle_manager.data_api_service_descriptor())
apache_beam/runners/portability/fn_api_runner/execution.py:1064: in data_api_service_descriptor
    return self.worker_handlers[0].data_api_service_descriptor()
apache_beam/runners/portability/fn_api_runner/execution.py:1056: in worker_handlers
    self.execution_context.worker_handler_manager.get_worker_handlers(
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:911: in get_worker_handlers
    worker_handler.start_worker()
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:770: in start_worker
    self._container_id = subprocess.check_output([
/usr/lib/python3.8/subprocess.py:415: in check_output
    return run(*popenargs, stdout=PIPE, timeout=timeout, check=True,
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

input = None, capture_output = False, timeout = None, check = True
popenargs = (['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_10', ...],)
kwargs = {'stdout': -1}, process = <subprocess.Popen object at 0x7f317641acd0>
stdout = b'', stderr = None, retcode = 125

    def run(*popenargs,
            input=None, capture_output=False, timeout=None, check=False, **kwargs):
        """Run command with arguments and return a CompletedProcess instance.
    
        The returned instance will have attributes args, returncode, stdout and
        stderr. By default, stdout and stderr are not captured, and those attributes
        will be None. Pass stdout=PIPE and/or stderr=PIPE in order to capture them.
    
        If check is True and the exit code was non-zero, it raises a
        CalledProcessError. The CalledProcessError object will have the return code
        in the returncode attribute, and output & stderr attributes if those streams
        were captured.
    
        If timeout is given, and the process takes too long, a TimeoutExpired
        exception will be raised.
    
        There is an optional argument "input", allowing you to
        pass bytes or a string to the subprocess's stdin.  If you use this argument
        you may not also use the Popen constructor's "stdin" argument, as
        it will be used internally.
    
        By default, all communication is in bytes, and therefore any "input" should
        be bytes, and the stdout and stderr will be bytes. If in text mode, any
        "input" should be a string, and stdout and stderr will be strings decoded
        according to locale encoding, or by "encoding" if set. Text mode is
        triggered by setting any of text, encoding, errors or universal_newlines.
    
        The other arguments are the same as for the Popen constructor.
        """
        if input is not None:
            if kwargs.get('stdin') is not None:
                raise ValueError('stdin and input arguments may not both be used.')
            kwargs['stdin'] = PIPE
    
        if capture_output:
            if kwargs.get('stdout') is not None or kwargs.get('stderr') is not None:
                raise ValueError('stdout and stderr arguments may not be used '
                                 'with capture_output.')
            kwargs['stdout'] = PIPE
            kwargs['stderr'] = PIPE
    
        with Popen(*popenargs, **kwargs) as process:
            try:
                stdout, stderr = process.communicate(input, timeout=timeout)
            except TimeoutExpired as exc:
                process.kill()
                if _mswindows:
                    # Windows accumulates the output in a single blocking
                    # read() call run on child threads, with the timeout
                    # being done in a join() on those threads.  communicate()
                    # _after_ kill() is required to collect that and add it
                    # to the exception.
                    exc.stdout, exc.stderr = process.communicate()
                else:
                    # POSIX _communicate already populated the output so
                    # far into the TimeoutExpired exception.
                    process.wait()
                raise
            except:  # Including KeyboardInterrupt, communicate handled that.
                process.kill()
                # We don't call process.wait() as .__exit__ does that for us.
                raise
            retcode = process.poll()
            if check and retcode:
>               raise CalledProcessError(retcode, process.args,
                                         output=stdout, stderr=stderr)
E               subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_10', '--logging_endpoint=localhost:42919', '--control_endpoint=localhost:40055', '--artifact_endpoint=localhost:40055', '--provision_endpoint=localhost:40055']' returned non-zero exit status 125.

/usr/lib/python3.8/subprocess.py:516: CalledProcessError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:186 Created table [test-table-1692269551-880c07]
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function annotate_downstream_side_inputs at 0x7f3143c139d0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function fix_side_input_pcoll_coders at 0x7f3143c13af0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function pack_combiners at 0x7f3143c15040> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function lift_combiners at 0x7f3143c150d0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_sdf at 0x7f3143c15280> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_gbk at 0x7f3143c15310> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sink_flattens at 0x7f3143c15430> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function greedily_fuse at 0x7f3143c154c0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function read_to_impulse at 0x7f3143c15550> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function impulse_to_input at 0x7f3143c155e0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sort_stages at 0x7f3143c15820> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function add_impulse_to_dangling_transforms at 0x7f3143c15940> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function setup_timer_mapping at 0x7f3143c15790> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function populate_data_channel_coders at 0x7f3143c158b0> ====================
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 104857600
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.EmbeddedWorkerHandler object at 0x7f31767f6100> for environment ref_Environment_default_environment_2 (beam:env:embedded_python:v1, b'')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:510 starting control server on port 40055
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:511 starting data server on port 36731
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:512 starting state server on port 36445
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:513 starting logging server on port 42919
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f31764b89a0> for environment external_6beam:env:docker:v1 (beam:env:docker:v1, b'\n!apache/beam_java11_sdk:2.51.0.dev')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:764 Attempting to pull image apache/beam_java11_sdk:2.51.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:767 Unable to pull image apache/beam_java11_sdk:2.51.0.dev, defaulting to local image if it exists
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:190 Deleting table [test-table-1692269551-880c07]
---------------------------- Captured log teardown -----------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:198 Deleting instance [bt-write-xlang-1692269507-636140]
=============================== warnings summary ===============================
apache_beam/runners/portability/stager.py:63
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/python/apache_beam/runners/portability/stager.py>:63: 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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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/hdfs/config.py:28
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py>:28: 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:20
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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_TransformService_Direct/ws/src/sdks/python/pytest_transformService.xml> -
=========================== short test summary info ============================
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_0', '--logging_endpoint=localhost:41481', '--control_endpoint=localhost:42129', '--artifact_endpoint=localhost:42129', '--provision_endpoint=localhost:42129']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_2', '--logging_endpoint=localhost:41583', '--control_endpoint=localhost:41997', '--artifact_endpoint=localhost:41997', '--provision_endpoint=localhost:41997']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_4', '--logging_endpoint=localhost:45523', '--control_endpoint=localhost:44097', '--artifact_endpoint=localhost:44097', '--provision_endpoint=localhost:44097']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_6', '--logging_endpoint=localhost:34723', '--control_endpoint=localhost:36147', '--artifact_endpoint=localhost:36147', '--provision_endpoint=localhost:36147']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_8', '--logging_endpoint=localhost:40467', '--control_endpoint=localhost:41835', '--artifact_endpoint=localhost:41835', '--provision_endpoint=localhost:41835']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_10', '--logging_endpoint=localhost:42919', '--control_endpoint=localhost:40055', '--artifact_endpoint=localhost:40055', '--provision_endpoint=localhost:40055']' returned non-zero exit status 125.
==== 6 failed, 15 skipped, 6954 deselected, 51 warnings in 84.87s (0:01:24) ====

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

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

> Task :sdks:python:test-suites:direct:xlang:transformServiceCleanup
Stopping the transform service for project xlang at port 34377 for Beam version 2.51.0.dev  transform service startup jar is <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/java/transform-service/launcher/build/libs/beam-sdks-java-transform-service-launcher-2.51.0-SNAPSHOT.jar>

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava'.
> 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 10m 15s
159 actionable tasks: 112 executed, 38 from cache, 9 up-to-date

Publishing build scan...

Publishing failed.

The response from https://ge.apache.org/scans/publish/gradle/3.13.2/token was not from Gradle Enterprise.
The specified server address may be incorrect, or your network environment may be interfering.

Please report this problem to your Gradle Enterprise administrator via https://ge.apache.org/help and include the following via copy/paste:

----------
Gradle version: 7.6.2
Plugin version: 3.13.2
Request URL: https://ge.apache.org/scans/publish/gradle/3.13.2/token
Request ID: 1a166f61-421b-4de7-a401-f95249894018
Response status code: 502
Response content type: text/html
----------

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_TransformService_Direct #16

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

Changes:


------------------------------------------
[...truncated 760.41 KB...]
      row2_col1_cell = Cell(b'val2-1', 100_000_000)
      row2_col2_cell = Cell(b'val2-2', 200_000_000)
      # rows sent to write transform
      row1.set_cell(
          'col_fam', b'col-1', row1_col1_cell.value, row1_col1_cell.timestamp)
      row1.set_cell(
          'col_fam', b'col-2', row1_col2_cell.value, row1_col2_cell.timestamp)
      row2.set_cell(
          'col_fam', b'col-1', row2_col1_cell.value, row2_col1_cell.timestamp)
      row2.set_cell(
          'col_fam', b'col-2', row2_col2_cell.value, row2_col2_cell.timestamp)
    
>     self.run_pipeline([row1, row2])

apache_beam/io/gcp/bigtableio_it_test.py:236: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:206: in run_pipeline
    _ = (
apache_beam/pipeline.py:600: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:577: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/direct/test_direct_runner.py:42: in run_pipeline
    self.result = super().run_pipeline(pipeline, options)
apache_beam/runners/direct/direct_runner.py:128: in run_pipeline
    return runner.run_pipeline(pipeline, options)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:202: in run_pipeline
    self._latest_run_result = self.run_via_runner_api(
apache_beam/runners/portability/fn_api_runner/fn_runner.py:224: in run_via_runner_api
    return self.run_stages(stage_context, stages)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:430: in run_stages
    runner_execution_context.setup()
apache_beam/runners/portability/fn_api_runner/execution.py:811: in setup
    self._enqueue_stage_initial_inputs(stage)
apache_beam/runners/portability/fn_api_runner/execution.py:840: in _enqueue_stage_initial_inputs
    bundle_manager.data_api_service_descriptor())
apache_beam/runners/portability/fn_api_runner/execution.py:1064: in data_api_service_descriptor
    return self.worker_handlers[0].data_api_service_descriptor()
apache_beam/runners/portability/fn_api_runner/execution.py:1056: in worker_handlers
    self.execution_context.worker_handler_manager.get_worker_handlers(
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:911: in get_worker_handlers
    worker_handler.start_worker()
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:770: in start_worker
    self._container_id = subprocess.check_output([
/usr/lib/python3.8/subprocess.py:415: in check_output
    return run(*popenargs, stdout=PIPE, timeout=timeout, check=True,
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

input = None, capture_output = False, timeout = None, check = True
popenargs = (['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_10', ...],)
kwargs = {'stdout': -1}, process = <subprocess.Popen object at 0x7f02fa8141c0>
stdout = b'', stderr = None, retcode = 125

    def run(*popenargs,
            input=None, capture_output=False, timeout=None, check=False, **kwargs):
        """Run command with arguments and return a CompletedProcess instance.
    
        The returned instance will have attributes args, returncode, stdout and
        stderr. By default, stdout and stderr are not captured, and those attributes
        will be None. Pass stdout=PIPE and/or stderr=PIPE in order to capture them.
    
        If check is True and the exit code was non-zero, it raises a
        CalledProcessError. The CalledProcessError object will have the return code
        in the returncode attribute, and output & stderr attributes if those streams
        were captured.
    
        If timeout is given, and the process takes too long, a TimeoutExpired
        exception will be raised.
    
        There is an optional argument "input", allowing you to
        pass bytes or a string to the subprocess's stdin.  If you use this argument
        you may not also use the Popen constructor's "stdin" argument, as
        it will be used internally.
    
        By default, all communication is in bytes, and therefore any "input" should
        be bytes, and the stdout and stderr will be bytes. If in text mode, any
        "input" should be a string, and stdout and stderr will be strings decoded
        according to locale encoding, or by "encoding" if set. Text mode is
        triggered by setting any of text, encoding, errors or universal_newlines.
    
        The other arguments are the same as for the Popen constructor.
        """
        if input is not None:
            if kwargs.get('stdin') is not None:
                raise ValueError('stdin and input arguments may not both be used.')
            kwargs['stdin'] = PIPE
    
        if capture_output:
            if kwargs.get('stdout') is not None or kwargs.get('stderr') is not None:
                raise ValueError('stdout and stderr arguments may not be used '
                                 'with capture_output.')
            kwargs['stdout'] = PIPE
            kwargs['stderr'] = PIPE
    
        with Popen(*popenargs, **kwargs) as process:
            try:
                stdout, stderr = process.communicate(input, timeout=timeout)
            except TimeoutExpired as exc:
                process.kill()
                if _mswindows:
                    # Windows accumulates the output in a single blocking
                    # read() call run on child threads, with the timeout
                    # being done in a join() on those threads.  communicate()
                    # _after_ kill() is required to collect that and add it
                    # to the exception.
                    exc.stdout, exc.stderr = process.communicate()
                else:
                    # POSIX _communicate already populated the output so
                    # far into the TimeoutExpired exception.
                    process.wait()
                raise
            except:  # Including KeyboardInterrupt, communicate handled that.
                process.kill()
                # We don't call process.wait() as .__exit__ does that for us.
                raise
            retcode = process.poll()
            if check and retcode:
>               raise CalledProcessError(retcode, process.args,
                                         output=stdout, stderr=stderr)
E               subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_10', '--logging_endpoint=localhost:33225', '--control_endpoint=localhost:46139', '--artifact_endpoint=localhost:46139', '--provision_endpoint=localhost:46139']' returned non-zero exit status 125.

/usr/lib/python3.8/subprocess.py:516: CalledProcessError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:186 Created table [test-table-1692247953-9fb227]
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function annotate_downstream_side_inputs at 0x7f031937c9d0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function fix_side_input_pcoll_coders at 0x7f031937caf0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function pack_combiners at 0x7f031937e040> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function lift_combiners at 0x7f031937e0d0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_sdf at 0x7f031937e280> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_gbk at 0x7f031937e310> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sink_flattens at 0x7f031937e430> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function greedily_fuse at 0x7f031937e4c0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function read_to_impulse at 0x7f031937e550> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function impulse_to_input at 0x7f031937e5e0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sort_stages at 0x7f031937e820> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function add_impulse_to_dangling_transforms at 0x7f031937e940> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function setup_timer_mapping at 0x7f031937e790> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function populate_data_channel_coders at 0x7f031937e8b0> ====================
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 104857600
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.EmbeddedWorkerHandler object at 0x7f034bf2ab20> for environment ref_Environment_default_environment_2 (beam:env:embedded_python:v1, b'')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:510 starting control server on port 46139
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:511 starting data server on port 33347
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:512 starting state server on port 38769
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:513 starting logging server on port 33225
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f02fa814cd0> for environment external_6beam:env:docker:v1 (beam:env:docker:v1, b'\n!apache/beam_java11_sdk:2.51.0.dev')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:764 Attempting to pull image apache/beam_java11_sdk:2.51.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:767 Unable to pull image apache/beam_java11_sdk:2.51.0.dev, defaulting to local image if it exists
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:190 Deleting table [test-table-1692247953-9fb227]
---------------------------- Captured log teardown -----------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:198 Deleting instance [bt-write-xlang-1692247910-9d55bd]
=============================== warnings summary ===============================
apache_beam/runners/portability/stager.py:63
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/python/apache_beam/runners/portability/stager.py>:63: 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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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/hdfs/config.py:28
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py>:28: 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:20
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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_TransformService_Direct/ws/src/sdks/python/pytest_transformService.xml> -
=========================== short test summary info ============================
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_0', '--logging_endpoint=localhost:43149', '--control_endpoint=localhost:36397', '--artifact_endpoint=localhost:36397', '--provision_endpoint=localhost:36397']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_2', '--logging_endpoint=localhost:42175', '--control_endpoint=localhost:43085', '--artifact_endpoint=localhost:43085', '--provision_endpoint=localhost:43085']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_4', '--logging_endpoint=localhost:35637', '--control_endpoint=localhost:33443', '--artifact_endpoint=localhost:33443', '--provision_endpoint=localhost:33443']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_6', '--logging_endpoint=localhost:45165', '--control_endpoint=localhost:34733', '--artifact_endpoint=localhost:34733', '--provision_endpoint=localhost:34733']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_8', '--logging_endpoint=localhost:39735', '--control_endpoint=localhost:46443', '--artifact_endpoint=localhost:46443', '--provision_endpoint=localhost:46443']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_10', '--logging_endpoint=localhost:33225', '--control_endpoint=localhost:46139', '--artifact_endpoint=localhost:46139', '--provision_endpoint=localhost:46139']' returned non-zero exit status 125.
==== 6 failed, 15 skipped, 6954 deselected, 51 warnings in 80.65s (0:01:20) ====

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

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

> Task :sdks:python:test-suites:direct:xlang:transformServiceCleanup
Stopping the transform service for project xlang at port 45669 for Beam version 2.51.0.dev  transform service startup jar is <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/java/transform-service/launcher/build/libs/beam-sdks-java-transform-service-launcher-2.51.0-SNAPSHOT.jar>

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava'.
> 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 10m 20s
159 actionable tasks: 112 executed, 38 from cache, 9 up-to-date

Publishing build scan...
https://ge.apache.org/s/5mybtmgyaihoe

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_TransformService_Direct #15

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

Changes:


------------------------------------------
[...truncated 712.08 KB...]
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:186 Created table [test-table-1692226701-3cf794]
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:190 Deleting table [test-table-1692226701-3cf794]
_____________ TestWriteToBigtableXlangIT.test_delete_row_mutation ______________

self = <apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT testMethod=test_delete_row_mutation>

    def test_delete_row_mutation(self):
      write_row1: DirectRow = DirectRow('key-1', self.table)
      write_row2: DirectRow = DirectRow('key-2', self.table)
      col_fam = self.table.column_family('col_fam')
      col_fam.create()
      # write a couple of rows to the table beforehand
      write_row1.set_cell('col_fam', b'col', b'val-1')
      write_row1.commit()
      write_row2.set_cell('col_fam', b'col', b'val-2')
      write_row2.commit()
    
      # prepare a row that will delete itself
      delete_row: DirectRow = DirectRow('key-1')
      delete_row.delete()
    
>     self.run_pipeline([delete_row])

apache_beam/io/gcp/bigtableio_it_test.py:364: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:209: in run_pipeline
    | bigtableio.WriteToBigTable(
apache_beam/io/gcp/bigtableio.py:219: in __init__
    SchemaAwareExternalTransform.discover_config(
apache_beam/transforms/external.py:430: in discover_config
    for st in schematransforms:
apache_beam/transforms/external.py:402: in discover
    discover_response = service.DiscoverSchemaTransform(
../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1161: in __call__
    return _end_unary_response_blocking(state, call, False, None)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

state = <grpc._channel._RPCState object at 0x7f600703d130>
call = <grpc._cython.cygrpc.SegregatedCall object at 0x7f600730e780>
with_call = False, deadline = None

    def _end_unary_response_blocking(
        state: _RPCState,
        call: cygrpc.SegregatedCall,
        with_call: bool,
        deadline: Optional[float],
    ) -> Union[ResponseType, Tuple[ResponseType, grpc.Call]]:
        if state.code is grpc.StatusCode.OK:
            if with_call:
                rendezvous = _MultiThreadedRendezvous(state, call, None, deadline)
                return state.response, rendezvous
            else:
                return state.response
        else:
>           raise _InactiveRpcError(state)  # pytype: disable=not-instantiable
E           grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
E           	status = StatusCode.UNAVAILABLE
E           	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused"
E           	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused {grpc_status:14, created_time:"2023-08-16T22:58:36.996111653+00:00"}"
E           >

../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1004: _InactiveRpcError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:186 Created table [test-table-1692226708-794f9e]
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:190 Deleting table [test-table-1692226708-794f9e]
_________________ TestWriteToBigtableXlangIT.test_set_mutation _________________

self = <apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT testMethod=test_set_mutation>

    def test_set_mutation(self):
      row1: DirectRow = DirectRow('key-1')
      row2: DirectRow = DirectRow('key-2')
      col_fam = self.table.column_family('col_fam')
      col_fam.create()
      # expected cells
      row1_col1_cell = Cell(b'val1-1', 100_000_000)
      row1_col2_cell = Cell(b'val1-2', 200_000_000)
      row2_col1_cell = Cell(b'val2-1', 100_000_000)
      row2_col2_cell = Cell(b'val2-2', 200_000_000)
      # rows sent to write transform
      row1.set_cell(
          'col_fam', b'col-1', row1_col1_cell.value, row1_col1_cell.timestamp)
      row1.set_cell(
          'col_fam', b'col-2', row1_col2_cell.value, row1_col2_cell.timestamp)
      row2.set_cell(
          'col_fam', b'col-1', row2_col1_cell.value, row2_col1_cell.timestamp)
      row2.set_cell(
          'col_fam', b'col-2', row2_col2_cell.value, row2_col2_cell.timestamp)
    
>     self.run_pipeline([row1, row2])

apache_beam/io/gcp/bigtableio_it_test.py:236: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:209: in run_pipeline
    | bigtableio.WriteToBigTable(
apache_beam/io/gcp/bigtableio.py:219: in __init__
    SchemaAwareExternalTransform.discover_config(
apache_beam/transforms/external.py:430: in discover_config
    for st in schematransforms:
apache_beam/transforms/external.py:402: in discover
    discover_response = service.DiscoverSchemaTransform(
../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1161: in __call__
    return _end_unary_response_blocking(state, call, False, None)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

state = <grpc._channel._RPCState object at 0x7f60071abf10>
call = <grpc._cython.cygrpc.SegregatedCall object at 0x7f6007512cc0>
with_call = False, deadline = None

    def _end_unary_response_blocking(
        state: _RPCState,
        call: cygrpc.SegregatedCall,
        with_call: bool,
        deadline: Optional[float],
    ) -> Union[ResponseType, Tuple[ResponseType, grpc.Call]]:
        if state.code is grpc.StatusCode.OK:
            if with_call:
                rendezvous = _MultiThreadedRendezvous(state, call, None, deadline)
                return state.response, rendezvous
            else:
                return state.response
        else:
>           raise _InactiveRpcError(state)  # pytype: disable=not-instantiable
E           grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
E           	status = StatusCode.UNAVAILABLE
E           	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused"
E           	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused {created_time:"2023-08-16T22:58:41.199380985+00:00", grpc_status:14}"
E           >

../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1004: _InactiveRpcError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:186 Created table [test-table-1692226717-ba798e]
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:190 Deleting table [test-table-1692226717-ba798e]
---------------------------- Captured log teardown -----------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:198 Deleting instance [bt-write-xlang-1692226688-c9e791]
=============================== warnings summary ===============================
apache_beam/runners/portability/stager.py:63
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/python/apache_beam/runners/portability/stager.py>:63: 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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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/hdfs/config.py:28
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py>:28: 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:20
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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__)

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/python/pytest_transformService.xml> -
=========================== short test summary info ============================
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang - grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused"
	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused {created_time:"2023-08-16T22:58:06.375159492+00:00", grpc_status:14}"
>
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation - grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused"
	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused {created_time:"2023-08-16T22:58:16.87219418+00:00", grpc_status:14}"
>
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation - grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused"
	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused {created_time:"2023-08-16T22:58:21.123657587+00:00", grpc_status:14}"
>
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation - grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused"
	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused {grpc_status:14, created_time:"2023-08-16T22:58:27.90304583+00:00"}"
>
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation - grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused"
	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused {grpc_status:14, created_time:"2023-08-16T22:58:36.996111653+00:00"}"
>
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation - grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused"
	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:44133: Failed to connect to remote host: Connection refused {created_time:"2023-08-16T22:58:41.199380985+00:00", grpc_status:14}"
>
==== 6 failed, 15 skipped, 6954 deselected, 45 warnings in 90.11s (0:01:30) ====

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

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

> Task :sdks:python:test-suites:direct:xlang:transformServiceCleanup
Stopping the transform service for project xlang at port 44133 for Beam version 2.51.0.dev  transform service startup jar is <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/java/transform-service/launcher/build/libs/beam-sdks-java-transform-service-launcher-2.51.0-SNAPSHOT.jar>

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava'.
> 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 14m 40s
159 actionable tasks: 112 executed, 38 from cache, 9 up-to-date

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

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_TransformService_Direct #14

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

Changes:


------------------------------------------
Started by user Chamikara Madhusanka Jayalath
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-3 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Using shallow clone with depth 1
Avoid fetching tags
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.25.1'
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Using shallow fetch with depth 1
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse refs/remotes/origin/pr/28039/head^{commit} # timeout=10
 > git rev-parse origin/pr/28039/head^{commit} # timeout=10
ERROR: Couldn't find any revision to build. Verify the repository and branch configuration for this job.

---------------------------------------------------------------------
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_TransformService_Direct #13

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

Changes:


------------------------------------------
[...truncated 762.39 KB...]
apache_beam/pipeline.py:577: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/direct/test_direct_runner.py:42: in run_pipeline
    self.result = super().run_pipeline(pipeline, options)
apache_beam/runners/direct/direct_runner.py:128: in run_pipeline
    return runner.run_pipeline(pipeline, options)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:202: in run_pipeline
    self._latest_run_result = self.run_via_runner_api(
apache_beam/runners/portability/fn_api_runner/fn_runner.py:224: in run_via_runner_api
    return self.run_stages(stage_context, stages)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:430: in run_stages
    runner_execution_context.setup()
apache_beam/runners/portability/fn_api_runner/execution.py:811: in setup
    self._enqueue_stage_initial_inputs(stage)
apache_beam/runners/portability/fn_api_runner/execution.py:840: in _enqueue_stage_initial_inputs
    bundle_manager.data_api_service_descriptor())
apache_beam/runners/portability/fn_api_runner/execution.py:1064: in data_api_service_descriptor
    return self.worker_handlers[0].data_api_service_descriptor()
apache_beam/runners/portability/fn_api_runner/execution.py:1056: in worker_handlers
    self.execution_context.worker_handler_manager.get_worker_handlers(
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:911: in get_worker_handlers
    worker_handler.start_worker()
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:770: in start_worker
    self._container_id = subprocess.check_output([
/usr/lib/python3.8/subprocess.py:415: in check_output
    return run(*popenargs, stdout=PIPE, timeout=timeout, check=True,
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

input = None, capture_output = False, timeout = None, check = True
popenargs = (['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_11', ...],)
kwargs = {'stdout': -1}, process = <subprocess.Popen object at 0x7f1fdf005b20>
stdout = b'', stderr = None, retcode = 125

    def run(*popenargs,
            input=None, capture_output=False, timeout=None, check=False, **kwargs):
        """Run command with arguments and return a CompletedProcess instance.
    
        The returned instance will have attributes args, returncode, stdout and
        stderr. By default, stdout and stderr are not captured, and those attributes
        will be None. Pass stdout=PIPE and/or stderr=PIPE in order to capture them.
    
        If check is True and the exit code was non-zero, it raises a
        CalledProcessError. The CalledProcessError object will have the return code
        in the returncode attribute, and output & stderr attributes if those streams
        were captured.
    
        If timeout is given, and the process takes too long, a TimeoutExpired
        exception will be raised.
    
        There is an optional argument "input", allowing you to
        pass bytes or a string to the subprocess's stdin.  If you use this argument
        you may not also use the Popen constructor's "stdin" argument, as
        it will be used internally.
    
        By default, all communication is in bytes, and therefore any "input" should
        be bytes, and the stdout and stderr will be bytes. If in text mode, any
        "input" should be a string, and stdout and stderr will be strings decoded
        according to locale encoding, or by "encoding" if set. Text mode is
        triggered by setting any of text, encoding, errors or universal_newlines.
    
        The other arguments are the same as for the Popen constructor.
        """
        if input is not None:
            if kwargs.get('stdin') is not None:
                raise ValueError('stdin and input arguments may not both be used.')
            kwargs['stdin'] = PIPE
    
        if capture_output:
            if kwargs.get('stdout') is not None or kwargs.get('stderr') is not None:
                raise ValueError('stdout and stderr arguments may not be used '
                                 'with capture_output.')
            kwargs['stdout'] = PIPE
            kwargs['stderr'] = PIPE
    
        with Popen(*popenargs, **kwargs) as process:
            try:
                stdout, stderr = process.communicate(input, timeout=timeout)
            except TimeoutExpired as exc:
                process.kill()
                if _mswindows:
                    # Windows accumulates the output in a single blocking
                    # read() call run on child threads, with the timeout
                    # being done in a join() on those threads.  communicate()
                    # _after_ kill() is required to collect that and add it
                    # to the exception.
                    exc.stdout, exc.stderr = process.communicate()
                else:
                    # POSIX _communicate already populated the output so
                    # far into the TimeoutExpired exception.
                    process.wait()
                raise
            except:  # Including KeyboardInterrupt, communicate handled that.
                process.kill()
                # We don't call process.wait() as .__exit__ does that for us.
                raise
            retcode = process.poll()
            if check and retcode:
>               raise CalledProcessError(retcode, process.args,
                                         output=stdout, stderr=stderr)
E               subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_11', '--logging_endpoint=localhost:41765', '--control_endpoint=localhost:46171', '--artifact_endpoint=localhost:46171', '--provision_endpoint=localhost:46171']' returned non-zero exit status 125.

/usr/lib/python3.8/subprocess.py:516: CalledProcessError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:186 Created table [test-table-1692204742-405f3e]
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function annotate_downstream_side_inputs at 0x7f1faaebf3a0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function fix_side_input_pcoll_coders at 0x7f1faaebf4c0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function pack_combiners at 0x7f1faaebf9d0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function lift_combiners at 0x7f1faaebfa60> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_sdf at 0x7f1faaebfc10> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_gbk at 0x7f1faaebfca0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sink_flattens at 0x7f1faaebfdc0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function greedily_fuse at 0x7f1faaebfe50> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function read_to_impulse at 0x7f1faaebfee0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function impulse_to_input at 0x7f1faaebff70> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sort_stages at 0x7f1faaec01f0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function add_impulse_to_dangling_transforms at 0x7f1faaec0310> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function setup_timer_mapping at 0x7f1faaec0160> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function populate_data_channel_coders at 0x7f1faaec0280> ====================
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 104857600
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.EmbeddedWorkerHandler object at 0x7f1fdfc8cac0> for environment ref_Environment_default_environment_2 (beam:env:embedded_python:v1, b'')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:510 starting control server on port 46171
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:511 starting data server on port 41025
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:512 starting state server on port 46143
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:513 starting logging server on port 41765
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f1fdee4deb0> for environment external_6beam:env:docker:v1 (beam:env:docker:v1, b'\n!apache/beam_java11_sdk:2.51.0.dev')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:764 Attempting to pull image apache/beam_java11_sdk:2.51.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:767 Unable to pull image apache/beam_java11_sdk:2.51.0.dev, defaulting to local image if it exists
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:190 Deleting table [test-table-1692204742-405f3e]
---------------------------- Captured log teardown -----------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:198 Deleting instance [bt-write-xlang-1692204704-040b79]
=============================== warnings summary ===============================
apache_beam/runners/portability/stager.py:63
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/python/apache_beam/runners/portability/stager.py>:63: 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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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/hdfs/config.py:28
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py>:28: 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:20
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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/io/external/xlang_kafkaio_it_test.py:146
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/python/apache_beam/io/external/xlang_kafkaio_it_test.py>:146: PytestUnknownMarkWarning: Unknown pytest.mark.uses_io_expansion_service - is this a typo?  You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/how-to/mark.html
    @pytest.mark.uses_io_expansion_service

apache_beam/io/external/xlang_kafkaio_it_test.py:165
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/python/apache_beam/io/external/xlang_kafkaio_it_test.py>:165: PytestUnknownMarkWarning: Unknown pytest.mark.uses_io_expansion_service - is this a typo?  You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/how-to/mark.html
    @pytest.mark.uses_io_expansion_service

apache_beam/typehints/pandas_type_compatibility_test.py:67
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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_TransformService_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_TransformService_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/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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_TransformService_Direct/ws/src/sdks/python/pytest_transformService.xml> -
=========================== short test summary info ============================
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_1', '--logging_endpoint=localhost:41651', '--control_endpoint=localhost:43087', '--artifact_endpoint=localhost:43087', '--provision_endpoint=localhost:43087']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_3', '--logging_endpoint=localhost:34967', '--control_endpoint=localhost:38703', '--artifact_endpoint=localhost:38703', '--provision_endpoint=localhost:38703']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_5', '--logging_endpoint=localhost:40495', '--control_endpoint=localhost:35337', '--artifact_endpoint=localhost:35337', '--provision_endpoint=localhost:35337']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_7', '--logging_endpoint=localhost:34981', '--control_endpoint=localhost:33147', '--artifact_endpoint=localhost:33147', '--provision_endpoint=localhost:33147']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_9', '--logging_endpoint=localhost:35225', '--control_endpoint=localhost:39961', '--artifact_endpoint=localhost:39961', '--provision_endpoint=localhost:39961']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_11', '--logging_endpoint=localhost:41765', '--control_endpoint=localhost:46171', '--artifact_endpoint=localhost:46171', '--provision_endpoint=localhost:46171']' returned non-zero exit status 125.
==== 6 failed, 15 skipped, 6954 deselected, 56 warnings in 77.83s (0:01:17) ====

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

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

> Task :sdks:python:test-suites:direct:xlang:transformServiceCleanup
Stopping the transform service for project xlang at port 40991 for Beam version 2.51.0.dev  transform service startup jar is <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/java/transform-service/launcher/build/libs/beam-sdks-java-transform-service-launcher-2.51.0-SNAPSHOT.jar>

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava'.
> 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 10m 12s
159 actionable tasks: 112 executed, 38 from cache, 9 up-to-date

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

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_TransformService_Direct #12

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

Changes:


------------------------------------------
[...truncated 691.85 KB...]
    
>     self.run_pipeline([delete_row])

apache_beam/io/gcp/bigtableio_it_test.py:364: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:209: in run_pipeline
    | bigtableio.WriteToBigTable(
apache_beam/io/gcp/bigtableio.py:219: in __init__
    SchemaAwareExternalTransform.discover_config(
apache_beam/transforms/external.py:430: in discover_config
    for st in schematransforms:
apache_beam/transforms/external.py:402: in discover
    discover_response = service.DiscoverSchemaTransform(
../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1161: in __call__
    return _end_unary_response_blocking(state, call, False, None)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

state = <grpc._channel._RPCState object at 0x7f88093cc4c0>
call = <grpc._cython.cygrpc.SegregatedCall object at 0x7f88094bae00>
with_call = False, deadline = None

    def _end_unary_response_blocking(
        state: _RPCState,
        call: cygrpc.SegregatedCall,
        with_call: bool,
        deadline: Optional[float],
    ) -> Union[ResponseType, Tuple[ResponseType, grpc.Call]]:
        if state.code is grpc.StatusCode.OK:
            if with_call:
                rendezvous = _MultiThreadedRendezvous(state, call, None, deadline)
                return state.response, rendezvous
            else:
                return state.response
        else:
>           raise _InactiveRpcError(state)  # pytype: disable=not-instantiable
E           grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
E           	status = StatusCode.UNAVAILABLE
E           	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused"
E           	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused {grpc_status:14, created_time:"2023-08-16T10:52:44.018330868+00:00"}"
E           >

../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1004: _InactiveRpcError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:186 Created table [test-table-1692183158-553a7b]
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:190 Deleting table [test-table-1692183158-553a7b]
_________________ TestWriteToBigtableXlangIT.test_set_mutation _________________

self = <apache_beam.io.gcp.bigtableio_it_test.TestWriteToBigtableXlangIT testMethod=test_set_mutation>

    def test_set_mutation(self):
      row1: DirectRow = DirectRow('key-1')
      row2: DirectRow = DirectRow('key-2')
      col_fam = self.table.column_family('col_fam')
      col_fam.create()
      # expected cells
      row1_col1_cell = Cell(b'val1-1', 100_000_000)
      row1_col2_cell = Cell(b'val1-2', 200_000_000)
      row2_col1_cell = Cell(b'val2-1', 100_000_000)
      row2_col2_cell = Cell(b'val2-2', 200_000_000)
      # rows sent to write transform
      row1.set_cell(
          'col_fam', b'col-1', row1_col1_cell.value, row1_col1_cell.timestamp)
      row1.set_cell(
          'col_fam', b'col-2', row1_col2_cell.value, row1_col2_cell.timestamp)
      row2.set_cell(
          'col_fam', b'col-1', row2_col1_cell.value, row2_col1_cell.timestamp)
      row2.set_cell(
          'col_fam', b'col-2', row2_col2_cell.value, row2_col2_cell.timestamp)
    
>     self.run_pipeline([row1, row2])

apache_beam/io/gcp/bigtableio_it_test.py:236: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/io/gcp/bigtableio_it_test.py:209: in run_pipeline
    | bigtableio.WriteToBigTable(
apache_beam/io/gcp/bigtableio.py:219: in __init__
    SchemaAwareExternalTransform.discover_config(
apache_beam/transforms/external.py:430: in discover_config
    for st in schematransforms:
apache_beam/transforms/external.py:402: in discover
    discover_response = service.DiscoverSchemaTransform(
../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1161: in __call__
    return _end_unary_response_blocking(state, call, False, None)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

state = <grpc._channel._RPCState object at 0x7f88093f7eb0>
call = <grpc._cython.cygrpc.SegregatedCall object at 0x7f88094373c0>
with_call = False, deadline = None

    def _end_unary_response_blocking(
        state: _RPCState,
        call: cygrpc.SegregatedCall,
        with_call: bool,
        deadline: Optional[float],
    ) -> Union[ResponseType, Tuple[ResponseType, grpc.Call]]:
        if state.code is grpc.StatusCode.OK:
            if with_call:
                rendezvous = _MultiThreadedRendezvous(state, call, None, deadline)
                return state.response, rendezvous
            else:
                return state.response
        else:
>           raise _InactiveRpcError(state)  # pytype: disable=not-instantiable
E           grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
E           	status = StatusCode.UNAVAILABLE
E           	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused"
E           	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused {grpc_status:14, created_time:"2023-08-16T10:52:47.729090655+00:00"}"
E           >

../../build/gradleenv/1922375555/lib/python3.8/site-packages/grpc/_channel.py:1004: _InactiveRpcError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:186 Created table [test-table-1692183164-382916]
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:190 Deleting table [test-table-1692183164-382916]
---------------------------- Captured log teardown -----------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:198 Deleting instance [bt-write-xlang-1692183135-2cd813]
=============================== warnings summary ===============================
apache_beam/runners/portability/stager.py:63
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/python/apache_beam/runners/portability/stager.py>:63: 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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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/hdfs/config.py:28
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py>:28: 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:20
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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/io/external/xlang_kafkaio_it_test.py:146
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/python/apache_beam/io/external/xlang_kafkaio_it_test.py>:146: PytestUnknownMarkWarning: Unknown pytest.mark.uses_io_expansion_service - is this a typo?  You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/how-to/mark.html
    @pytest.mark.uses_io_expansion_service

apache_beam/io/external/xlang_kafkaio_it_test.py:165
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/python/apache_beam/io/external/xlang_kafkaio_it_test.py>:165: PytestUnknownMarkWarning: Unknown pytest.mark.uses_io_expansion_service - is this a typo?  You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/how-to/mark.html
    @pytest.mark.uses_io_expansion_service

apache_beam/typehints/pandas_type_compatibility_test.py:67
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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_TransformService_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_TransformService_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'),

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/python/pytest_transformService.xml> -
=========================== short test summary info ============================
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang - grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused"
	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused {created_time:"2023-08-16T10:52:14.476232169+00:00", grpc_status:14}"
>
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation - grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused"
	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused {created_time:"2023-08-16T10:52:27.486098825+00:00", grpc_status:14}"
>
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation - grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused"
	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused {grpc_status:14, created_time:"2023-08-16T10:52:31.576280372+00:00"}"
>
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation - grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused"
	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused {created_time:"2023-08-16T10:52:38.676992459+00:00", grpc_status:14}"
>
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation - grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused"
	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused {grpc_status:14, created_time:"2023-08-16T10:52:44.018330868+00:00"}"
>
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation - grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused"
	debug_error_string = "UNKNOWN:failed to connect to all addresses; last error: UNKNOWN: ipv4:127.0.0.1:45175: Failed to connect to remote host: Connection refused {grpc_status:14, created_time:"2023-08-16T10:52:47.729090655+00:00"}"
>
========= 6 failed, 15 skipped, 6953 deselected, 50 warnings in 56.12s =========

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

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

> Task :sdks:python:test-suites:direct:xlang:transformServiceCleanup
Stopping the transform service for project xlang at port 45175 for Beam version 2.51.0.dev  transform service startup jar is <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/java/transform-service/launcher/build/libs/beam-sdks-java-transform-service-launcher-2.51.0-SNAPSHOT.jar>

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava'.
> 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 10m 25s
159 actionable tasks: 112 executed, 38 from cache, 9 up-to-date

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

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_TransformService_Direct #11

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

Changes:


------------------------------------------
[...truncated 784.42 KB...]
apache_beam/pipeline.py:577: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/direct/test_direct_runner.py:42: in run_pipeline
    self.result = super().run_pipeline(pipeline, options)
apache_beam/runners/direct/direct_runner.py:128: in run_pipeline
    return runner.run_pipeline(pipeline, options)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:202: in run_pipeline
    self._latest_run_result = self.run_via_runner_api(
apache_beam/runners/portability/fn_api_runner/fn_runner.py:224: in run_via_runner_api
    return self.run_stages(stage_context, stages)
apache_beam/runners/portability/fn_api_runner/fn_runner.py:430: in run_stages
    runner_execution_context.setup()
apache_beam/runners/portability/fn_api_runner/execution.py:811: in setup
    self._enqueue_stage_initial_inputs(stage)
apache_beam/runners/portability/fn_api_runner/execution.py:840: in _enqueue_stage_initial_inputs
    bundle_manager.data_api_service_descriptor())
apache_beam/runners/portability/fn_api_runner/execution.py:1064: in data_api_service_descriptor
    return self.worker_handlers[0].data_api_service_descriptor()
apache_beam/runners/portability/fn_api_runner/execution.py:1056: in worker_handlers
    self.execution_context.worker_handler_manager.get_worker_handlers(
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:911: in get_worker_handlers
    worker_handler.start_worker()
apache_beam/runners/portability/fn_api_runner/worker_handlers.py:770: in start_worker
    self._container_id = subprocess.check_output([
/usr/lib/python3.8/subprocess.py:415: in check_output
    return run(*popenargs, stdout=PIPE, timeout=timeout, check=True,
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

input = None, capture_output = False, timeout = None, check = True
popenargs = (['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_11', ...],)
kwargs = {'stdout': -1}, process = <subprocess.Popen object at 0x7f05a30541c0>
stdout = b'', stderr = None, retcode = 125

    def run(*popenargs,
            input=None, capture_output=False, timeout=None, check=False, **kwargs):
        """Run command with arguments and return a CompletedProcess instance.
    
        The returned instance will have attributes args, returncode, stdout and
        stderr. By default, stdout and stderr are not captured, and those attributes
        will be None. Pass stdout=PIPE and/or stderr=PIPE in order to capture them.
    
        If check is True and the exit code was non-zero, it raises a
        CalledProcessError. The CalledProcessError object will have the return code
        in the returncode attribute, and output & stderr attributes if those streams
        were captured.
    
        If timeout is given, and the process takes too long, a TimeoutExpired
        exception will be raised.
    
        There is an optional argument "input", allowing you to
        pass bytes or a string to the subprocess's stdin.  If you use this argument
        you may not also use the Popen constructor's "stdin" argument, as
        it will be used internally.
    
        By default, all communication is in bytes, and therefore any "input" should
        be bytes, and the stdout and stderr will be bytes. If in text mode, any
        "input" should be a string, and stdout and stderr will be strings decoded
        according to locale encoding, or by "encoding" if set. Text mode is
        triggered by setting any of text, encoding, errors or universal_newlines.
    
        The other arguments are the same as for the Popen constructor.
        """
        if input is not None:
            if kwargs.get('stdin') is not None:
                raise ValueError('stdin and input arguments may not both be used.')
            kwargs['stdin'] = PIPE
    
        if capture_output:
            if kwargs.get('stdout') is not None or kwargs.get('stderr') is not None:
                raise ValueError('stdout and stderr arguments may not be used '
                                 'with capture_output.')
            kwargs['stdout'] = PIPE
            kwargs['stderr'] = PIPE
    
        with Popen(*popenargs, **kwargs) as process:
            try:
                stdout, stderr = process.communicate(input, timeout=timeout)
            except TimeoutExpired as exc:
                process.kill()
                if _mswindows:
                    # Windows accumulates the output in a single blocking
                    # read() call run on child threads, with the timeout
                    # being done in a join() on those threads.  communicate()
                    # _after_ kill() is required to collect that and add it
                    # to the exception.
                    exc.stdout, exc.stderr = process.communicate()
                else:
                    # POSIX _communicate already populated the output so
                    # far into the TimeoutExpired exception.
                    process.wait()
                raise
            except:  # Including KeyboardInterrupt, communicate handled that.
                process.kill()
                # We don't call process.wait() as .__exit__ does that for us.
                raise
            retcode = process.poll()
            if check and retcode:
>               raise CalledProcessError(retcode, process.args,
                                         output=stdout, stderr=stderr)
E               subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_11', '--logging_endpoint=localhost:34497', '--control_endpoint=localhost:45057', '--artifact_endpoint=localhost:45057', '--provision_endpoint=localhost:45057']' returned non-zero exit status 125.

/usr/lib/python3.8/subprocess.py:516: CalledProcessError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:186 Created table [test-table-1692161587-264582]
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function annotate_downstream_side_inputs at 0x7f056e3fd3a0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function fix_side_input_pcoll_coders at 0x7f056e3fd4c0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function pack_combiners at 0x7f056e3fd9d0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function lift_combiners at 0x7f056e3fda60> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_sdf at 0x7f056e3fdc10> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function expand_gbk at 0x7f056e3fdca0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sink_flattens at 0x7f056e3fddc0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function greedily_fuse at 0x7f056e3fde50> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function read_to_impulse at 0x7f056e3fdee0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function impulse_to_input at 0x7f056e3fdf70> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function sort_stages at 0x7f056e4011f0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function add_impulse_to_dangling_transforms at 0x7f056e401310> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function setup_timer_mapping at 0x7f056e401160> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:710 ==================== <function populate_data_channel_coders at 0x7f056e401280> ====================
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 104857600
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.EmbeddedWorkerHandler object at 0x7f054fc7f6d0> for environment ref_Environment_default_environment_2 (beam:env:embedded_python:v1, b'')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:510 starting control server on port 45057
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:511 starting data server on port 40979
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:512 starting state server on port 38905
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:513 starting logging server on port 34497
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:903 Created Worker handler <apache_beam.runners.portability.fn_api_runner.worker_handlers.DockerSdkWorkerHandler object at 0x7f054fc301f0> for environment external_6beam:env:docker:v1 (beam:env:docker:v1, b'\n!apache/beam_java11_sdk:2.51.0.dev')
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:764 Attempting to pull image apache/beam_java11_sdk:2.51.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.worker_handlers:worker_handlers.py:767 Unable to pull image apache/beam_java11_sdk:2.51.0.dev, defaulting to local image if it exists
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:190 Deleting table [test-table-1692161587-264582]
---------------------------- Captured log teardown -----------------------------
INFO     apache_beam.io.gcp.bigtableio_it_test:bigtableio_it_test.py:198 Deleting instance [bt-write-xlang-1692161542-dcdd88]
=============================== warnings summary ===============================
apache_beam/runners/portability/stager.py:63
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/python/apache_beam/runners/portability/stager.py>:63: 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_TransformService_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_TransformService_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_TransformService_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_TransformService_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_TransformService_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/hdfs/config.py:28
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/build/gradleenv/1922375555/lib/python3.8/site-packages/hdfs/config.py>:28: 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:20
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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/io/external/xlang_kafkaio_it_test.py:146
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/python/apache_beam/io/external/xlang_kafkaio_it_test.py>:146: PytestUnknownMarkWarning: Unknown pytest.mark.uses_io_expansion_service - is this a typo?  You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/how-to/mark.html
    @pytest.mark.uses_io_expansion_service

apache_beam/io/external/xlang_kafkaio_it_test.py:165
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/python/apache_beam/io/external/xlang_kafkaio_it_test.py>:165: PytestUnknownMarkWarning: Unknown pytest.mark.uses_io_expansion_service - is this a typo?  You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/how-to/mark.html
    @pytest.mark.uses_io_expansion_service

apache_beam/typehints/pandas_type_compatibility_test.py:67
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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_TransformService_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_TransformService_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/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation
apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation
  <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_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_TransformService_Direct/ws/src/sdks/python/pytest_transformService.xml> -
=========================== short test summary info ============================
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestReadFromBigTableIT::test_read_xlang - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_1', '--logging_endpoint=localhost:43643', '--control_endpoint=localhost:45753', '--artifact_endpoint=localhost:45753', '--provision_endpoint=localhost:45753']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_3', '--logging_endpoint=localhost:44411', '--control_endpoint=localhost:36023', '--artifact_endpoint=localhost:36023', '--provision_endpoint=localhost:36023']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_cells_with_timerange_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_5', '--logging_endpoint=localhost:41585', '--control_endpoint=localhost:44783', '--artifact_endpoint=localhost:44783', '--provision_endpoint=localhost:44783']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_column_family_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_7', '--logging_endpoint=localhost:43041', '--control_endpoint=localhost:42419', '--artifact_endpoint=localhost:42419', '--provision_endpoint=localhost:42419']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_delete_row_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_9', '--logging_endpoint=localhost:44745', '--control_endpoint=localhost:44385', '--artifact_endpoint=localhost:44385', '--provision_endpoint=localhost:44385']' returned non-zero exit status 125.
FAILED apache_beam/io/gcp/bigtableio_it_test.py::TestWriteToBigtableXlangIT::test_set_mutation - subprocess.CalledProcessError: Command '['docker', 'run', '-d', '--network=host', 'apache/beam_java11_sdk:2.51.0.dev', '--id=worker_11', '--logging_endpoint=localhost:34497', '--control_endpoint=localhost:45057', '--artifact_endpoint=localhost:45057', '--provision_endpoint=localhost:45057']' returned non-zero exit status 125.
==== 6 failed, 15 skipped, 6953 deselected, 56 warnings in 92.00s (0:01:31) ====

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

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

> Task :sdks:python:test-suites:direct:xlang:transformServiceCleanup
Stopping the transform service for project xlang at port 34977 for Beam version 2.51.0.dev  transform service startup jar is <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/sdks/java/transform-service/launcher/build/libs/beam-sdks-java-transform-service-launcher-2.51.0-SNAPSHOT.jar>

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava'.
> 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 11m 6s
159 actionable tasks: 113 executed, 37 from cache, 9 up-to-date

Publishing build scan...
https://ge.apache.org/s/4lz3uvrea4joq

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_TransformService_Direct #10

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

Changes:

[noreply] Exclude StorageApiSinkSchemaUpdate integration tests from dataflow


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-12 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Using shallow clone with depth 1
Avoid fetching tags
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.25.1'
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Using shallow fetch with depth 1
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 0a7b99966cb14dfcb3422dcb1c594d026a2ec2d9 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 0a7b99966cb14dfcb3422dcb1c594d026a2ec2d9 # timeout=10
Commit message: "Exclude StorageApiSinkSchemaUpdate integration tests from dataflow postcommit (#27928)"
 > git rev-list --no-walk a0a297dddaae1ec45c514bffb7977772cb42d528 # timeout=10
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SETUPTOOLS_USE_DISTUTILS=stdlib
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_TransformService_Direct] $ /bin/bash -xe /tmp/jenkins8700603607023076204.sh
+ echo '*** RUN TRANSFORM SERVICE DIRECT USING PYTHON TRANSFORM_SERVICE_PYTHON_VERSION ***'
*** RUN TRANSFORM SERVICE DIRECT USING PYTHON TRANSFORM_SERVICE_PYTHON_VERSION ***
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/gradlew> --continue --max-workers=8 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx6g -Dorg.gradle.vfs.watch=false -Pdocker-pull-licenses -PcompileAndRunTestsWithJava11 -Pjava11Home=/usr/lib/jvm/java-11-openjdk-amd64 :sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava
To honour the JVM settings for this build a single-use Daemon process will be forked. See https://docs.gradle.org/7.6.2/userguide/gradle_daemon.html#sec:disabling_the_daemon.
Daemon will be stopped at the end of the build 
Configuration on demand is an incubating feature.
Gradle Enterprise plugins resolution: https://plugins.gradle.org/m2
Enforcing Gradle Enterprise: https://ge.apache.org, allowUntrustedServer: false
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build

FAILURE: Build failed with an exception.

* What went wrong:
Cannot locate tasks that match ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava' as task 'transformServicePythonUsingJava' not found in project ':sdks:python:test-suites:direct:xlang'.

* Try:
> Run gradlew tasks to get a list of available tasks.
> 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

BUILD FAILED in 13s
10 actionable tasks: 4 executed, 4 from cache, 2 up-to-date

Publishing build scan...

Publishing failed.

The response from https://ge.apache.org/scans/publish/gradle/3.13.2/token was not from Gradle Enterprise.
The specified server address may be incorrect, or your network environment may be interfering.

Please report this problem to your Gradle Enterprise administrator via https://ge.apache.org/help and include the following via copy/paste:

----------
Gradle version: 7.6.2
Plugin version: 3.13.2
Request URL: https://ge.apache.org/scans/publish/gradle/3.13.2/token
Request ID: c4a83418-19ce-4e46-a488-c61850274cf4
Response status code: 502
Response content type: text/html
----------

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_TransformService_Direct #9

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

Changes:


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-3 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Using shallow clone with depth 1
Avoid fetching tags
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.25.1'
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Using shallow fetch with depth 1
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision a0a297dddaae1ec45c514bffb7977772cb42d528 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f a0a297dddaae1ec45c514bffb7977772cb42d528 # timeout=10
Commit message: "Try a second time to delete old images (#27905)"
 > git rev-list --no-walk 29ea352fa7c96503dfc914c8e2ef982ee37a0c01 # timeout=10
First time build. Skipping changelog.
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SETUPTOOLS_USE_DISTUTILS=stdlib
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_TransformService_Direct] $ /bin/bash -xe /tmp/jenkins2749452096039600445.sh
+ echo '*** RUN TRANSFORM SERVICE DIRECT USING PYTHON TRANSFORM_SERVICE_PYTHON_VERSION ***'
*** RUN TRANSFORM SERVICE DIRECT USING PYTHON TRANSFORM_SERVICE_PYTHON_VERSION ***
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/gradlew> --continue --max-workers=8 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx6g -Dorg.gradle.vfs.watch=false -Pdocker-pull-licenses -PcompileAndRunTestsWithJava11 -Pjava11Home=/usr/lib/jvm/java-11-openjdk-amd64 :sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava
To honour the JVM settings for this build a single-use Daemon process will be forked. See https://docs.gradle.org/7.6.2/userguide/gradle_daemon.html#sec:disabling_the_daemon.
Daemon will be stopped at the end of the build 
Configuration on demand is an incubating feature.
Gradle Enterprise plugins resolution: https://plugins.gradle.org/m2
Enforcing Gradle Enterprise: https://ge.apache.org, allowUntrustedServer: false
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build

FAILURE: Build failed with an exception.

* What went wrong:
Cannot locate tasks that match ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava' as task 'transformServicePythonUsingJava' not found in project ':sdks:python:test-suites:direct:xlang'.

* Try:
> Run gradlew tasks to get a list of available tasks.
> 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

BUILD FAILED in 15s
10 actionable tasks: 4 executed, 4 from cache, 2 up-to-date

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

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_TransformService_Direct #8

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

Changes:


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-12 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Using shallow clone with depth 1
Avoid fetching tags
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.25.1'
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Using shallow fetch with depth 1
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 29ea352fa7c96503dfc914c8e2ef982ee37a0c01 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 29ea352fa7c96503dfc914c8e2ef982ee37a0c01 # timeout=10
Commit message: "Add an option to the FnApi harness PIPELINE_OPTIONS_FILE that overrides the old PIPELINE_OPTIONS environment variable with the contents of a file. This allows us to circumvent kernel limits on the combined size of environment variables and commandline arguments. (#27841)"
 > git rev-list --no-walk 450d801c88862de3fe0368a51049439a71817b9c # timeout=10
First time build. Skipping changelog.
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SETUPTOOLS_USE_DISTUTILS=stdlib
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_TransformService_Direct] $ /bin/bash -xe /tmp/jenkins4660607656277858733.sh
+ echo '*** RUN TRANSFORM SERVICE DIRECT USING PYTHON TRANSFORM_SERVICE_PYTHON_VERSION ***'
*** RUN TRANSFORM SERVICE DIRECT USING PYTHON TRANSFORM_SERVICE_PYTHON_VERSION ***
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/gradlew> --continue --max-workers=8 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx6g -Dorg.gradle.vfs.watch=false -Pdocker-pull-licenses -PcompileAndRunTestsWithJava11 -Pjava11Home=/usr/lib/jvm/java-11-openjdk-amd64 :sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava
To honour the JVM settings for this build a single-use Daemon process will be forked. See https://docs.gradle.org/7.6.2/userguide/gradle_daemon.html#sec:disabling_the_daemon.
Daemon will be stopped at the end of the build 
Configuration on demand is an incubating feature.
Gradle Enterprise plugins resolution: https://plugins.gradle.org/m2
Enforcing Gradle Enterprise: https://ge.apache.org, allowUntrustedServer: false
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build

FAILURE: Build failed with an exception.

* What went wrong:
Cannot locate tasks that match ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava' as task 'transformServicePythonUsingJava' not found in project ':sdks:python:test-suites:direct:xlang'.

* Try:
> Run gradlew tasks to get a list of available tasks.
> 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

BUILD FAILED in 14s
10 actionable tasks: 4 executed, 4 from cache, 2 up-to-date

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

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

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

Changes:

[noreply] Update example for BundleProcessResponse (#27834)


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-11 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Using shallow clone with depth 1
Avoid fetching tags
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.25.1'
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Using shallow fetch with depth 1
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 450d801c88862de3fe0368a51049439a71817b9c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 450d801c88862de3fe0368a51049439a71817b9c # timeout=10
Commit message: "Update example for BundleProcessResponse (#27834)"
 > git rev-list --no-walk 9ca6c3349156a255823bba8a09402981378de815 # timeout=10
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SETUPTOOLS_USE_DISTUTILS=stdlib
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_TransformService_Direct] $ /bin/bash -xe /tmp/jenkins7564165662964223625.sh
+ echo '*** RUN TRANSFORM SERVICE DIRECT USING PYTHON TRANSFORM_SERVICE_PYTHON_VERSION ***'
*** RUN TRANSFORM SERVICE DIRECT USING PYTHON TRANSFORM_SERVICE_PYTHON_VERSION ***
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/gradlew> --continue --max-workers=8 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx6g -Dorg.gradle.vfs.watch=false -Pdocker-pull-licenses -PcompileAndRunTestsWithJava11 -Pjava11Home=/usr/lib/jvm/java-11-openjdk-amd64 :sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava
To honour the JVM settings for this build a single-use Daemon process will be forked. See https://docs.gradle.org/7.6.2/userguide/gradle_daemon.html#sec:disabling_the_daemon.
Daemon will be stopped at the end of the build 
Configuration on demand is an incubating feature.
Gradle Enterprise plugins resolution: https://plugins.gradle.org/m2
Enforcing Gradle Enterprise: https://ge.apache.org, allowUntrustedServer: false
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build

FAILURE: Build failed with an exception.

* What went wrong:
Cannot locate tasks that match ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava' as task 'transformServicePythonUsingJava' not found in project ':sdks:python:test-suites:direct:xlang'.

* Try:
> Run gradlew tasks to get a list of available tasks.
> 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

BUILD FAILED in 16s
10 actionable tasks: 4 executed, 4 from cache, 2 up-to-date

Publishing build scan...
https://ge.apache.org/s/6jginnxtjzdbk

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_TransformService_Direct #6

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

Changes:


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-12 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Using shallow clone with depth 1
Avoid fetching tags
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.25.1'
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Using shallow fetch with depth 1
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 9ca6c3349156a255823bba8a09402981378de815 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 9ca6c3349156a255823bba8a09402981378de815 # timeout=10
Commit message: "Fix broken url for 'Tour of Beam' (#27412)"
 > git rev-list --no-walk 7754ab9eab8951eb047643857623ea435ccbe894 # timeout=10
First time build. Skipping changelog.
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SETUPTOOLS_USE_DISTUTILS=stdlib
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_TransformService_Direct] $ /bin/bash -xe /tmp/jenkins5199401627786100764.sh
+ echo '*** RUN TRANSFORM SERVICE DIRECT USING PYTHON TRANSFORM_SERVICE_PYTHON_VERSION ***'
*** RUN TRANSFORM SERVICE DIRECT USING PYTHON TRANSFORM_SERVICE_PYTHON_VERSION ***
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/gradlew> --continue --max-workers=8 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx6g -Dorg.gradle.vfs.watch=false -Pdocker-pull-licenses -PcompileAndRunTestsWithJava11 -Pjava11Home=null :sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava
To honour the JVM settings for this build a single-use Daemon process will be forked. See https://docs.gradle.org/7.6.2/userguide/gradle_daemon.html#sec:disabling_the_daemon.
Daemon will be stopped at the end of the build 
Configuration on demand is an incubating feature.
Gradle Enterprise plugins resolution: https://plugins.gradle.org/m2
Enforcing Gradle Enterprise: https://ge.apache.org, allowUntrustedServer: false
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build

FAILURE: Build failed with an exception.

* What went wrong:
Cannot locate tasks that match ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava' as task 'transformServicePythonUsingJava' not found in project ':sdks:python:test-suites:direct:xlang'.

* Try:
> Run gradlew tasks to get a list of available tasks.
> 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

BUILD FAILED in 14s
10 actionable tasks: 4 executed, 4 from cache, 2 up-to-date

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

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_TransformService_Direct #5

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

Changes:


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-12 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Using shallow clone with depth 1
Avoid fetching tags
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.25.1'
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Using shallow fetch with depth 1
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --no-tags --force --progress --depth=1 -- https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 7754ab9eab8951eb047643857623ea435ccbe894 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 7754ab9eab8951eb047643857623ea435ccbe894 # timeout=10
Commit message: "Fix google-api-services-bigquery to match new google-cloud-bigquery (#27828)"
 > git rev-list --no-walk 90809097260ec4252b746b97bd849efc412950f5 # timeout=10
First time build. Skipping changelog.
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SETUPTOOLS_USE_DISTUTILS=stdlib
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_TransformService_Direct] $ /bin/bash -xe /tmp/jenkins7694198348497888477.sh
+ echo '*** RUN TRANSFORM SERVICE DIRECT USING PYTHON TRANSFORM_SERVICE_PYTHON_VERSION ***'
*** RUN TRANSFORM SERVICE DIRECT USING PYTHON TRANSFORM_SERVICE_PYTHON_VERSION ***
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_TransformService_Direct/ws/src/gradlew> --continue --max-workers=8 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx6g -Dorg.gradle.vfs.watch=false -Pdocker-pull-licenses :sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava
To honour the JVM settings for this build a single-use Daemon process will be forked. See https://docs.gradle.org/7.6.2/userguide/gradle_daemon.html#sec:disabling_the_daemon.
Daemon will be stopped at the end of the build 
Configuration on demand is an incubating feature.
Gradle Enterprise plugins resolution: https://plugins.gradle.org/m2
Enforcing Gradle Enterprise: https://ge.apache.org, allowUntrustedServer: false
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build

FAILURE: Build failed with an exception.

* What went wrong:
Cannot locate tasks that match ':sdks:python:test-suites:direct:xlang:transformServicePythonUsingJava' as task 'transformServicePythonUsingJava' not found in project ':sdks:python:test-suites:direct:xlang'.

* Try:
> Run gradlew tasks to get a list of available tasks.
> 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

BUILD FAILED in 14s
10 actionable tasks: 4 executed, 4 from cache, 2 up-to-date

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

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