You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@flink.apache.org by "Gyula Fora (JIRA)" <ji...@apache.org> on 2017/04/04 13:39:41 UTC

[jira] [Created] (FLINK-6264) Kafka consumer fails if can't find leader for partition

Gyula Fora created FLINK-6264:
---------------------------------

             Summary: Kafka consumer fails if can't find leader for partition
                 Key: FLINK-6264
                 URL: https://issues.apache.org/jira/browse/FLINK-6264
             Project: Flink
          Issue Type: Bug
          Components: Kafka Connector
    Affects Versions: 1.2.0
            Reporter: Gyula Fora


We have observed the following error many times when brokers failed/were restarted:

java.lang.RuntimeException: Unable to find a leader for partitions: [Partition: KafkaTopicPartition{topic='mytopic', partition=10}, KafkaPartitionHandle=[mytopic,10], offset=-1]
	at org.apache.flink.streaming.connectors.kafka.internals.Kafka08Fetcher.findLeaderForPartitions(Kafka08Fetcher.java:474)
	at org.apache.flink.streaming.connectors.kafka.internals.Kafka08Fetcher.runFetchLoop(Kafka08Fetcher.java:194)
	at org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase.run(FlinkKafkaConsumerBase.java:256)
	at org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:78)
	at org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:55)
	at org.apache.flink.streaming.runtime.tasks.SourceStreamTask.run(SourceStreamTask.java:56)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:261)
	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:656)
	at java.lang.Thread.run(Thread.java:745)



--
This message was sent by Atlassian JIRA
(v6.3.15#6346)