Uploaded image for project: 'Kafka'
  1. Kafka
  2. KAFKA-10152

Attempt to write checkpoint without first committing during recycle

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Resolved
    • Blocker
    • Resolution: Fixed
    • None
    • 2.6.0
    • streams
    • None

    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

          Activity

            People

              ableegoldman A. Sophie Blee-Goldman
              ableegoldman A. Sophie Blee-Goldman
              Votes:
              0 Vote for this issue
              Watchers:
              2 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: