See 
<https://ci-beam.apache.org/job/beam_PostCommit_Python39/2641/display/redirect>

Changes:


------------------------------------------
[...truncated 10.60 MB...]
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"apache_beam/coders/coder_impl.py", line 1837, in 
apache_beam.coders.coder_impl.RowCoderImpl.decode_from_stream
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     item 
= component_coder.decode_from_stream(in_stream, True)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"apache_beam/coders/coder_impl.py", line 1890, in 
apache_beam.coders.coder_impl.LogicalTypeCoderImpl.decode_from_stream
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
return self.logical_type.to_language_type(
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/typehints/schemas.py";,>
 line 1000, in to_language_type
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
return DecimalLogicalType().to_language_type(value)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/typehints/schemas.py";,>
 line 962, in to_language_type
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
return decimal.Decimal(value.decode())
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 
AttributeError: 'decimal.Decimal' object has no attribute 'decode'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 The above 
exception was the direct cause of the following exception:
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 Traceback 
(most recent call last):
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 300, in _execute
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
response = task()
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 375, in <lambda>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
lambda: self.create_worker().do_instruction(request), request)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 631, in do_instruction
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
return getattr(self, request_type)(
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 669, in process_bundle
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
bundle_processor.process_bundle(instruction_id))
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py";,>
 line 1113, in process_bundle
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
input_op_by_transform_id[element.transform_id].process_encoded(
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py";,>
 line 234, in process_encoded
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     raise 
ValueError(
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 
ValueError: Error decoding input stream with coder WindowedValueCoder[RowCoder]
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1908)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.sdk.util.MoreFutures.get(MoreFutures.java:61)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.runners.fnexecution.control.SdkHarnessClient$BundleProcessor$ActiveBundle.close(SdkHarnessClient.java:522)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$SimpleStageBundleFactory$1.close(DefaultJobBundleFactory.java:562)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.runners.flink.translation.functions.FlinkExecutableStageFunction.$closeResource(FlinkExecutableStageFunction.java:269)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.runners.flink.translation.functions.FlinkExecutableStageFunction.mapPartition(FlinkExecutableStageFunction.java:269)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.flink.runtime.operators.MapPartitionDriver.run(MapPartitionDriver.java:113)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.flink.runtime.operators.BatchTask.run(BatchTask.java:514)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.flink.runtime.operators.BatchTask.invoke(BatchTask.java:357)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.flink.runtime.taskmanager.Task.runWithSystemExitMonitoring(Task.java:935)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.flink.runtime.taskmanager.Task.restoreAndInvoke(Task.java:914)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:728)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.flink.runtime.taskmanager.Task.run(Task.java:550)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
java.lang.Thread.run(Thread.java:750)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 Caused 
by: java.lang.RuntimeException: Error received from SDK harness for instruction 
6: Traceback (most recent call last):
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py";,>
 line 231, in process_encoded
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
decoded_value = self.windowed_coder_impl.decode_from_stream(
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"apache_beam/coders/coder_impl.py", line 1469, in 
apache_beam.coders.coder_impl.WindowedValueCoderImpl.decode_from_stream
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     def 
decode_from_stream(self, in_stream, nested):
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"apache_beam/coders/coder_impl.py", line 1488, in 
apache_beam.coders.coder_impl.WindowedValueCoderImpl.decode_from_stream
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     value 
= self._value_coder.decode_from_stream(in_stream, nested)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"apache_beam/coders/coder_impl.py", line 1837, in 
apache_beam.coders.coder_impl.RowCoderImpl.decode_from_stream
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     item 
= component_coder.decode_from_stream(in_stream, True)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"apache_beam/coders/coder_impl.py", line 1890, in 
apache_beam.coders.coder_impl.LogicalTypeCoderImpl.decode_from_stream
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
return self.logical_type.to_language_type(
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/typehints/schemas.py";,>
 line 1000, in to_language_type
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
return DecimalLogicalType().to_language_type(value)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/typehints/schemas.py";,>
 line 962, in to_language_type
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
return decimal.Decimal(value.decode())
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 
AttributeError: 'decimal.Decimal' object has no attribute 'decode'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 The above 
exception was the direct cause of the following exception:
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 Traceback 
(most recent call last):
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 300, in _execute
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
response = task()
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 375, in <lambda>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
lambda: self.create_worker().do_instruction(request), request)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 631, in do_instruction
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
return getattr(self, request_type)(
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 669, in process_bundle
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
bundle_processor.process_bundle(instruction_id))
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py";,>
 line 1113, in process_bundle
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     
input_op_by_transform_id[element.transform_id].process_encoded(
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py";,>
 line 234, in process_encoded
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213     raise 
ValueError(
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 
ValueError: Error decoding input stream with coder WindowedValueCoder[RowCoder]
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.vendor.grpc.v1p54p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:262)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.vendor.grpc.v1p54p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.vendor.grpc.v1p54p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.vendor.grpc.v1p54p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:333)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.vendor.grpc.v1p54p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:316)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.vendor.grpc.v1p54p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:835)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.vendor.grpc.v1p54p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
org.apache.beam.vendor.grpc.v1p54p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   at 
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213   ... 1 
more
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:213 
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:550 
Job state changed to FAILED
=============================== warnings summary ===============================
apache_beam/io/external/xlang_jdbcio_it_test.py::CrossLanguageJdbcIOTest::test_xlang_jdbc_write_read_0_postgres
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/external/xlang_jdbcio_it_test.py>:132:
 RemovedIn20Warning: Deprecated API features detected! These feature(s) are not 
