You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@flink.apache.org by "Vishal Santoshi (JIRA)" <ji...@apache.org> on 2018/05/13 14:50:00 UTC

[jira] [Created] (FLINK-9349) KafkaConnector Exception while fetching from multiple kafka topics

Vishal Santoshi created FLINK-9349:
--------------------------------------

             Summary: KafkaConnector Exception  while fetching from multiple kafka topics
                 Key: FLINK-9349
                 URL: https://issues.apache.org/jira/browse/FLINK-9349
             Project: Flink
          Issue Type: Bug
          Components: Kafka Connector
    Affects Versions: 1.4.0
            Reporter: Vishal Santoshi


./flink-connectors/flink-connector-kafka-0.9/src/main/java/org/apache/flink/streaming/connectors/kafka/internal/Kafka09Fetcher.java
 
It seems the List subscribedPartitionStates was being modified when runFetchLoop iterated the List.
This can happen if, e.g., FlinkKafkaConsumer runs the following code concurrently:
                kafkaFetcher.addDiscoveredPartitions(discoveredPartitions);
 
{code:java}
 java.util.ConcurrentModificationException
	at java.util.LinkedList$ListItr.checkForComodification(LinkedList.java:966)
	at java.util.LinkedList$ListItr.next(LinkedList.java:888)
	at org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher.runFetchLoop(Kafka09Fetcher.java:134)
{code}



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