You are viewing a plain text version of this content. The canonical link for it is here.
Posted to builds@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2021/02/10 13:05:50 UTC

Build failed in Jenkins: beam_PreCommit_Python_PVR_Flink_Cron #565

See <https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/565/display/redirect>

Changes:


------------------------------------------
[...truncated 211.59 KB...]
apache_beam/runners/portability/flink_runner_test.py:290: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/pvalue.py:141: in __or__
    return self.pipeline.apply(ptransform, self)
apache_beam/pipeline.py:636: in apply
    transform.transform, pvalueish, label or transform.label)
apache_beam/pipeline.py:646: in apply
    return self.apply(transform, pvalueish)
apache_beam/pipeline.py:689: in apply
    pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
apache_beam/runners/runner.py:188: in apply
    return m(transform, input, options)
apache_beam/runners/runner.py:218: in apply_PTransform
    return transform.expand(input)
apache_beam/transforms/external.py:316: in expand
    response = service.Expand(request)
target/.tox-flink-runner-test/flink-runner-test/lib/python3.6/site-packages/grpc/_channel.py:923: in __call__
    return _end_unary_response_blocking(state, call, False, None)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

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

    def _end_unary_response_blocking(state, call, with_call, deadline):
        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)
E           grpc._channel._InactiveRpcError: <_InactiveRpcError of RPC that terminated with:
E           	status = StatusCode.UNAVAILABLE
E           	details = "failed to connect to all addresses"
E           	debug_error_string = "{"created":"@1612961341.334044682","description":"Failed to pick subchannel","file":"src/core/ext/filters/client_channel/client_channel.cc","file_line":5390,"referenced_errors":[{"created":"@1612961341.334038973","description":"failed to connect to all addresses","file":"src/core/ext/filters/client_channel/lb_policy/pick_first/pick_first.cc","file_line":397,"grpc_status":14}]}"
E           >

target/.tox-flink-runner-test/flink-runner-test/lib/python3.6/site-packages/grpc/_channel.py:826: _InactiveRpcError
_______________ FlinkRunnerTest.test_windowed_pardo_state_timers _______________

self = <apache_beam.runners.portability.flink_runner_test.FlinkRunnerTest testMethod=test_windowed_pardo_state_timers>

    def test_windowed_pardo_state_timers(self):
>     self._run_pardo_state_timers(windowed=True)

apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:429: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:494: in _run_pardo_state_timers
    assert_that(actual, is_buffered_correctly)
apache_beam/pipeline.py:580: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:559: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/portability/portable_runner.py:442: in run_pipeline
    job_service_handle = self.create_job_service(options)
apache_beam/runners/portability/portable_runner.py:320: in create_job_service
    return self.create_job_service_handle(server.start(), options)
apache_beam/runners/portability/job_server.py:56: in start
    grpc.channel_ready_future(channel).result(timeout=self._timeout)
target/.tox-flink-runner-test/flink-runner-test/lib/python3.6/site-packages/grpc/_utilities.py:140: in result
    self._block(timeout)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <grpc._utilities._ChannelReadyFuture object at 0x7fc9d753d5c0>
timeout = 60

    def _block(self, timeout):
        until = None if timeout is None else time.time() + timeout
        with self._condition:
            while True:
                if self._cancelled:
                    raise grpc.FutureCancelledError()
                elif self._matured:
                    return
                else:
                    if until is None:
                        self._condition.wait()
                    else:
                        remaining = until - time.time()
                        if remaining < 0:
>                           raise grpc.FutureTimeoutError()
E                           grpc.FutureTimeoutError

target/.tox-flink-runner-test/flink-runner-test/lib/python3.6/site-packages/grpc/_utilities.py:86: FutureTimeoutError
----------------------------- Captured stderr call -----------------------------
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
------------------------------ Captured log call -------------------------------
WARNING  root:environments.py:312 Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
________________________ FlinkRunnerTest.test_windowing ________________________

self = <apache_beam.runners.portability.flink_runner_test.FlinkRunnerTest testMethod=test_windowing>

    def test_windowing(self):
      with self.create_pipeline() as p:
        res = (
            p
            | beam.Create([1, 2, 100, 101, 102])
            | beam.Map(lambda t: window.TimestampedValue(('k', t), t))
            | beam.WindowInto(beam.transforms.window.Sessions(10))
            | beam.GroupByKey()
            | beam.Map(lambda k_vs1: (k_vs1[0], sorted(k_vs1[1]))))
