See
<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/7161/display/redirect>
Changes:
------------------------------------------
[...truncated 972.95 KB...]
INFO: No metrics reporter configured, no metrics will be exposed/reported.
Oct 27, 2023 6:27:13 PM org.apache.flink.runtime.minicluster.MiniCluster start
INFO: Starting RPC Service(s)
Oct 27, 2023 6:27:13 PM org.apache.flink.runtime.rpc.akka.AkkaBootstrapTools
startLocalActorSystem
INFO: Trying to start local actor system
Oct 27, 2023 6:27:14 PM akka.event.slf4j.Slf4jLogger$$anonfun$receive$1
applyOrElse
INFO: Slf4jLogger started
Oct 27, 2023 6:27:14 PM org.apache.flink.runtime.rpc.akka.AkkaBootstrapTools
startActorSystem
INFO: Actor system started at akka://flink
Oct 27, 2023 6:27:14 PM org.apache.flink.runtime.rpc.akka.AkkaBootstrapTools
startLocalActorSystem
INFO: Trying to start local actor system
Oct 27, 2023 6:27:14 PM akka.event.slf4j.Slf4jLogger$$anonfun$receive$1
applyOrElse
INFO: Slf4jLogger started
Oct 27, 2023 6:27:14 PM org.apache.flink.runtime.rpc.akka.AkkaBootstrapTools
startActorSystem
INFO: Actor system started at akka://flink-metrics
Oct 27, 2023 6:27:14 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService
startServer
INFO: Starting RPC endpoint for
org.apache.flink.runtime.metrics.dump.MetricQueryService at
akka://flink-metrics/user/rpc/MetricQueryService .
Oct 27, 2023 6:27:14 PM org.apache.flink.runtime.blob.BlobServer <init>
INFO: Created BLOB server storage directory
/tmp/minicluster_0bdd50cc77fe7507c933a26bd0dc3d97/blobStorage
Oct 27, 2023 6:27:14 PM org.apache.flink.runtime.blob.BlobServer <init>
INFO: Started BLOB server at 0.0.0.0:43907 - max concurrent requests: 50 - max
backlog: 1000
INFO:apache_beam.runners.portability.abstract_job_service:Artifact server
started on port 44265
INFO:apache_beam.runners.portability.abstract_job_service:Running job
'job-9b031d64-e90e-40b4-8045-98f292aa1dc4'
Oct 27, 2023 6:27:14 PM org.apache.hadoop.util.NativeCodeLoader <clinit>
WARNING: Unable to load native-hadoop library for your platform... using
builtin-java classes where applicable
Oct 27, 2023 6:27:14 PM
org.apache.flink.runtime.security.token.KerberosDelegationTokenManagerFactory
create
INFO: Cannot use kerberos delegation token manager no valid kerberos
credentials provided.
Oct 27, 2023 6:27:14 PM org.apache.flink.runtime.blob.AbstractBlobCache <init>
INFO: Created BLOB cache storage directory
/tmp/minicluster_0bdd50cc77fe7507c933a26bd0dc3d97/blobStorage
Oct 27, 2023 6:27:14 PM org.apache.flink.runtime.blob.AbstractBlobCache <init>
INFO: Created BLOB cache storage directory
/tmp/minicluster_0bdd50cc77fe7507c933a26bd0dc3d97/blobStorage
Oct 27, 2023 6:27:14 PM org.apache.flink.runtime.minicluster.MiniCluster
startTaskManagers
INFO: Starting 1 TaskManager(s)
Oct 27, 2023 6:27:14 PM org.apache.flink.runtime.taskexecutor.TaskManagerRunner
startTaskManager
INFO: Starting TaskManager with ResourceID: ae20bf65-513c-4999-803a-70ed0596ed3e
Oct 27, 2023 6:27:14 PM
org.apache.flink.runtime.taskexecutor.TaskManagerServices checkTempDirs
INFO: Temporary file directory '/tmp': total 969 GB, usable 362 GB (37.36%
usable)
Oct 27, 2023 6:27:14 PM org.apache.flink.runtime.io.disk.iomanager.IOManager
<init>
INFO: Created a new FileChannelManager for spilling of task related data to
disk (joins, sorting, ...). Used directories:
/tmp/flink-io-3abb7369-8210-478c-a2d1-66071e7888e7
Oct 27, 2023 6:27:14 PM
org.apache.flink.runtime.io.network.NettyShuffleServiceFactory
createNettyShuffleEnvironment
INFO: Created a new FileChannelManager for storing result partitions of
BLOCKING shuffles. Used directories:
/tmp/flink-netty-shuffle-86884942-40a6-47e2-a592-ec4878ab11ee
Oct 27, 2023 6:27:14 PM
org.apache.flink.runtime.io.network.buffer.NetworkBufferPool <init>
INFO: Allocated 64 MB for network buffer pool (number of memory segments: 2048,
bytes per segment: 32768).
Oct 27, 2023 6:27:14 PM
org.apache.flink.runtime.io.network.NettyShuffleEnvironment start
INFO: Starting the network environment and its components.
Oct 27, 2023 6:27:14 PM org.apache.flink.runtime.taskexecutor.KvStateService
start
INFO: Starting the kvState service and its components.
Oct 27, 2023 6:27:14 PM org.apache.flink.configuration.Configuration
loggingFallback
INFO: Config uses fallback configuration key 'akka.ask.timeout' instead of key
'taskmanager.slot.timeout'
Oct 27, 2023 6:27:14 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService
startServer
INFO: Starting RPC endpoint for
org.apache.flink.runtime.taskexecutor.TaskExecutor at
akka://flink/user/rpc/taskmanager_0 .
Oct 27, 2023 6:27:15 PM
org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService start
INFO: Start job leader service.
Oct 27, 2023 6:27:15 PM org.apache.flink.runtime.filecache.FileCache <init>
INFO: User file cache uses directory
/tmp/flink-dist-cache-ce3dd7b4-537e-476c-a3ee-07c6c729da36
Oct 27, 2023 6:27:15 PM org.apache.flink.configuration.Configuration
loggingFallback
INFO: Config uses fallback configuration key 'rest.port' instead of key
'rest.bind-port'
Oct 27, 2023 6:27:15 PM org.apache.flink.runtime.rest.RestServerEndpoint start
INFO: Starting rest endpoint.
Oct 27, 2023 6:27:15 PM
org.apache.flink.runtime.webmonitor.WebMonitorUtils$LogFileLocation find
WARNING: Log file environment variable 'log.file' is not set.
Oct 27, 2023 6:27:15 PM
org.apache.flink.runtime.webmonitor.WebMonitorUtils$LogFileLocation find
WARNING: JobManager log files are unavailable in the web dashboard. Log file
location not found in environment variable 'log.file' or configuration key
'web.log.path'.
Traceback (most recent call last):
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/urllib3/connection.py",>
line 203, in _new_conn
sock = connection.create_connection(
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/urllib3/util/connection.py",>
line 85, in create_connection
raise err
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/urllib3/util/connection.py",>
line 73, in create_connection
sock.connect(sa)
ConnectionRefusedError: [Errno 111] Connection refused
The above exception was the direct cause of the following exception:
Traceback (most recent call last):
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/urllib3/connectionpool.py",>
line 791, in urlopen
response = self._make_request(
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/urllib3/connectionpool.py",>
line 497, in _make_request
conn.request(
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/urllib3/connection.py",>
line 395, in request
self.endheaders()
File "/usr/lib/python3.8/http/client.py", line 1251, in endheaders
self._send_output(message_body, encode_chunked=encode_chunked)
File "/usr/lib/python3.8/http/client.py", line 1011, in _send_output
self.send(msg)
File "/usr/lib/python3.8/http/client.py", line 951, in send
self.connect()
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/urllib3/connection.py",>
line 243, in connect
self.sock = self._new_conn()
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/urllib3/connection.py",>
line 218, in _new_conn
raise NewConnectionError(
urllib3.exceptions.NewConnectionError: <urllib3.connection.HTTPConnection
object at 0x7fdde9d13940>: Failed to establish a new connection: [Errno 111]
Connection refused
The above exception was the direct cause of the following exception:
Traceback (most recent call last):
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/requests/adapters.py",>
line 486, in send
resp = conn.urlopen(
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/urllib3/connectionpool.py",>
line 845, in urlopen
retries = retries.increment(
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/urllib3/util/retry.py",>
line 515, in increment
raise MaxRetryError(_pool, url, reason) from reason # type:
ignore[arg-type]
urllib3.exceptions.MaxRetryError: HTTPConnectionPool(host='localhost',
port=46179): Max retries exceeded with url: /v1/jars/upload (Caused by
NewConnectionError('<urllib3.connection.HTTPConnection object at
0x7fdde9d13940>: Failed to establish a new connection: [Errno 111] Connection
refused'))
During handling of the above exception, another exception occurred:
Traceback (most recent call last):
File "<string>", line 31, in <module>
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/sdks/python/apache_beam/pipeline.py",>
line 585, in run
return self.runner.run_pipeline(self, self._options)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/sdks/python/apache_beam/runners/runner.py",>
line 192, in run_pipeline
return self.run_portable_pipeline(
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner.py",>
line 382, in run_portable_pipeline
job_id, message_stream, state_stream = job_service_handle.submit(
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner.py",>
line 114, in submit
return self.run(prepare_response.preparation_id)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner.py",>
line 241, in run
run_response = self.job_service.Run(
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/sdks/python/apache_beam/runners/portability/abstract_job_service.py",>
line 120, in Run
self._jobs[job_id].run()
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_uber_jar_job_server.py",>
line 152, in run
self._flink_jar_id = self.post(
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_uber_jar_job_server.py",>
line 142, in post
return self.request(requests.post, path, **kwargs)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_uber_jar_job_server.py",>
line 130, in request
response = method(url, **kwargs)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/requests/api.py",>
line 115, in post
return request("post", url, data=data, json=json, **kwargs)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/requests/api.py",>
line 59, in request
return session.request(method=method, url=url, **kwargs)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/requests/sessions.py",>
line 589, in request
resp = self.send(prep, **send_kwargs)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/requests/sessions.py",>
line 703, in send
r = adapter.send(request, **kwargs)
File
"<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/requests/adapters.py",>
line 519, in send
raise ConnectionError(e, request=request)
requests.exceptions.ConnectionError: HTTPConnectionPool(host='localhost',
port=46179): Max retries exceeded with url: /v1/jars/upload (Caused by
NewConnectionError('<urllib3.connection.HTTPConnection object at
0x7fdde9d13940>: Failed to establish a new connection: [Errno 111] Connection
refused'))
Oct 27, 2023 6:27:15 PM org.apache.flink.runtime.rest.RestServerEndpoint start
INFO: Rest endpoint listening at 127.0.0.1:46179
Oct 27, 2023 6:27:15 PM
org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
updateLeader
INFO: Proposing leadership to contender http://127.0.0.1:46179
Oct 27, 2023 6:27:15 PM org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
startInternal
INFO: Web frontend listening at http://127.0.0.1:46179.
Oct 27, 2023 6:27:15 PM org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
grantLeadership
INFO: http://127.0.0.1:46179 was granted leadership with
leaderSessionID=c0c5a952-5d53-4e39-b507-b0699746025d
Oct 27, 2023 6:27:15 PM
org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
confirmLeader
INFO: Received confirmation of leadership for leader http://127.0.0.1:46179 ,
session=c0c5a952-5d53-4e39-b507-b0699746025d
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
updateLeader
INFO: Proposing leadership to contender LeaderContender: DefaultDispatcherRunner
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.resourcemanager.ResourceManagerServiceImpl start
INFO: Starting resource manager service.
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
updateLeader
INFO: Proposing leadership to contender LeaderContender:
ResourceManagerServiceImpl
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunner
lambda$grantLeadership$0
INFO: DefaultDispatcherRunner was granted leadership with leader id
3d5f21d7-f1ec-4aab-8fc9-a1b024aa1bef. Creating new DispatcherLeaderProcess.
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.resourcemanager.ResourceManagerServiceImpl
lambda$grantLeadership$2
INFO: Resource manager service is granted leadership with session id
7213f16a-1357-4435-b4d8-953675deac84.
Oct 27, 2023 6:27:16 PM org.apache.flink.runtime.minicluster.MiniCluster start
INFO: Flink Mini Cluster started successfully
Started Flink mini cluster (1 TaskManagers with 1 task slots) with Rest API at
java.util.concurrent.CompletableFuture@3e850122[Completed normally]
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
startInternal
INFO: Start SessionDispatcherLeaderProcess.
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess
recoverJobs
INFO: Recover all persisted job graphs that are not finished, yet.
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess
recoverJobs
INFO: Successfully recovered 0 persisted job graphs.
Oct 27, 2023 6:27:16 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService
startServer
INFO: Starting RPC endpoint for
org.apache.flink.runtime.resourcemanager.StandaloneResourceManager at
akka://flink/user/rpc/resourcemanager_1 .
Oct 27, 2023 6:27:16 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService
startServer
INFO: Starting RPC endpoint for
org.apache.flink.runtime.dispatcher.StandaloneDispatcher at
akka://flink/user/rpc/dispatcher_2 .
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.resourcemanager.ResourceManager onStart
INFO: Starting the resource manager.
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
confirmLeader
INFO: Received confirmation of leadership for leader
akka://flink/user/rpc/resourcemanager_1 ,
session=7213f16a-1357-4435-b4d8-953675deac84
Oct 27, 2023 6:27:16 PM org.apache.flink.runtime.taskexecutor.TaskExecutor
connectToResourceManager
INFO: Connecting to ResourceManager
akka://flink/user/rpc/resourcemanager_1(b4d8953675deac847213f16a13574435).
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
confirmLeader
INFO: Received confirmation of leadership for leader
akka://flink/user/rpc/dispatcher_2 ,
session=3d5f21d7-f1ec-4aab-8fc9-a1b024aa1bef
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.registration.RetryingRegistration
lambda$startRegistration$0
INFO: Resolved ResourceManager address, beginning registration
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.resourcemanager.ResourceManager
registerTaskExecutorInternal
INFO: Registering TaskManager with ResourceID
ae20bf65-513c-4999-803a-70ed0596ed3e (akka://flink/user/rpc/taskmanager_0) at
ResourceManager
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
onRegistrationSuccess
INFO: Successful registration at resource manager
akka://flink/user/rpc/resourcemanager_1 under registration id
149708c27d776bcdcc0074f1e8ebe7e9.
kill %1 || echo "Failed to shut down Flink mini cluster"
rm -rf "$ENV_DIR"
Oct 27, 2023 6:27:16 PM
org.apache.flink.runtime.state.TaskExecutorStateChangelogStoragesManager
shutdown
INFO: Shutting down TaskExecutorStateChangelogStoragesManager.
>>> FAILURE
if [[ "$TEST_EXIT_CODE" -eq 0 ]]; then
echo ">>> SUCCESS"
else
echo ">>> FAILURE"
fi
exit $TEST_EXIT_CODE
> Task
> :sdks:python:test-suites:portable:py38:testUberJarFlinkRunnerSaveMainSession
> FAILED
FAILURE: Build completed with 2 failures.
1: Task failed with an exception.
-----------
* Where:
Script
'<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'>
line: 411
* What went wrong:
Execution failed for task
':sdks:python:test-suites:portable:py38:testUberJarFlinkRunner'.
> 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.
==============================================================================
2: Task failed with an exception.
-----------
* Where:
Script
'<https://ci-beam.apache.org/job/beam_PostCommit_PortableJar_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'>
line: 411
* What went wrong:
Execution failed for task
':sdks:python:test-suites:portable:py38:testUberJarFlinkRunnerSaveMainSession'.
> 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 9.0.
You can use '--warning-mode all' to show the individual deprecation warnings
and determine if they come from your own scripts or plugins.
For more on this, please refer to
https://docs.gradle.org/8.4/userguide/command_line_interface.html#sec:command_line_warnings
in the Gradle documentation.
BUILD FAILED in 28m 50s
148 actionable tasks: 102 executed, 44 from cache, 2 up-to-date
Publishing build scan...
https://ge.apache.org/s/7tpuilcfxotmu
Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
---------------------------------------------------------------------
To unsubscribe, e-mail: [email protected]
For additional commands, e-mail: [email protected]