You are viewing a plain text version of this content. The canonical link for it is here.
Posted to github@beam.apache.org by GitBox <gi...@apache.org> on 2022/06/03 19:19:12 UTC

[GitHub] [beam] kennknowles opened a new issue, #18560: MqttIO CheckpointMark decoding randomly fails

kennknowles opened a new issue, #18560:
URL: https://github.com/apache/beam/issues/18560

   Randomly, the decoding of MQTT CheckpointMark randomly fails:
   
   ```
   
   Caused by: org.apache.beam.sdk.coders.CoderException: 95 unexpected extra bytes after decoding org.apache.beam.sdk.io.mqtt.MqttIO$MqttCheckpointMark@14922739
   	at
   org.apache.beam.sdk.util.CoderUtils.decodeFromByteArray(CoderUtils.java:116)
   	at org.apache.beam.sdk.util.CoderUtils.decodeFromByteArray(CoderUtils.java:107)
   	at
   org.apache.beam.sdk.util.CoderUtils.clone(CoderUtils.java:156)
   	at org.apache.beam.runners.direct.UnboundedReadEvaluatorFactory$UnboundedReadEvaluator.getReader(UnboundedReadEvaluatorFactory.java:191)
   	at
   org.apache.beam.runners.direct.UnboundedReadEvaluatorFactory$UnboundedReadEvaluator.processElement(UnboundedReadEvaluatorFactory.java:127)
   	at
   org.apache.beam.runners.direct.TransformExecutor.processElements(TransformExecutor.java:146)
   	at org.apache.beam.runners.direct.TransformExecutor.run(TransformExecutor.java:110)
   	at
   java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
   	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
   	at
   java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142)
   	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:617)
   	at
   java.lang.Thread.run(Thread.java:745)
   
   ```
   
   
   It happens especially when the number of messages to consume from the MQTT topic is high.
   
   Imported from Jira [BEAM-3274](https://issues.apache.org/jira/browse/BEAM-3274). Original Jira may contain additional context.
   Reported by: jbonofre.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org