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

CachingSessionStore doesn't use the default keySerde.

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Resolved
    • Major
    • Resolution: Fixed
    • 0.10.2.0
    • 0.10.2.2, 0.11.0.0
    • streams
    • None

    Description

      CachingSessionStore wasn't properly using the default keySerde if no Serde was supplied. I saw the below error in the logs for one of my test cases.

      ERROR stream-thread [cogroup-integration-test-3-5570fe48-d2a3-4271-80b1-81962295553d-StreamThread-6] Streams application error during processing: (org.apache.kafka.streams.processor.internals.StreamThread:335)
      java.lang.NullPointerException
      at org.apache.kafka.streams.state.internals.CachingSessionStore.findSessions(CachingSessionStore.java:93)
      at org.apache.kafka.streams.kstream.internals.KStreamSessionWindowAggregate$KStreamSessionWindowAggregateProcessor.process(KStreamSessionWindowAggregate.java:94)
      at org.apache.kafka.streams.processor.internals.ProcessorNode$1.run(ProcessorNode.java:47)
      at org.apache.kafka.streams.processor.internals.StreamsMetricsImpl.measureLatencyNs(StreamsMetricsImpl.java:187)
      at org.apache.kafka.streams.processor.internals.ProcessorNode.process(ProcessorNode.java:133)
      at org.apache.kafka.streams.processor.internals.ProcessorContextImpl.forward(ProcessorContextImpl.java:82)
      at org.apache.kafka.streams.processor.internals.SourceNode.process(SourceNode.java:69)
      at org.apache.kafka.streams.processor.internals.StreamTask.process(StreamTask.java:206)
      at org.apache.kafka.streams.processor.internals.StreamThread.processAndPunctuate(StreamThread.java:657)
      at org.apache.kafka.streams.processor.internals.StreamThread.runLoop(StreamThread.java:728)
      at org.apache.kafka.streams.processor.internals.StreamThread.run(StreamThread.java:327)

      Attachments

        Activity

          People

            winkelman.kyle Kyle Winkelman
            winkelman.kyle Kyle Winkelman
            Votes:
            0 Vote for this issue
            Watchers:
            2 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved: