You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by "Till Rohrmann (JIRA)" <ji...@apache.org> on 2015/12/09 18:15:11 UTC

[jira] [Created] (FLINK-3156) FlinkKafkaConsumer fails with NPE on notifyCheckpointComplete

Till Rohrmann created FLINK-3156:
------------------------------------

             Summary: FlinkKafkaConsumer fails with NPE on notifyCheckpointComplete
                 Key: FLINK-3156
                 URL: https://issues.apache.org/jira/browse/FLINK-3156
             Project: Flink
          Issue Type: Bug
          Components: Kafka Connector
    Affects Versions: 1.0.0
            Reporter: Till Rohrmann
            Assignee: Robert Metzger


The {{FlinkKafkaConsumer}} fails with a {{NullPointerException}} when a checkpoint was completed. The stack trace is

{code}
 java.lang.RuntimeException: Error while confirming checkpoint
    at org.apache.flink.runtime.taskmanager.Task$2.run(Task.java:908)
    at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:471)
    at java.util.concurrent.FutureTask.run(FutureTask.java:262)
    at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1145)
    at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:615)
    at java.lang.Thread.run(Thread.java:745)
Caused by: java.lang.NullPointerException
    at org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer.commitOffsets(FlinkKafkaConsumer.java:664)
    at org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer.notifyCheckpointComplete(FlinkKafkaConsumer.java:578)
    at org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator.notifyOfCompletedCheckpoint(AbstractUdfStreamOperator.java:176)
    at org.apache.flink.streaming.runtime.tasks.StreamTask.notifyCheckpointComplete(StreamTask.java:546)
    at org.apache.flink.runtime.taskmanager.Task$2.run(Task.java:904)
    ... 5 more
{code}

Apparently, one of the {{KafkaTopicPartitionLeaders}} from the {{subscribedPartitions}} was {{null}}.



--
This message was sent by Atlassian JIRA
(v6.3.4#6332)