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

NPE in SubscriptionState

Attach filesAttach ScreenshotVotersWatch issueWatchersCreate sub-taskLinkCloneUpdate Comment AuthorReplace String in CommentUpdate Comment VisibilityDelete Comments
    XMLWordPrintableJSON

Details

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

    Description

      In a soak test, we got this exception:

       

      java.lang.NullPointerException	at org.apache.kafka.clients.consumer.internals.SubscriptionState.partitionLag(SubscriptionState.java:545)	at org.apache.kafka.clients.consumer.KafkaConsumer.currentLag(KafkaConsumer.java:2241)	at org.apache.kafka.streams.processor.internals.PartitionGroup.readyToProcess(PartitionGroup.java:143)	at org.apache.kafka.streams.processor.internals.StreamTask.isProcessable(StreamTask.java:650)	at org.apache.kafka.streams.processor.internals.StreamTask.process(StreamTask.java:661)	at org.apache.kafka.streams.processor.internals.TaskManager.process(TaskManager.java:1114) 

      This is related to the implementation of:

      https://cwiki.apache.org/confluence/display/KAFKA/KIP-695%3A+Further+Improve+Kafka+Streams+Timestamp+Synchronization

      aka

      https://issues.apache.org/jira/browse/KAFKA-10091

       

      Luckily, the stack trace is pretty unambiguous. I'll open a PR shortly.

      Attachments

        Activity

          This comment will be Viewable by All Users Viewable by All Users
          Cancel

          People

            vvcephei John Roesler
            vvcephei John Roesler
            Votes:
            0 Vote for this issue
            Watchers:
            3 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved:

              Slack

                Issue deployment