See 
<https://ci-beam.apache.org/job/beam_PostCommit_Python38/2439/display/redirect?page=changes>

Changes:

[chamikaramj] Mapped JOB_STATE_RESOURCE_CLEANING_UP to RESOURCE_CLEANING_UP in 
Python

[noreply] Explicitly import estimator from tensorflow (#17168)


------------------------------------------
[...truncated 30.07 MB...]
message: "Closing all cached grpc data channels."
log_location: 
"/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/data_plane.py:782"
thread: "MainThread"

INFO:root:severity: INFO
timestamp {
  seconds: 1648275727
  nanos: 735065698
}
message: "Closing all cached gRPC state handlers."
log_location: 
"/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py:859"
thread: "MainThread"

INFO:root:severity: INFO
timestamp {
  seconds: 1648275727
  nanos: 749976158
}
message: "Done consuming work."
log_location: 
"/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py:257"
thread: "MainThread"

INFO:root:severity: INFO
timestamp {
  seconds: 1648275727
  nanos: 750262260
}
message: "Python sdk harness exiting."
log_location: 
"/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker_main.py:181"
thread: "MainThread"

INFO:apache_beam.runners.portability.local_job_service:Successfully completed 
job in 17.08671998977661 seconds.
INFO:root:Successfully completed job in 17.08671998977661 seconds.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE

> Task :sdks:python:test-suites:portable:py38:portableWordCountSparkRunnerBatch
INFO:apache_beam.runners.worker.worker_pool_main:Listening for workers at 
localhost:40617
WARNING:root:Make sure that locally built Python SDK docker image has Python 
3.8 interpreter.
INFO:root:Default Python SDK image for environment is 
apache/beam_python3.8_sdk:2.39.0.dev
INFO:apache_beam.runners.portability.fn_api_runner.translations:====================
 <function pack_combiners at 0x7f8a8cdc1550> ====================
INFO:apache_beam.runners.portability.fn_api_runner.translations:====================
 <function lift_combiners at 0x7f8a8cdc15e0> ====================
INFO:apache_beam.runners.portability.fn_api_runner.translations:====================
 <function sort_stages at 0x7f8a8cdc1d30> ====================
INFO:apache_beam.utils.subprocess_server:Starting service with ['java' '-jar' 
'<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-job-server-2.39.0-SNAPSHOT.jar'>
 '--spark-master-url' 'local[4]' '--artifacts-dir' 
'/tmp/beam-tempyki129q0/artifactshgh9odna' '--job-port' '48713' 
'--artifact-port' '0' '--expansion-port' '0']
E0326 06:22:15.142819836 3391677 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
WARNING:root:Waiting for grpc channel to be ready at localhost:48713.
WARNING:root:Waiting for grpc channel to be ready at localhost:48713.
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:21 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
WARNING:root:Waiting for grpc channel to be ready at localhost:48713.
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:23 INFO 
org.apache.beam.runners.jobsubmission.JobServerDriver: ArtifactStagingService 
started on localhost:36905'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:23 INFO 
org.apache.beam.runners.jobsubmission.JobServerDriver: Java ExpansionService 
started on localhost:33091'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:23 INFO 
org.apache.beam.runners.jobsubmission.JobServerDriver: JobService started on 
localhost:48713'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:23 INFO 
org.apache.beam.runners.jobsubmission.JobServerDriver: Job server now running, 
terminate with Ctrl+C'
WARNING:root:Waiting for grpc channel to be ready at localhost:48713.
WARNING:root:Waiting for grpc channel to be ready at localhost:48713.
WARNING:apache_beam.options.pipeline_options:Discarding unparseable args: 
['--parallelism=2']
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:26 INFO 
org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Staging 
artifacts for job_6761de1d-1ef1-4260-8cdf-02c51bc58ade.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:26 INFO 
org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Resolving 
artifacts for 
job_6761de1d-1ef1-4260-8cdf-02c51bc58ade.ref_Environment_default_environment_1.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:26 INFO 
org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Getting 1 
artifacts for job_6761de1d-1ef1-4260-8cdf-02c51bc58ade.null.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:26 INFO 
org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Artifacts 
fully staged for job_6761de1d-1ef1-4260-8cdf-02c51bc58ade.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:27 INFO 
org.apache.beam.runners.spark.SparkJobInvoker: Invoking job 
BeamApp-jenkins-0326062227-63e0f09b_14d60c75-4efd-4f0d-9a39-ab7098d54f39'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:28 INFO 
org.apache.beam.runners.jobsubmission.JobInvocation: Starting job invocation 
BeamApp-jenkins-0326062227-63e0f09b_14d60c75-4efd-4f0d-9a39-ab7098d54f39'
INFO:apache_beam.runners.portability.portable_runner:Environment "LOOPBACK" has 
started a component necessary for the execution. Be sure to run the pipeline 
using
  with Pipeline() as p:
    p.apply(..)
This ensures that the pipeline finishes before this program exits.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to 
STOPPED
INFO:apache_beam.runners.portability.portable_runner:Job state changed to 
STARTING
INFO:apache_beam.runners.portability.portable_runner:Job state changed to 
RUNNING
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:29 INFO 
org.apache.beam.runners.spark.translation.SparkContextFactory: Creating a brand 
new Spark Context.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:30 WARN 
org.apache.hadoop.util.NativeCodeLoader: Unable to load native-hadoop library 
for your platform... using builtin-java classes where applicable'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:33 INFO 
org.apache.beam.runners.spark.aggregators.AggregatorsAccumulator: Instantiated 
aggregators accumulator:'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:33 INFO 
org.apache.beam.runners.spark.metrics.MetricsAccumulator: Instantiated metrics 
accumulator: MetricQueryResults()'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:34 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:34 INFO 
org.apache.beam.runners.spark.SparkPipelineRunner: Running job 
BeamApp-jenkins-0326062227-63e0f09b_14d60c75-4efd-4f0d-9a39-ab7098d54f39 on 
Spark master local[4]'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:36 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:36 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:36 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:36 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.runners.worker.statecache:Creating state cache with size 0
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure control channel 
for localhost:42891.
INFO:apache_beam.runners.worker.sdk_worker:Control channel established.
INFO:apache_beam.runners.worker.sdk_worker:Initializing SDKHarness with 
unbounded number of workers.
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:37 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam 
Fn Control client connected with id 1-1'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:37 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-2'
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure state channel for 
localhost:44199.
INFO:apache_beam.runners.worker.sdk_worker:State channel established.
INFO:apache_beam.runners.worker.data_plane:Creating client data channel for 
localhost:39487
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:37 INFO 
org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client 
connected.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:38 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-3'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:38 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:38 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:38 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:38 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:38 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-4'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:38 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-5'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-6'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-8'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-7'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-9'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-10'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-11'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-12'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-13'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:39 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-14'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:40 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:40 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:40 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:40 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-15'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:40 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:40 INFO 
org.apache.beam.runners.spark.SparkPipelineRunner: Job 
BeamApp-jenkins-0326062227-63e0f09b_14d60c75-4efd-4f0d-9a39-ab7098d54f39: 
Pipeline translated successfully. Computing outputs'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:40 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:40 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:40 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:40 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.'
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:40 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-16'
INFO:apache_beam.io.filebasedsink:Starting finalize_write threads with 
num_shards: 4 (skipped: 0), batches: 4, num_threads: 4
INFO:apache_beam.io.filebasedsink:Renamed 4 shards in 0.07 seconds.
INFO:apache_beam.utils.subprocess_server:b'22/03/26 06:22:40 INFO 
org.apache.beam.runners.spark.SparkPipelineRunner: Job 
BeamApp-jenkins-0326062227-63e0f09b_14d60c75-4efd-4f0d-9a39-ab7098d54f39 
finished.'
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE
Exception in thread read_state:
Traceback (most recent call last):
  File "/usr/lib/python3.8/threading.py", line 932, in _bootstrap_inner
ERROR:apache_beam.runners.worker.data_plane:Failed to read inputs in the data 
plane.
Traceback (most recent call last):
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py";,>
 line 634, in _read_inputs
    for elements in elements_iterator:
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/grpc/_channel.py";,>
 line 426, in __next__
    return self._next()
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/grpc/_channel.py";,>
 line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that 
terminated with:
        status = StatusCode.UNAVAILABLE
        details = "Socket closed"
        debug_error_string = 
"{"created":"@1648275761.532109466","description":"Error received from peer 
ipv6:[::1]:39487","file":"src/core/lib/surface/call.cc","file_line":903,"grpc_message":"Socket
 closed","grpc_status":14}"
>
Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.8/threading.py", line 932, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.8/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py";,>
 line 651, in <lambda>
    target=lambda: self._read_inputs(elements_iterator),
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py";,>
 line 634, in _read_inputs
    for elements in elements_iterator:
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/grpc/_channel.py";,>
 line 426, in __next__
    return self._next()
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/grpc/_channel.py";,>
 line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that 
terminated with:
        status = StatusCode.UNAVAILABLE
        details = "Socket closed"
        debug_error_string = 
"{"created":"@1648275761.532109466","description":"Error received from peer 
ipv6:[::1]:39487","file":"src/core/lib/surface/call.cc","file_line":903,"grpc_message":"Socket
 closed","grpc_status":14}"
>
    self.run()
  File "/usr/lib/python3.8/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 990, in pull_responses
    for response in responses:
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/grpc/_channel.py";,>
 line 426, in __next__
    return self._next()
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/grpc/_channel.py";,>
 line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that 
terminated with:
        status = StatusCode.UNAVAILABLE
        details = "Socket closed"
        debug_error_string = 
"{"created":"@1648275761.532121653","description":"Error received from peer 
ipv6:[::1]:44199","file":"src/core/lib/surface/call.cc","file_line":903,"grpc_message":"Socket
 closed","grpc_status":14}"
>
Exception in thread run_worker_1-1:
Traceback (most recent call last):
  File "/usr/lib/python3.8/threading.py", line 932, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.8/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 234, in run
    for work_request in self._control_stub.Control(get_responses()):
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/grpc/_channel.py";,>
 line 426, in __next__
    return self._next()
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/build/gradleenv/2022703442/lib/python3.8/site-packages/grpc/_channel.py";,>
 line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that 
terminated with:
        status = StatusCode.UNAVAILABLE
        details = "Socket closed"
        debug_error_string = 
"{"created":"@1648275761.541745007","description":"Error received from peer 
ipv6:[::1]:42891","file":"src/core/lib/surface/call.cc","file_line":903,"grpc_message":"Socket
 closed","grpc_status":14}"
>

> Task :sdks:python:test-suites:dataflow:py38:postCommitIT
E0326 06:25:17.436168689 3254121 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 06:28:31.440450871 3254236 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 06:31:20.054684813 3254129 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 06:33:31.824393603 3254121 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 06:37:16.514240775 3254236 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 06:39:54.623786987 3254129 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 06:44:10.127099867 3254121 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 06:47:14.351029234 3254236 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 06:48:20.415887899 3254129 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 06:54:13.792914841 3254121 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 07:03:28.267083986 3254121 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 07:05:35.359097453 3254236 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 07:11:37.044404509 3254121 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 07:17:09.578887598 3254178 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 07:21:06.405463048 3254121 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 07:23:43.352805067 3254236 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 07:29:30.911423754 3254178 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 07:30:21.241031148 3254121 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 07:38:50.998028368 3254121 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies
E0326 07:48:10.648139684 3254121 fork_posix.cc:70]           Fork support is 
only compatible with the epoll1 and poll polling strategies

FAILURE: Build failed with an exception.

* Where:
Script 
'<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/sdks/python/test-suites/portable/common.gradle'>
 line: 314

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

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

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

Deprecated Gradle features were used in this build, making it incompatible with 
Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings 
and determine if they come from your own scripts or plugins.

See 
https://docs.gradle.org/7.3.2/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during 
this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 55m 43s
219 actionable tasks: 156 executed, 57 from cache, 6 up-to-date

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

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]

Reply via email to