You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kafka.apache.org by ij...@apache.org on 2017/05/05 03:52:02 UTC

kafka git commit: MINOR: Temporarily disable a few flaky tests

Repository: kafka
Updated Branches:
  refs/heads/trunk 41fead3ac -> 1816e2998


MINOR: Temporarily disable a few flaky tests

Author: Ismael Juma <is...@juma.me.uk>

Reviewers: Ewen Cheslack-Postava <me...@ewencp.org>

Closes #2978 from ijuma/disable-some-flaky-tests


Project: http://git-wip-us.apache.org/repos/asf/kafka/repo
Commit: http://git-wip-us.apache.org/repos/asf/kafka/commit/1816e299
Tree: http://git-wip-us.apache.org/repos/asf/kafka/tree/1816e299
Diff: http://git-wip-us.apache.org/repos/asf/kafka/diff/1816e299

Branch: refs/heads/trunk
Commit: 1816e29981b0e9df67d416c8cfccc4f2ee1241fa
Parents: 41fead3
Author: Ismael Juma <is...@juma.me.uk>
Authored: Fri May 5 04:51:51 2017 +0100
Committer: Ismael Juma <is...@juma.me.uk>
Committed: Fri May 5 04:51:51 2017 +0100

----------------------------------------------------------------------
 .../integration/kafka/api/ConsumerBounceTest.scala   |  3 ++-
 .../integration/kafka/api/ProducerBounceTest.scala   | 15 +++------------
 .../kafka/controller/ControllerFailoverTest.scala    |  9 ++-------
 3 files changed, 7 insertions(+), 20 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/kafka/blob/1816e299/core/src/test/scala/integration/kafka/api/ConsumerBounceTest.scala
----------------------------------------------------------------------
diff --git a/core/src/test/scala/integration/kafka/api/ConsumerBounceTest.scala b/core/src/test/scala/integration/kafka/api/ConsumerBounceTest.scala
index 6635d7f..4057ccf 100644
--- a/core/src/test/scala/integration/kafka/api/ConsumerBounceTest.scala
+++ b/core/src/test/scala/integration/kafka/api/ConsumerBounceTest.scala
@@ -23,7 +23,7 @@ import org.apache.kafka.clients.consumer._
 import org.apache.kafka.clients.producer.{ProducerConfig, ProducerRecord}
 import org.apache.kafka.common.TopicPartition
 import org.junit.Assert._
-import org.junit.{After, Before, Test}
+import org.junit.{After, Before, Ignore, Test}
 
 import scala.collection.JavaConverters._
 
@@ -82,6 +82,7 @@ class ConsumerBounceTest extends IntegrationTestHarness with Logging {
   }
 
   @Test
+  @Ignore // To be re-enabled once we can make it less flaky (KAFKA-4801)
   def testConsumptionWithBrokerFailures() = consumeWithBrokerFailures(10)
 
   /*

http://git-wip-us.apache.org/repos/asf/kafka/blob/1816e299/core/src/test/scala/integration/kafka/api/ProducerBounceTest.scala
----------------------------------------------------------------------
diff --git a/core/src/test/scala/integration/kafka/api/ProducerBounceTest.scala b/core/src/test/scala/integration/kafka/api/ProducerBounceTest.scala
index 5aeeefe..7b65c4f 100644
--- a/core/src/test/scala/integration/kafka/api/ProducerBounceTest.scala
+++ b/core/src/test/scala/integration/kafka/api/ProducerBounceTest.scala
@@ -23,7 +23,7 @@ import kafka.utils.{ShutdownableThread, TestUtils}
 import org.apache.kafka.clients.producer._
 import org.apache.kafka.clients.producer.internals.ErrorLoggingCallback
 import org.junit.Assert._
-import org.junit.{After, Before, Test}
+import org.junit.{Ignore, Test}
 
 import scala.collection.mutable.ArrayBuffer
 
@@ -58,23 +58,14 @@ class ProducerBounceTest extends KafkaServerTestHarness {
 
   private val topic1 = "topic-1"
 
-  @Before
-  override def setUp() {
-    super.setUp()
-  }
-
-  @After
-  override def tearDown() {
-    super.tearDown()
-  }
-
   /**
    * With replication, producer should able able to find new leader after it detects broker failure
    */
+  @Ignore // To be re-enabled once we can make it less flaky (KAFKA-2837)
   @Test
   def testBrokerFailure() {
     val numPartitions = 3
-    val topicConfig = new Properties();
+    val topicConfig = new Properties()
     topicConfig.put(KafkaConfig.MinInSyncReplicasProp, 2.toString)
     val leaders = TestUtils.createTopic(zkUtils, topic1, numPartitions, numServers, servers, topicConfig)
 

http://git-wip-us.apache.org/repos/asf/kafka/blob/1816e299/core/src/test/scala/unit/kafka/controller/ControllerFailoverTest.scala
----------------------------------------------------------------------
diff --git a/core/src/test/scala/unit/kafka/controller/ControllerFailoverTest.scala b/core/src/test/scala/unit/kafka/controller/ControllerFailoverTest.scala
index fd23894..83a315f 100644
--- a/core/src/test/scala/unit/kafka/controller/ControllerFailoverTest.scala
+++ b/core/src/test/scala/unit/kafka/controller/ControllerFailoverTest.scala
@@ -27,11 +27,10 @@ import kafka.utils._
 import org.apache.kafka.common.metrics.Metrics
 import org.apache.kafka.common.utils.Time
 import org.apache.log4j.{Level, Logger}
-import org.junit.{After, Before, Test}
+import org.junit.{After, Ignore, Test}
 
 import scala.collection.mutable
 
-
 class ControllerFailoverTest extends KafkaServerTestHarness with Logging {
   val log = Logger.getLogger(classOf[ControllerFailoverTest])
   val numNodes = 2
@@ -45,11 +44,6 @@ class ControllerFailoverTest extends KafkaServerTestHarness with Logging {
   override def generateConfigs() = TestUtils.createBrokerConfigs(numNodes, zkConnect)
     .map(KafkaConfig.fromProps(_, overridingProps))
 
-  @Before
-  override def setUp() {
-    super.setUp()
-  }
-
   @After
   override def tearDown() {
     super.tearDown()
@@ -60,6 +54,7 @@ class ControllerFailoverTest extends KafkaServerTestHarness with Logging {
    * See @link{https://issues.apache.org/jira/browse/KAFKA-2300}
    * for the background of this test case
    */
+  @Ignore // This needs to be reworked as described here: https://github.com/apache/kafka/pull/2935#discussion_r114374412
   @Test
   def testMetadataUpdate() {
     log.setLevel(Level.INFO)