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

Changes:

[noreply] interface{} -> any for registration (#24600)

[noreply] Restrict tox to be in 3.x version (#24601)


------------------------------------------
[...truncated 9.76 MB...]
log_location: 
"/usr/local/lib/python3.8/site-packages/apache_beam/runners/worker/sdk_worker.py:277"
thread: "MainThread"

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

75fb14fb781718321fa2d8836d312c7f2cfddc50ed0ac6faaf43bcdadde7291c
INFO:apache_beam.runners.portability.local_job_service:Completed job in 
16.232184171676636 seconds with state DONE.
INFO:root:Completed job in 16.232184171676636 seconds with state DONE.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE

> Task :sdks:python:test-suites:dataflow:py38:postCommitIT
>>> RUNNING integration tests with pipeline options: 
>>> --runner=TestDataflowRunner --project=apache-beam-testing 
>>> --region=us-central1 
>>> --staging_location=gs://temp-storage-for-end-to-end-tests/staging-it 
>>> --temp_location=gs://temp-storage-for-end-to-end-tests/temp-it 
>>> --output=gs://temp-storage-for-end-to-end-tests/py-it-cloud/output 
>>> --sdk_location=<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/sdks/python/build/apache-beam.tar.gz>
>>>  --requirements_file=postcommit_requirements.txt --num_workers=1 
>>> --sleep_secs=20 
>>> --kms_key_name=projects/apache-beam-testing/locations/global/keyRings/beam-it/cryptoKeys/test
>>>  
>>> --dataflow_kms_key=projects/apache-beam-testing/locations/global/keyRings/beam-it/cryptoKeys/test
>>>   pytest options: --capture=no --timeout=4500 --color=yes 
>>> --log-cli-level=INFO --numprocesses=8 --dist=loadfile
>>>   collect markers: -m=it_postcommit

> Task :sdks:python:test-suites:portable:py38:portableWordCountSparkRunnerBatch
INFO:apache_beam.runners.worker.worker_pool_main:Listening for workers at 
localhost:34469
INFO:root:Default Python SDK image for environment is 
apache/beam_python3.8_sdk:2.45.0.dev
INFO:apache_beam.runners.portability.fn_api_runner.translations:====================
 <function pack_combiners at 0x7f99620a0820> ====================
INFO:apache_beam.runners.portability.fn_api_runner.translations:====================
 <function lift_combiners at 0x7f99620a08b0> ====================
INFO:apache_beam.runners.portability.fn_api_runner.translations:====================
 <function sort_stages at 0x7f99620a2040> ====================
INFO:apache_beam.utils.subprocess_server:Starting service with ['java' '-jar' 
'<https://ci-beam.apache.org/job/beam_PostCommit_Python38/ws/src/runners/spark/3/job-server/build/libs/beam-runners-spark-3-job-server-2.45.0-SNAPSHOT.jar'>
 '--spark-master-url' 'local[4]' '--artifacts-dir' 
'/tmp/beam-temp_u2ms8jn/artifactsemnj4usn' '--job-port' '45905' 
'--artifact-port' '0' '--expansion-port' '0']
INFO:apache_beam.utils.subprocess_server:22/12/09 14:30:54 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:30:54 INFO 
org.apache.beam.runners.jobsubmission.JobServerDriver: ArtifactStagingService 
started on localhost:46773
INFO:apache_beam.utils.subprocess_server:22/12/09 14:30:55 INFO 
org.apache.beam.runners.jobsubmission.JobServerDriver: Java ExpansionService 
started on localhost:39407
INFO:apache_beam.utils.subprocess_server:22/12/09 14:30:55 INFO 
org.apache.beam.runners.jobsubmission.JobServerDriver: JobService started on 
localhost:45905
INFO:apache_beam.utils.subprocess_server:22/12/09 14:30:55 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:45905.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:30:57 INFO 
org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Staging 
artifacts for job_c0612827-cc15-4bcb-99f3-ddead85db777.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:30:57 INFO 
org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Resolving 
artifacts for 
job_c0612827-cc15-4bcb-99f3-ddead85db777.ref_Environment_default_environment_1.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:30:57 INFO 
org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Getting 1 
artifacts for job_c0612827-cc15-4bcb-99f3-ddead85db777.null.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:30:57 INFO 
org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Artifacts 
fully staged for job_c0612827-cc15-4bcb-99f3-ddead85db777.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:30:57 INFO 
org.apache.beam.runners.spark.SparkJobInvoker: Invoking job 
BeamApp-jenkins-1209143057-2c2c053f_36d6aafd-2f47-4105-8a9a-ca70fde09128
INFO:apache_beam.utils.subprocess_server:22/12/09 14:30:57 INFO 
org.apache.beam.runners.jobsubmission.JobInvocation: Starting job invocation 
BeamApp-jenkins-1209143057-2c2c053f_36d6aafd-2f47-4105-8a9a-ca70fde09128
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:22/12/09 14:30:58 INFO 
org.apache.beam.runners.spark.translation.SparkContextFactory: Creating a brand 
new Spark Context.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:30:58 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:22/12/09 14:30:59 INFO 
org.sparkproject.jetty.util.log: Logging initialized @8087ms to 
org.sparkproject.jetty.util.log.Slf4jLog
INFO:apache_beam.utils.subprocess_server:22/12/09 14:30:59 INFO 
org.sparkproject.jetty.server.Server: jetty-9.4.40.v20210413; built: 
2021-04-13T20:42:42.668Z; git: b881a572662e1943a14ae12e7e1207989f218b74; jvm 
1.8.0_352-8u352-ga-1~20.04-b08
INFO:apache_beam.utils.subprocess_server:22/12/09 14:30:59 INFO 
org.sparkproject.jetty.server.Server: Started @8424ms
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.AbstractConnector: Started 
ServerConnector@4309df21{HTTP/1.1, (http/1.1)}{127.0.0.1:4040}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@4bfa9812{/jobs,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@625a6661{/jobs/json,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@7f1a3d93{/jobs/job,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@43edc814{/jobs/job/json,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@6197d670{/stages,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@31447f90{/stages/json,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@2f51c1bf{/stages/stage,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@d36de0{/stages/stage/json,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@4014b285{/stages/pool,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@a2eb16c{/stages/pool/json,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@b48cdae{/storage,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@2e57cff9{/storage/json,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@63c1536b{/storage/rdd,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@4fc3e4ee{/storage/rdd/json,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@46cc4302{/environment,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@1785e790{/environment/json,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@64614641{/executors,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@17623735{/executors/json,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@37c8b3b3{/executors/threadDump,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@1a76fad{/executors/threadDump/json,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@72de397{/static,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@51395f1b{/,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@75258285{/api,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@234dc9fa{/jobs/job/kill,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@5355801{/stages/stage/kill,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.sparkproject.jetty.server.handler.ContextHandler: Started 
o.s.j.s.ServletContextHandler@14c3cc47{/metrics/json,null,AVAILABLE,@Spark}
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.apache.beam.runners.spark.aggregators.AggregatorsAccumulator: Instantiated 
aggregators accumulator:
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.apache.beam.runners.spark.metrics.MetricsAccumulator: Instantiated metrics 
accumulator: MetricQueryResults()
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:00 INFO 
org.apache.beam.runners.spark.SparkPipelineRunner: Running job 
BeamApp-jenkins-1209143057-2c2c053f_36d6aafd-2f47-4105-8a9a-ca70fde09128 on 
Spark master local[4]
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:01 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:01 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:01 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:01 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:45577.
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:22/12/09 14:31:02 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam 
Fn Control client connected with id 1-1
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:02 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:34933.
INFO:apache_beam.runners.worker.sdk_worker:State channel established.
INFO:apache_beam.runners.worker.data_plane:Creating client data channel for 
localhost:38241
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:02 INFO 
org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client 
connected.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:02 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-3
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:03 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:03 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:03 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:03 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:03 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-4
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:03 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-5
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-6
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-8
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-7
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-9
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-10
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-11
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-12
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-13
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-14
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 INFO 
org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: 
getProcessBundleDescriptor request with id 1-15
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 INFO 
org.apache.beam.runners.spark.SparkPipelineRunner: Job 
BeamApp-jenkins-1209143057-2c2c053f_36d6aafd-2f47-4105-8a9a-ca70fde09128: 
Pipeline translated successfully. Computing outputs
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:04 WARN 
software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to 
retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:05 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.01 seconds.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:05 INFO 
org.apache.beam.runners.spark.SparkPipelineRunner: Job 
BeamApp-jenkins-1209143057-2c2c053f_36d6aafd-2f47-4105-8a9a-ca70fde09128 
finished.
INFO:apache_beam.utils.subprocess_server:22/12/09 14:31:05 INFO 
org.sparkproject.jetty.server.AbstractConnector: Stopped 
Spark@4309df21{HTTP/1.1, (http/1.1)}{127.0.0.1:4040}
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
    self.run()
  File "/usr/lib/python3.8/threading.py", line 870, in run
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._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 1006, 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__
    self.run()
  File "/usr/lib/python3.8/threading.py", line 870, in run
    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 = "recvmsg:Connection reset by peer"
        debug_error_string = "UNKNOWN:Error received from peer 
ipv6:%5B::1%5D:34933 {grpc_message:"recvmsg:Connection reset by peer", 
grpc_status:14, created_time:"2022-12-09T14:31:05.795527475+00:00"}"
>
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 654, 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 = "recvmsg:Connection reset by peer"
        debug_error_string = "UNKNOWN:Error received from peer 
ipv6:%5B::1%5D:38241 {grpc_message:"recvmsg:Connection reset by peer", 
grpc_status:14, created_time:"2022-12-09T14:31:05.795501966+00:00"}"
>
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._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 254, in run
    self.run()
  File "/usr/lib/python3.8/threading.py", line 870, 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__
    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 671, in <lambda>
    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
    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 654, in _read_inputs
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that 
terminated with:
        status = StatusCode.UNAVAILABLE
        details = "recvmsg:Connection reset by peer"
        debug_error_string = "UNKNOWN:Error received from peer 
ipv6:%5B::1%5D:45577 {grpc_message:"recvmsg:Connection reset by peer", 
grpc_status:14, created_time:"2022-12-09T14:31:05.795501821+00:00"}"
>
    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 = "recvmsg:Connection reset by peer"
        debug_error_string = "UNKNOWN:Error received from peer 
ipv6:%5B::1%5D:38241 {grpc_message:"recvmsg:Connection reset by peer", 
grpc_status:14, created_time:"2022-12-09T14:31:05.795501966+00:00"}"
>

> Task :sdks:python:test-suites:portable:py38:postCommitPy38

> Task :sdks:python:test-suites:dataflow:py38:postCommitIT
warning: sdist: standard file not found: should have one of README, README.rst, 
README.txt, README.md

warning: check: missing required meta-data: url

warning: check: missing meta-data: either (author and author_email) or 
(maintainer and maintainer_email) must be supplied


> Task :sdks:python:test-suites:dataflow:py38:postCommitIT FAILED

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:postCommitIT'.
> 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.5.1/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 4h 12m 27s
204 actionable tasks: 145 executed, 53 from cache, 6 up-to-date

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

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