>       assert_that(res, equal_to([('k', [1, 2]), ('k', [100, 101, 102])]))

apache_beam/runners/portability/fn_api_runner/fn_runner_test.py:781: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/pipeline.py:580: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:559: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/portability/portable_runner.py:442: in run_pipeline
    job_service_handle = self.create_job_service(options)
apache_beam/runners/portability/portable_runner.py:320: in create_job_service
    return self.create_job_service_handle(server.start(), options)
apache_beam/runners/portability/job_server.py:56: in start
    grpc.channel_ready_future(channel).result(timeout=self._timeout)
target/.tox-flink-runner-test/flink-runner-test/lib/python3.6/site-packages/grpc/_utilities.py:140: in result
    self._block(timeout)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <grpc._utilities._ChannelReadyFuture object at 0x7fc9d746b780>
timeout = 60

    def _block(self, timeout):
        until = None if timeout is None else time.time() + timeout
        with self._condition:
            while True:
                if self._cancelled:
                    raise grpc.FutureCancelledError()
                elif self._matured:
                    return
                else:
                    if until is None:
                        self._condition.wait()
                    else:
                        remaining = until - time.time()
                        if remaining < 0:
>                           raise grpc.FutureTimeoutError()
E                           grpc.FutureTimeoutError

target/.tox-flink-runner-test/flink-runner-test/lib/python3.6/site-packages/grpc/_utilities.py:86: FutureTimeoutError
----------------------------- Captured stderr call -----------------------------
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
------------------------------ Captured log call -------------------------------
WARNING  root:environments.py:312 Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
=============================== warnings summary ===============================
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTest::test_expand_kafka_read
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTest::test_expand_kafka_write
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTest::test_external_transform
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTest::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTest::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTest::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTest::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTest::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTest::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_expand_kafka_read
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_expand_kafka_write
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_external_transform
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src/sdks/python/test-suites/portable/py36/build/srcs/sdks/python/apache_beam/coders/coder_impl.py>:223: DeprecationWarning: tostring() is deprecated. Use tobytes() instead.
    self.encode_to_stream(value, out, False)

apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src/sdks/python/test-suites/portable/py36/build/srcs/sdks/python/apache_beam/coders/coder_impl.py>:228: DeprecationWarning: fromstring() is deprecated. Use frombytes() instead.
    return self.decode_from_stream(create_InputStream(encoded), False)

apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src/sdks/python/test-suites/portable/py36/build/srcs/sdks/python/apache_beam/coders/coder_impl.py>:235: DeprecationWarning: tostring() is deprecated. Use tobytes() instead.
    self.encode_to_stream(value, out, nested)

apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src/sdks/python/test-suites/portable/py36/build/srcs/sdks/python/apache_beam/coders/coder_impl.py>:1249: DeprecationWarning: tostring() is deprecated. Use tobytes() instead.
    self._value_coder.encode_to_stream(wv.value, out, nested)

apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
apache_beam/runners/portability/flink_runner_test.py::FlinkRunnerTestStreaming::test_sql
  <https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src/sdks/python/test-suites/portable/py36/build/srcs/sdks/python/apache_beam/coders/coder_impl.py>:1270: DeprecationWarning: fromstring() is deprecated. Use frombytes() instead.
    value = self._value_coder.decode_from_stream(in_stream, nested)

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src/sdks/python/test-suites/portable/py36/build/srcs/sdks/python/pytest_flink-runner-test.xml> -
======= 43 failed, 86 passed, 36 skipped, 53 warnings in 3276.39 seconds =======
ERROR: InvocationError for command <https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src/sdks/python/test-suites/portable/py36/build/srcs/sdks/python/scripts/pytest_validates_runner.sh> flink-runner-test apache_beam/runners/portability/flink_runner_test.py '--flink_job_server_jar=<https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src/runners/flink/1.12/job-server/build/libs/beam-runners-flink-1.12-job-server-2.29.0-SNAPSHOT.jar> --environment_type=LOOPBACK' (exited with code 1)
flink-runner-test run-test-post: commands[0] | bash <https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src/sdks/python/test-suites/portable/py36/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
ERROR:   flink-runner-test: commands failed

