Uploaded image for project: 'Kafka'
  1. Kafka
  2. KAFKA-2054 Fix Kafka transient unit test failures
  3. KAFKA-5264

kafka.api.SslProducerSendTest.testSendToPartition transient failure

    XMLWordPrintableJSON

Details

    • Sub-task
    • Status: Open
    • Major
    • Resolution: Unresolved
    • None
    • None
    • None
    • None

    Description

      Error Message

      org.apache.kafka.common.errors.TopicExistsException: Topic 'topic' already exists.
      

      Stacktrace

      org.apache.kafka.common.errors.TopicExistsException: Topic 'topic' already exists.
      

      Standard Output

      [2017-05-17 17:24:31,041] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:24:32,898] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:24:32,907] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:24:34,792] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:24:34,798] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:24:36,665] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:24:36,673] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:24:38,657] ERROR [Controller 1]: Error while electing or becoming controller on broker 1 (kafka.controller.KafkaController:105)
      org.I0Itec.zkclient.exception.ZkInterruptedException: java.lang.InterruptedException
      	at org.I0Itec.zkclient.ZkClient.retryUntilConnected(ZkClient.java:1003)
      	at org.I0Itec.zkclient.ZkClient.readData(ZkClient.java:1100)
      	at org.I0Itec.zkclient.ZkClient.readData(ZkClient.java:1095)
      	at kafka.utils.ZkUtils.readDataMaybeNull(ZkUtils.scala:659)
      	at kafka.utils.ReplicationUtils$.getLeaderIsrAndEpochForPartition(ReplicationUtils.scala:75)
      	at kafka.utils.ZkUtils$$anonfun$getPartitionLeaderAndIsrForTopics$1.apply(ZkUtils.scala:708)
      	at kafka.utils.ZkUtils$$anonfun$getPartitionLeaderAndIsrForTopics$1.apply(ZkUtils.scala:707)
      	at scala.collection.mutable.HashMap$$anon$1$$anonfun$foreach$2.apply(HashMap.scala:134)
      	at scala.collection.mutable.HashMap$$anon$1$$anonfun$foreach$2.apply(HashMap.scala:134)
      	at scala.collection.mutable.HashTable$class.foreachEntry(HashTable.scala:236)
      	at scala.collection.mutable.HashMap.foreachEntry(HashMap.scala:40)
      	at scala.collection.mutable.HashMap$$anon$1.foreach(HashMap.scala:134)
      	at kafka.utils.ZkUtils.getPartitionLeaderAndIsrForTopics(ZkUtils.scala:707)
      	at kafka.controller.KafkaController.updateLeaderAndIsrCache(KafkaController.scala:736)
      	at kafka.controller.KafkaController.initializeControllerContext(KafkaController.scala:664)
      	at kafka.controller.KafkaController.onControllerFailover(KafkaController.scala:255)
      	at kafka.controller.KafkaController.elect(KafkaController.scala:1565)
      	at kafka.controller.KafkaController$Reelect$.process(KafkaController.scala:1512)
      	at kafka.controller.KafkaController$ControllerEventThread.doWork(KafkaController.scala:1154)
      	at kafka.utils.ShutdownableThread.run(ShutdownableThread.scala:64)
      Caused by: java.lang.InterruptedException
      	at java.lang.Object.wait(Native Method)
      	at java.lang.Object.wait(Object.java:503)
      	at org.apache.zookeeper.ClientCnxn.submitRequest(ClientCnxn.java:1406)
      	at org.apache.zookeeper.ZooKeeper.getData(ZooKeeper.java:1210)
      	at org.apache.zookeeper.ZooKeeper.getData(ZooKeeper.java:1241)
      	at org.I0Itec.zkclient.ZkConnection.readData(ZkConnection.java:125)
      	at org.I0Itec.zkclient.ZkClient$12.call(ZkClient.java:1104)
      	at org.I0Itec.zkclient.ZkClient$12.call(ZkClient.java:1100)
      	at org.I0Itec.zkclient.ZkClient.retryUntilConnected(ZkClient.java:991)
      	... 19 more
      [2017-05-17 17:24:38,660] ERROR [controller-event-thread]: Error processing event Reelect (kafka.controller.KafkaController$ControllerEventThread:105)
      org.I0Itec.zkclient.exception.ZkInterruptedException: java.lang.InterruptedException
      	at org.I0Itec.zkclient.ZkClient.retryUntilConnected(ZkClient.java:1003)
      	at org.I0Itec.zkclient.ZkClient.delete(ZkClient.java:1048)
      	at org.I0Itec.zkclient.ZkClient.delete(ZkClient.java:1043)
      	at kafka.utils.ZkUtils.deletePath(ZkUtils.scala:618)
      	at kafka.controller.KafkaController.kafka$controller$KafkaController$$triggerControllerMove(KafkaController.scala:1539)
      	at kafka.controller.KafkaController.elect(KafkaController.scala:1578)
      	at kafka.controller.KafkaController$Reelect$.process(KafkaController.scala:1512)
      	at kafka.controller.KafkaController$ControllerEventThread.doWork(KafkaController.scala:1154)
      	at kafka.utils.ShutdownableThread.run(ShutdownableThread.scala:64)
      Caused by: java.lang.InterruptedException
      	at java.lang.Object.wait(Native Method)
      	at java.lang.Object.wait(Object.java:503)
      	at org.apache.zookeeper.ClientCnxn.submitRequest(ClientCnxn.java:1406)
      	at org.apache.zookeeper.ZooKeeper.delete(ZooKeeper.java:871)
      	at org.I0Itec.zkclient.ZkConnection.delete(ZkConnection.java:110)
      	at org.I0Itec.zkclient.ZkClient$11.call(ZkClient.java:1052)
      	at org.I0Itec.zkclient.ZkClient.retryUntilConnected(ZkClient.java:991)
      	... 8 more
      [2017-05-17 17:24:38,665] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:24:38,674] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:24:40,603] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:24:40,610] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:24:42,542] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:24:42,548] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:24:54,445] ERROR Haven't been able to send leader and isr requests, current state of the map is Map(1 -> Map(topic-1 -> (LeaderAndIsrInfo:(Leader:1,ISR:1,LeaderEpoch:1,ControllerEpoch:2),ReplicationFactor:2),AllReplicas:0,1))). Exception message: java.lang.InterruptedException (kafka.controller.ControllerBrokerRequestBatch:99)
      [2017-05-17 17:24:54,446] ERROR Haven't been able to send metadata update requests to brokers Set(1), current state of the partition info is Map(topic-1 -> (LeaderAndIsrInfo:(Leader:1,ISR:1,LeaderEpoch:1,ControllerEpoch:2),ReplicationFactor:2),AllReplicas:0,1)). Exception message: java.lang.InterruptedException (kafka.controller.ControllerBrokerRequestBatch:99)
      [2017-05-17 17:24:54,446] ERROR [Partition state machine on Controller 1]: Error while moving some partitions to the online state (kafka.controller.PartitionStateMachine:105)
      java.lang.IllegalStateException: java.lang.InterruptedException
      	at kafka.controller.ControllerBrokerRequestBatch.sendRequestsToBrokers(ControllerChannelManager.scala:459)
      	at kafka.controller.PartitionStateMachine.triggerOnlinePartitionStateChange(PartitionStateMachine.scala:88)
      	at kafka.controller.PartitionStateMachine.startup(PartitionStateMachine.scala:59)
      	at kafka.controller.KafkaController.onControllerFailover(KafkaController.scala:266)
      	at kafka.controller.KafkaController.elect(KafkaController.scala:1565)
      	at kafka.controller.KafkaController$Reelect$.process(KafkaController.scala:1512)
      	at kafka.controller.KafkaController$ControllerEventThread.doWork(KafkaController.scala:1154)
      	at kafka.utils.ShutdownableThread.run(ShutdownableThread.scala:64)
      Caused by: java.lang.InterruptedException
      	at java.util.concurrent.locks.AbstractQueuedSynchronizer.acquireInterruptibly(AbstractQueuedSynchronizer.java:1219)
      	at java.util.concurrent.locks.ReentrantLock.lockInterruptibly(ReentrantLock.java:340)
      	at java.util.concurrent.LinkedBlockingQueue.put(LinkedBlockingQueue.java:338)
      	at kafka.controller.ControllerChannelManager.sendRequest(ControllerChannelManager.scala:66)
      	at kafka.controller.KafkaController.sendRequest(KafkaController.scala:614)
      	at kafka.controller.ControllerBrokerRequestBatch$$anonfun$sendRequestsToBrokers$2.apply(ControllerChannelManager.scala:372)
      	at kafka.controller.ControllerBrokerRequestBatch$$anonfun$sendRequestsToBrokers$2.apply(ControllerChannelManager.scala:351)
      	at scala.collection.mutable.HashMap$$anonfun$foreach$1.apply(HashMap.scala:130)
      	at scala.collection.mutable.HashMap$$anonfun$foreach$1.apply(HashMap.scala:130)
      	at scala.collection.mutable.HashTable$class.foreachEntry(HashTable.scala:236)
      	at scala.collection.mutable.HashMap.foreachEntry(HashMap.scala:40)
      	at scala.collection.mutable.HashMap.foreach(HashMap.scala:130)
      	at kafka.controller.ControllerBrokerRequestBatch.sendRequestsToBrokers(ControllerChannelManager.scala:351)
      	... 7 more
      [2017-05-17 17:24:54,450] ERROR [Partition state machine on Controller 1]: Error while moving some partitions to OnlinePartition state (kafka.controller.PartitionStateMachine:105)
      java.lang.IllegalStateException: Controller to broker state change requests batch is not empty while creating a new one. Some LeaderAndIsr state changes Map(1 -> Map(topic-1 -> (LeaderAndIsrInfo:(Leader:1,ISR:1,LeaderEpoch:1,ControllerEpoch:2),ReplicationFactor:2),AllReplicas:0,1))) might be lost 
      	at kafka.controller.ControllerBrokerRequestBatch.newBatch(ControllerChannelManager.scala:262)
      	at kafka.controller.PartitionStateMachine.handleStateChanges(PartitionStateMachine.scala:109)
      	at kafka.controller.KafkaController.onPreferredReplicaElection(KafkaController.scala:584)
      	at kafka.controller.KafkaController.onControllerFailover(KafkaController.scala:274)
      	at kafka.controller.KafkaController.elect(KafkaController.scala:1565)
      	at kafka.controller.KafkaController$Reelect$.process(KafkaController.scala:1512)
      	at kafka.controller.KafkaController$ControllerEventThread.doWork(KafkaController.scala:1154)
      	at kafka.utils.ShutdownableThread.run(ShutdownableThread.scala:64)
      [2017-05-17 17:24:54,480] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:24:54,487] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:25:05,572] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:25:05,580] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      [2017-05-17 17:25:07,244] ERROR ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes (org.apache.zookeeper.server.ZooKeeperServer:472)
      

      Attachments

        Activity

          People

            Unassigned Unassigned
            xvrl Xavier Léauté
            Votes:
            0 Vote for this issue
            Watchers:
            1 Start watching this issue

            Dates

              Created:
              Updated: