You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@kafka.apache.org by "Jun Rao (JIRA)" <ji...@apache.org> on 2017/10/20 01:47:00 UTC

[jira] [Created] (KAFKA-6094) transient failure in testMultipleMarkersOneLeader

Jun Rao created KAFKA-6094:
------------------------------

             Summary: transient failure in testMultipleMarkersOneLeader
                 Key: KAFKA-6094
                 URL: https://issues.apache.org/jira/browse/KAFKA-6094
             Project: Kafka
          Issue Type: Bug
          Components: core
    Affects Versions: 1.1.0
            Reporter: Jun Rao


Saw the following transient failure in https://builds.apache.org/job/kafka-pr-jdk7-scala2.11/9005/consoleFull

kafka.api.TransactionsTest > testMultipleMarkersOneLeader FAILED
    org.apache.kafka.common.KafkaException: Cannot perform send because at least one previous transactional or idempotent request has failed with errors.
        at org.apache.kafka.clients.producer.internals.TransactionManager.failIfNotReadyForSend(TransactionManager.java:278)
        at org.apache.kafka.clients.producer.internals.TransactionManager.maybeAddPartitionToTransaction(TransactionManager.java:263)
        at org.apache.kafka.clients.producer.KafkaProducer.doSend(KafkaProducer.java:805)
        at org.apache.kafka.clients.producer.KafkaProducer.send(KafkaProducer.java:761)
        at org.apache.kafka.clients.producer.KafkaProducer.send(KafkaProducer.java:649)
        at kafka.api.TransactionsTest$$anonfun$sendTransactionalMessagesWithValueRange$1.apply(TransactionsTest.scala:500)
        at kafka.api.TransactionsTest$$anonfun$sendTransactionalMessagesWithValueRange$1.apply(TransactionsTest.scala:499)
        at scala.collection.immutable.Range.foreach(Range.scala:160)
        at kafka.api.TransactionsTest.sendTransactionalMessagesWithValueRange(TransactionsTest.scala:499)
        at kafka.api.TransactionsTest.testMultipleMarkersOneLeader(TransactionsTest.scala:475)

        Caused by:
        org.apache.kafka.common.errors.TimeoutException: Expiring 213 record(s) for largeTopic-8: 10474 ms has passed since batch creation plus linger time





--
This message was sent by Atlassian JIRA
(v6.4.14#64029)