You are viewing a plain text version of this content. The canonical link for it is here.
Posted to jira@kafka.apache.org by "Levani Kokhreidze (Jira)" <ji...@apache.org> on 2020/11/27 06:59:00 UTC

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

    [ https://issues.apache.org/jira/browse/KAFKA-10772?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel&focusedCommentId=17239528#comment-17239528 ] 

Levani Kokhreidze commented on KAFKA-10772:
-------------------------------------------

cc [~ableegoldman] [~guozhang]

There have been some discussions around this exception in https://issues.apache.org/jira/browse/KAFKA-10134 but I couldn't find report around this bug. Not sure if 2.6.1 release addresses this problem, but we see this exception occurring that causes Kafka Streams to move to ERROR state.

 

> java.lang.IllegalStateException: There are insufficient bytes available to read assignment from the sync-group response (actual byte size 0)
> --------------------------------------------------------------------------------------------------------------------------------------------
>
>                 Key: KAFKA-10772
>                 URL: https://issues.apache.org/jira/browse/KAFKA-10772
>             Project: Kafka
>          Issue Type: Bug
>          Components: streams
>            Reporter: Levani Kokhreidze
>            Priority: Major
>
> From time to time we encounter the following exception that results in Kafka Streams threads dying.
> {code:java}
> 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)
> {code}



--
This message was sent by Atlassian Jira
(v8.3.4#803005)