> Task :sdks:python:test-suites:portable:py36:flinkCompatibilityMatrixLOOPBACK FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py36:flinkCompatibilityMatrixLOOPBACK'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 3m 57s
147 actionable tasks: 103 executed, 42 from cache, 2 up-to-date
Gradle was unable to watch the file system for changes. The inotify watches limit is too low.

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Jenkins build is back to normal : beam_PreCommit_Python_PVR_Flink_Cron #567

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/567/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_PreCommit_Python_PVR_Flink_Cron #566

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

Changes:


------------------------------------------
Started by timer
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_PreCommit_Python_PVR_Flink_Cron/ws/>
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress 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
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress 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 bc1569cb13540376c2878d87d3b270b752464888 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f bc1569cb13540376c2878d87d3b270b752464888 # timeout=10
Commit message: "Merge pull request #13942: [BEAM-11784] Maintain topological order of root transforms"
 > git rev-list --no-walk bc1569cb13540376c2878d87d3b270b752464888 # 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 
SPARK_LOCAL_IP=127.0.0.1
SETUPTOOLS_USE_DISTUTILS=stdlib

[EnvInject] - Variables injected successfully.
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src/gradlew> --continue --max-workers=12 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx4g -Pdocker-pull-licenses :sdks:python:test-suites:portable:flinkValidatesRunnerPrecommit
The message received from the daemon indicates that the daemon has disappeared.
Build request sent: Build{id=6941387b-5fe0-4713-9ae9-6117131e3ca9, currentDir=<https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src}>
Attempting to read last messages from the daemon log...
Daemon pid: 27035
  log file: /home/jenkins/.gradle/daemon/6.8/daemon-27035.out.log
----- Last  20 lines from daemon log file - daemon-27035.out.log -----
2021-02-10T18:02:01.563+0000 [DEBUG] [org.gradle.launcher.daemon.server.DefaultDaemonConnection] thread 231: Received non-IO message from client: Build{id=6941387b-5fe0-4713-9ae9-6117131e3ca9, currentDir=<https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src}>
2021-02-10T18:02:01.563+0000 [INFO] [org.gradle.launcher.daemon.server.DefaultIncomingConnectionHandler] Received command: Build{id=6941387b-5fe0-4713-9ae9-6117131e3ca9, currentDir=<https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src}.>
2021-02-10T18:02:01.563+0000 [DEBUG] [org.gradle.launcher.daemon.server.DefaultIncomingConnectionHandler] Starting executing command: Build{id=6941387b-5fe0-4713-9ae9-6117131e3ca9, currentDir=<https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src}> with connection: socket connection from /127.0.0.1:37173 to /127.0.0.1:51266.
2021-02-10T18:02:01.564+0000 [ERROR] [org.gradle.launcher.daemon.server.DaemonStateCoordinator] Command execution: started DaemonCommandExecution[command = Build{id=6941387b-5fe0-4713-9ae9-6117131e3ca9, currentDir=<https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src},> connection = DefaultDaemonConnection: socket connection from /127.0.0.1:37173 to /127.0.0.1:51266] after 0.0 minutes of idle
2021-02-10T18:02:01.564+0000 [INFO] [org.gradle.launcher.daemon.server.DaemonRegistryUpdater] Marking the daemon as busy, address: [aec79aec-3ef6-4235-a02a-eff8d95ab697 port:37173, addresses:[localhost/127.0.0.1]]
2021-02-10T18:02:01.566+0000 [DEBUG] [org.gradle.launcher.daemon.registry.PersistentDaemonRegistry] Marking busy by address: [aec79aec-3ef6-4235-a02a-eff8d95ab697 port:37173, addresses:[localhost/127.0.0.1]]
2021-02-10T18:02:01.566+0000 [DEBUG] [org.gradle.cache.internal.DefaultFileLockManager] Waiting to acquire exclusive lock on daemon addresses registry.
2021-02-10T18:02:01.567+0000 [DEBUG] [org.gradle.cache.internal.DefaultFileLockManager] Lock acquired on daemon addresses registry.
2021-02-10T18:02:01.567+0000 [DEBUG] [org.gradle.cache.internal.DefaultFileLockManager] Releasing lock on daemon addresses registry.
2021-02-10T18:02:01.568+0000 [DEBUG] [org.gradle.launcher.daemon.server.DaemonStateCoordinator] resetting idle timer
2021-02-10T18:02:01.568+0000 [DEBUG] [org.gradle.launcher.daemon.server.DaemonStateCoordinator] daemon is running. Sleeping until state changes.
2021-02-10T18:02:01.568+0000 [INFO] [org.gradle.launcher.daemon.server.exec.StartBuildOrRespondWithBusy] Daemon is about to start building Build{id=6941387b-5fe0-4713-9ae9-6117131e3ca9, currentDir=<https://ci-beam.apache.org/job/beam_PreCommit_Python_PVR_Flink_Cron/ws/src}.> Dispatching build started information...
2021-02-10T18:02:01.568+0000 [DEBUG] [org.gradle.launcher.daemon.server.SynchronizedDispatchConnection] thread 27: dispatching org.gradle.launcher.daemon.protocol.BuildStarted@12ea85bf
2021-02-10T18:02:01.570+0000 [DEBUG] [org.gradle.launcher.daemon.server.exec.EstablishBuildEnvironment] Configuring env variables: [PATH, RUN_DISPLAY_URL, HUDSON_HOME, RUN_CHANGES_DISPLAY_URL, JOB_URL, HUDSON_COOKIE, MAIL, JENKINS_SERVER_COOKIE, LOGNAME, PWD, JENKINS_URL, SHELL, BUILD_TAG, ROOT_BUILD_CAUSE, BUILD_CAUSE_TIMERTRIGGER, OLDPWD, GIT_CHECKOUT_DIR, JENKINS_HOME, sha1, CODECOV_TOKEN, NODE_NAME, BUILD_DISPLAY_NAME, JOB_DISPLAY_URL, GIT_BRANCH, SETUPTOOLS_USE_DISTUTILS, SHLVL, WORKSPACE_TMP, GIT_PREVIOUS_COMMIT, JAVA_HOME, BUILD_ID, LANG, XDG_SESSION_ID, JOB_NAME, SPARK_LOCAL_IP, BUILD_CAUSE, GIT_PREVIOUS_SUCCESSFUL_COMMIT, NODE_LABELS, HUDSON_URL, WORKSPACE, ROOT_BUILD_CAUSE_TIMERTRIGGER, _, GIT_COMMIT, COVERALLS_REPO_TOKEN, EXECUTOR_NUMBER, HUDSON_SERVER_COOKIE, SSH_CLIENT, JOB_BASE_NAME, USER, SSH_CONNECTION, BUILD_NUMBER, BUILD_URL, GIT_URL, XDG_RUNTIME_DIR, HOME]
2021-02-10T18:02:01.571+0000 [DEBUG] [org.gradle.launcher.daemon.server.exec.LogToClient] About to start relaying all logs to the client via the connection.
2021-02-10T18:02:01.571+0000 [INFO] [org.gradle.launcher.daemon.server.exec.LogToClient] The client will now receive all logging from the daemon (pid: 27035). The daemon log file: /home/jenkins/.gradle/daemon/6.8/daemon-27035.out.log
2021-02-10T18:02:01.572+0000 [INFO] [org.gradle.launcher.daemon.server.exec.LogAndCheckHealth] Starting 2nd build in daemon [uptime: 1 mins 31.299 secs, performance: 99%]
2021-02-10T18:02:01.573+0000 [DEBUG] [org.gradle.launcher.daemon.server.exec.ExecuteBuild] The daemon has started executing the build.
2021-02-10T18:02:01.573+0000 [DEBUG] [org.gradle.launcher.daemon.server.exec.ExecuteBuild] Executing build with daemon context: DefaultDaemonContext[uid=6c15bf30-a25d-4a46-bee3-7dec8a92e88d,javaHome=/usr/lib/jvm/java-8-openjdk-amd64,daemonRegistryDir=/home/jenkins/.gradle/daemon,pid=27035,idleTimeout=10800000,priority=NORMAL,daemonOpts=-Xmx4g,-Dfile.encoding=UTF-8,-Duser.country=US,-Duser.language=en,-Duser.variant]
Daemon vm is shutting down... The daemon has exited normally or was terminated in response to a user interrupt.
----- End of the daemon log -----


FAILURE: Build failed with an exception.

* What went wrong:
Gradle build daemon disappeared unexpectedly (it may have been killed or may have crashed)

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.

* Get more help at https://help.gradle.org
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