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

java.lang.IllegalStateException: There are insufficient bytes available to read assignment from the sync-group response (actual byte size 0)

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Closed
    • Blocker
    • Resolution: Duplicate
    • 2.6.0
    • None
    • streams
    • None

    Description

      From time to time we encounter the following exception that results in Kafka Streams threads dying.

      Broker version 2.4.1, Client version 2.6.0

      Nov 27 00:59:53.681 streaming-app service: prod | streaming-app-2 | stream-client [cluster1-profile-stats-pipeline-client-id] State transition from REBALANCING to ERROR Nov 27 00:59:53.681 streaming-app service: prod | streaming-app-2 | stream-client [cluster1-profile-stats-pipeline-client-id] State transition from REBALANCING to ERROR Nov 27 00:59:53.682 streaming-app service: prod | streaming-app-2 | 2020-11-27 00:59:53.681 ERROR 105 --- [-StreamThread-1] .KafkaStreamsBasedStreamProcessingEngine : Stream processing pipeline: [profile-stats] encountered unrecoverable exception. Thread: [cluster1-profile-stats-pipeline-client-id-StreamThread-1] is completely dead. If all worker threads die, Kafka Streams will be moved to permanent ERROR state. Nov 27 00:59:53.682 streaming-app service: prod | streaming-app-2 | Stream processing pipeline: [profile-stats] encountered unrecoverable exception. Thread: [cluster1-profile-stats-pipeline-client-id-StreamThread-1] is completely dead. If all worker threads die, Kafka Streams will be moved to permanent ERROR state. java.lang.IllegalStateException: There are insufficient bytes available to read assignment from the sync-group response (actual byte size 0) , this is not expected; it is possible that the leader's assign function is buggy and did not return any assignment for this member, or because static member is configured and the protocol is buggy hence did not get the assignment for this member at org.apache.kafka.clients.consumer.internals.ConsumerCoordinator.onJoinComplete(ConsumerCoordinator.java:367) at org.apache.kafka.clients.consumer.internals.AbstractCoordinator.joinGroupIfNeeded(AbstractCoordinator.java:440) at org.apache.kafka.clients.consumer.internals.AbstractCoordinator.ensureActiveGroup(AbstractCoordinator.java:359) at org.apache.kafka.clients.consumer.internals.ConsumerCoordinator.poll(ConsumerCoordinator.java:513) at org.apache.kafka.clients.consumer.KafkaConsumer.updateAssignmentMetadataIfNeeded(KafkaConsumer.java:1268) at org.apache.kafka.clients.consumer.KafkaConsumer.poll(KafkaConsumer.java:1230) at org.apache.kafka.clients.consumer.KafkaConsumer.poll(KafkaConsumer.java:1210) at org.apache.kafka.streams.processor.internals.StreamThread.pollRequests(StreamThread.java:766) at org.apache.kafka.streams.processor.internals.StreamThread.runOnce(StreamThread.java:624) at org.apache.kafka.streams.processor.internals.StreamThread.runLoop(StreamThread.java:551) at org.apache.kafka.streams.processor.internals.StreamThread.run(StreamThread.java:510)
      

      Attachments

        1. KAFKA-10772.log
          30 kB
          Levani Kokhreidze

        Issue Links

          Activity

            People

              cadonna Bruno Cadonna
              lkokhreidze Levani Kokhreidze
              Votes:
              0 Vote for this issue
              Watchers:
              8 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: