Description
Seen causing failure of `SmokeTestDirverIntegrationTest#shouldWorkWithRebalance locally:
Caused by: java.lang.IllegalStateException: A checkpoint should only be written if no commit is needed. at org.apache.kafka.streams.processor.internals.StreamTask.writeCheckpointIfNeed(StreamTask.java:534) at org.apache.kafka.streams.processor.internals.StreamTask.closeAndRecycleState(StreamTask.java:482) at org.apache.kafka.streams.processor.internals.StandbyTaskCreator.createStandbyTaskFromActive(StandbyTaskCreator.java:115) at org.apache.kafka.streams.processor.internals.TaskManager.handleAssignment(TaskManager.java:288)
See comment here: https://github.com/apache/kafka/pull/8833/files#r438953766
Attachments
Issue Links
- duplicates
-
KAFKA-10150 IllegalStateException when revoking task in CREATED state
- Resolved
- links to