You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@kafka.apache.org by "John Roesler (Jira)" <ji...@apache.org> on 2020/07/06 19:10:00 UTC

[jira] [Resolved] (KAFKA-10173) BufferUnderflowException during Kafka Streams Upgrade

     [ https://issues.apache.org/jira/browse/KAFKA-10173?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ]

John Roesler resolved KAFKA-10173.
----------------------------------
    Fix Version/s:     (was: 2.5.1)
                       (was: 2.4.2)
       Resolution: Fixed

> BufferUnderflowException during Kafka Streams Upgrade
> -----------------------------------------------------
>
>                 Key: KAFKA-10173
>                 URL: https://issues.apache.org/jira/browse/KAFKA-10173
>             Project: Kafka
>          Issue Type: Bug
>          Components: streams
>    Affects Versions: 2.5.0
>            Reporter: Karsten Schnitter
>            Assignee: John Roesler
>            Priority: Blocker
>              Labels: suppress
>             Fix For: 2.6.0
>
>
> I migrated a Kafka Streams application from version 2.3.1 to 2.5.0. I followed the steps described in the upgrade guide and set the property {{migrate.from=2.3}}. On my dev system with just one running instance I got the following exception:
> {noformat}
> stream-thread [0-StreamThread-2] Encountered the following error during processing:
> java.nio.BufferUnderflowException: null
> 	at java.base/java.nio.HeapByteBuffer.get(Unknown Source)
> 	at java.base/java.nio.ByteBuffer.get(Unknown Source)
> 	at org.apache.kafka.streams.state.internals.BufferValue.extractValue(BufferValue.java:94)
> 	at org.apache.kafka.streams.state.internals.BufferValue.deserialize(BufferValue.java:83)
> 	at org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer.restoreBatch(InMemoryTimeOrderedKeyValueBuffer.java:368)
> 	at org.apache.kafka.streams.processor.internals.CompositeRestoreListener.restoreBatch(CompositeRestoreListener.java:89)
> 	at org.apache.kafka.streams.processor.internals.StateRestorer.restore(StateRestorer.java:92)
> 	at org.apache.kafka.streams.processor.internals.StoreChangelogReader.processNext(StoreChangelogReader.java:350)
> 	at org.apache.kafka.streams.processor.internals.StoreChangelogReader.restore(StoreChangelogReader.java:94)
> 	at org.apache.kafka.streams.processor.internals.TaskManager.updateNewAndRestoringTasks(TaskManager.java:401)
> 	at org.apache.kafka.streams.processor.internals.StreamThread.runOnce(StreamThread.java:779)
> 	at org.apache.kafka.streams.processor.internals.StreamThread.runLoop(StreamThread.java:697)
> 	at org.apache.kafka.streams.processor.internals.StreamThread.run(StreamThread.java:670)
> {noformat}
> I figured out, that this problem only occurs for stores, where I use the suppress feature. If I rename the changelog topics during the migration, the problem will not occur. 



--
This message was sent by Atlassian Jira
(v8.3.4#803005)