compatible with SQLAlchemy 2.0. To prevent incompatible upgrades prior to 
updating applications, ensure requirements files are pinned to 
"sqlalchemy<2.0". Set environment variable SQLALCHEMY_WARN_20=1 to show all 
deprecation warnings.  Set environment variable 
SQLALCHEMY_SILENCE_UBER_WARNING=1 to silence this message. (Background on 
SQLAlchemy 2.0 at: https://sqlalche.me/e/b8d9)
    self.engine.execute(

apache_beam/io/external/xlang_jdbcio_it_test.py::CrossLanguageJdbcIOTest::test_xlang_jdbc_write_read_0_postgres
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/_pytest/threadexception.py>:73:
 PytestUnhandledThreadExceptionWarning: Exception in thread 
read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.9/threading.py", line 973, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.9/threading.py", line 910, in run
      self._target(*self._args, **self._kwargs)
    File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py";,>
 line 686, in <lambda>
      target=lambda: self._read_inputs(elements_iterator),
    File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py";,>
 line 669, in _read_inputs
      for elements in elements_iterator:
    File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py";,>
 line 540, in __next__
      return self._next()
    File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py";,>
 line 966, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that 
terminated with:
        status = StatusCode.CANCELLED
        details = "Multiplexer hanging up"
        debug_error_string = "UNKNOWN:Error received from peer 
ipv6:%5B::1%5D:44095 {grpc_message:"Multiplexer hanging up", grpc_status:1, 
created_time:"2023-12-12T00:36:40.575045736+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/io/external/xlang_kafkaio_it_test.py::CrossLanguageKafkaIOTest::test_local_kafkaio_null_key
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/_pytest/threadexception.py>:73:
 PytestUnhandledThreadExceptionWarning: Exception in thread 
read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.9/threading.py", line 973, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.9/threading.py", line 910, in run
      self._target(*self._args, **self._kwargs)
    File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py";,>
 line 686, in <lambda>
      target=lambda: self._read_inputs(elements_iterator),
    File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py";,>
 line 669, in _read_inputs
      for elements in elements_iterator:
    File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py";,>
 line 540, in __next__
      return self._next()
    File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py";,>
 line 966, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that 
terminated with:
        status = StatusCode.CANCELLED
        details = "Multiplexer hanging up"
        debug_error_string = "UNKNOWN:Error received from peer 
ipv6:%5B::1%5D:32917 {created_time:"2023-12-12T00:38:46.130336004+00:00", 
grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/io/external/xlang_debeziumio_it_test.py::CrossLanguageDebeziumIOTest::test_xlang_debezium_read
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/_pytest/threadexception.py>:73:
 PytestUnhandledThreadExceptionWarning: Exception in thread 
read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.9/threading.py", line 973, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.9/threading.py", line 910, in run
      self._target(*self._args, **self._kwargs)
    File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py";,>
 line 686, in <lambda>
      target=lambda: self._read_inputs(elements_iterator),
    File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py";,>
 line 669, in _read_inputs
      for elements in elements_iterator:
    File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py";,>
 line 540, in __next__
      return self._next()
    File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py";,>
 line 966, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that 
terminated with:
        status = StatusCode.CANCELLED
        details = "Multiplexer hanging up"
        debug_error_string = "UNKNOWN:Error received from peer 
ipv6:%5B::1%5D:39455 {created_time:"2023-12-12T00:40:59.481225803+00:00", 
grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: 
<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/pytest_postCommitIT-flink-py39.xml>
 -
=========================== short test summary info ============================
FAILED 
apache_beam/io/external/xlang_jdbcio_it_test.py::CrossLanguageJdbcIOTest::test_xlang_jdbc_write_read_0_postgres
 - RuntimeError: Pipeline 
BeamApp-jenkins-1212003617-85f7990a_e935d5e9-f013-41ef-812d-cc9e97eefa4c failed 
in state FAILED: java.lang.RuntimeException: Error received from SDK harness 
for instruction 6: Traceback (most recent call last):
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py";,>
 line 231, in process_encoded
    decoded_value = self.windowed_coder_impl.decode_from_stream(
  File "apache_beam/coders/coder_impl.py", line 1469, in 
apache_beam.coders.coder_impl.WindowedValueCoderImpl.decode_from_stream
    def decode_from_stream(self, in_stream, nested):
  File "apache_beam/coders/coder_impl.py", line 1488, in 
apache_beam.coders.coder_impl.WindowedValueCoderImpl.decode_from_stream
    value = self._value_coder.decode_from_stream(in_stream, nested)
  File "apache_beam/coders/coder_impl.py", line 1837, in 
apache_beam.coders.coder_impl.RowCoderImpl.decode_from_stream
    item = component_coder.decode_from_stream(in_stream, True)
  File "apache_beam/coders/coder_impl.py", line 1890, in 
apache_beam.coders.coder_impl.LogicalTypeCoderImpl.decode_from_stream
    return self.logical_type.to_language_type(
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/typehints/schemas.py";,>
 line 1000, in to_language_type
    return DecimalLogicalType().to_language_type(value)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/typehints/schemas.py";,>
 line 962, in to_language_type
    return decimal.Decimal(value.decode())
AttributeError: 'decimal.Decimal' object has no attribute 'decode'

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_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 300, in _execute
    response = task()
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 375, in <lambda>
    lambda: self.create_worker().do_instruction(request), request)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 631, in do_instruction
    return getattr(self, request_type)(
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 669, in process_bundle
    bundle_processor.process_bundle(instruction_id))
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py";,>
 line 1113, in process_bundle
    input_op_by_transform_id[element.transform_id].process_encoded(
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py";,>
 line 234, in process_encoded
    raise ValueError(
ValueError: Error decoding input stream with coder WindowedValueCoder[RowCoder]
======= 1 failed, 19 passed, 7 skipped, 4 warnings in 659.84s (0:10:59) ========

> Task :sdks:python:test-suites:dataflow:py39:postCommitIT

[gw2] PASSED 
apache_beam/io/gcp/bigquery_io_read_it_test.py::BigqueryIOReadIT::test_bigquery_read_1M_python
 
apache_beam/io/gcp/bigquery_io_read_it_test.py::BigqueryIOReadIT::test_bigquery_read_custom_1M_python
 
> Task :sdks:python:test-suites:portable:py39:postCommitPy39IT FAILED

> Task :sdks:python:test-suites:dataflow:py39:postCommitIT
<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/-1734967050/bin/python3.9>:
 No module named build
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) should be supplied


FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task 
':sdks:python:test-suites:portable:py39:postCommitPy39IT'.
> 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 1h 45m 24s
222 actionable tasks: 201 executed, 17 from cache, 4 up-to-date

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

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

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

Reply via email to