You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user@flink.apache.org by Abhijeet Kumar <ab...@sentienz.com> on 2018/11/21 08:49:48 UTC

Kafka: Unable to retrieve any partitions with KafkaTopicsDescriptor

Hello Team,

I have written a streaming job that takes data from Kafka. I've noticed for some Kafka topics things are working fine but, with the few topics when I'm trying to get the data it's throwing error:

Exception in thread "main" org.apache.flink.runtime.client.JobExecutionException: java.lang.RuntimeException: Unable to retrieve any partitions with KafkaTopicsDescriptor: Fixed Topics ([crimedatademo])
	at org.apache.flink.runtime.minicluster.MiniCluster.executeJobBlocking(MiniCluster.java:623)
	at org.apache.flink.streaming.api.environment.LocalStreamEnvironment.execute(LocalStreamEnvironment.java:123)
	at org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.execute(StreamExecutionEnvironment.java:1511)
	at com.argoid.crimedemo.flink.streaming.CrimeDemo.CrimeDemoStream.startStream(CrimeDemoStream.java:82)
	at com.argoid.crimedemo.flink.streaming.CrimeDemo.CrimeDemoApplication.main(CrimeDemoApplication.java:5)
Caused by: java.lang.RuntimeException: Unable to retrieve any partitions with KafkaTopicsDescriptor: Fixed Topics ([crimedatademo])
	at org.apache.flink.streaming.connectors.kafka.internals.AbstractPartitionDiscoverer.discoverPartitions(AbstractPartitionDiscoverer.java:153)
	at org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase.open(FlinkKafkaConsumerBase.java:473)
	at org.apache.flink.api.common.functions.util.FunctionUtils.openFunction(FunctionUtils.java:36)
	at org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator.open(AbstractUdfStreamOperator.java:102)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.openAllOperators(StreamTask.java:424)
	at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:290)
	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:711)
	at java.lang.Thread.run(Unknown Source)

I'm using 
Kafka --> 1.1.0 
Flink --> 1.6.1  
Kafka flink connector --> 1.6.1

Thanks,

	
Abhijeet Kumar
Software Development Engineer,
Sentienz Solutions Pvt Ltd
Cognitive Data Platform - Perceive the Data !
abhijeet.kumar@sentienz.com <ma...@sentienz.com> |www.sentienz.com <http://www.sentienz.com/> | Bengaluru