You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by "Fokko Driesprong (JIRA)" <ji...@apache.org> on 2019/01/14 23:32:00 UTC

[jira] [Created] (FLINK-11321) Clarify the NPE on fetching an nonexistent Kafka topic

Fokko Driesprong created FLINK-11321:
----------------------------------------

             Summary: Clarify the NPE on fetching an nonexistent Kafka topic
                 Key: FLINK-11321
                 URL: https://issues.apache.org/jira/browse/FLINK-11321
             Project: Flink
          Issue Type: Improvement
          Components: Kafka Connector
    Affects Versions: 1.7.1
            Reporter: Fokko Driesprong
            Assignee: Fokko Driesprong
             Fix For: 1.8.0


Following exception isn't that descriptive:

java.lang.NullPointerException
	at org.apache.flink.streaming.connectors.kafka.internal.Kafka09PartitionDiscoverer.getAllPartitionsForTopics(Kafka09PartitionDiscoverer.java:77)
	at org.apache.flink.streaming.connectors.kafka.internals.AbstractPartitionDiscoverer.discoverPartitions(AbstractPartitionDiscoverer.java:131)
	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(Thread.java:748)





--
This message was sent by Atlassian JIRA
(v7.6.3#76005)