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 2016/07/22 16:58:41 UTC

kafka git commit: MINOR: Increase default `waitTime` in `waitUntilTrue` to 15 seconds

Repository: kafka
Updated Branches:
  refs/heads/trunk 1ef7672ed -> 427e63851


MINOR: Increase default `waitTime` in `waitUntilTrue` to 15 seconds

5 seconds is probably enough when running tests locally, but
doesn't seem to be so for Jenkins when it is overloaded.

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

Reviewers: Guozhang Wang <wa...@gmail.com>, Ewen Cheslack-Postava <ew...@confluent.io>

Closes #1589 from ijuma/increase-default-wait-time-for-wait-until-true


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

Branch: refs/heads/trunk
Commit: 427e638517d2efedb7e7cb1387b1c59363cda21d
Parents: 1ef7672
Author: Ismael Juma <is...@juma.me.uk>
Authored: Fri Jul 22 17:58:24 2016 +0100
Committer: Ismael Juma <is...@juma.me.uk>
Committed: Fri Jul 22 17:58:24 2016 +0100

----------------------------------------------------------------------
 .../java/org/apache/kafka/test/TestUtils.java   |  3 +-
 .../test/scala/unit/kafka/utils/TestUtils.scala | 41 +++++---------------
 2 files changed, 12 insertions(+), 32 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/kafka/blob/427e6385/clients/src/test/java/org/apache/kafka/test/TestUtils.java
----------------------------------------------------------------------
diff --git a/clients/src/test/java/org/apache/kafka/test/TestUtils.java b/clients/src/test/java/org/apache/kafka/test/TestUtils.java
index e06aece..e5e4d9b 100644
--- a/clients/src/test/java/org/apache/kafka/test/TestUtils.java
+++ b/clients/src/test/java/org/apache/kafka/test/TestUtils.java
@@ -56,6 +56,7 @@ public class TestUtils {
     /* A consistent random number generator to make tests repeatable */
     public static final Random SEEDED_RANDOM = new Random(192348092834L);
     public static final Random RANDOM = new Random();
+    public static final long DEFAULT_MAX_WAIT_MS = 15000;
 
     public static Cluster singletonCluster(Map<String, Integer> topicPartitionCounts) {
         return clusterWith(1, topicPartitionCounts);
@@ -230,7 +231,7 @@ public class TestUtils {
      *  uses default value of 15 seconds for timeout
      */
     public static void waitForCondition(TestCondition testCondition, String conditionDetails) throws InterruptedException {
-        waitForCondition(testCondition, 15000, conditionDetails);
+        waitForCondition(testCondition, DEFAULT_MAX_WAIT_MS, conditionDetails);
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/kafka/blob/427e6385/core/src/test/scala/unit/kafka/utils/TestUtils.scala
----------------------------------------------------------------------
diff --git a/core/src/test/scala/unit/kafka/utils/TestUtils.scala b/core/src/test/scala/unit/kafka/utils/TestUtils.scala
index b42a6ba..dccdc7d 100755
--- a/core/src/test/scala/unit/kafka/utils/TestUtils.scala
+++ b/core/src/test/scala/unit/kafka/utils/TestUtils.scala
@@ -19,10 +19,9 @@ package kafka.utils
 
 import java.io._
 import java.nio._
-import java.nio.file.Files
 import java.nio.channels._
 import java.util.concurrent.{Callable, Executors, TimeUnit}
-import java.util.{Collections, Properties, Random}
+import java.util.{Properties, Random}
 import java.security.cert.X509Certificate
 import javax.net.ssl.X509TrustManager
 import charset.Charset
@@ -44,12 +43,11 @@ import kafka.log._
 import kafka.utils.ZkUtils._
 import org.junit.Assert._
 import org.apache.kafka.clients.producer.{KafkaProducer, ProducerConfig, ProducerRecord}
-import org.apache.kafka.clients.consumer.{Consumer, ConsumerRecord, KafkaConsumer, RangeAssignor}
+import org.apache.kafka.clients.consumer.{KafkaConsumer, RangeAssignor}
 import org.apache.kafka.clients.CommonClientConfigs
 import org.apache.kafka.common.network.Mode
-import org.apache.kafka.common.record.CompressionType
 import org.apache.kafka.common.serialization.{ByteArraySerializer, Serializer}
-import org.apache.kafka.common.utils.Utils
+import org.apache.kafka.test.{TestUtils => JTestUtils}
 
 import scala.collection.Map
 import scala.collection.JavaConversions._
@@ -60,15 +58,7 @@ import scala.collection.JavaConverters._
  */
 object TestUtils extends Logging {
 
-  val IoTmpDir = System.getProperty("java.io.tmpdir")
-
-  val Letters = "ABCDEFGHIJKLMNOPQRSTUVWXYZabcdefghijklmnopqrstuvwxyz"
-  val Digits = "0123456789"
-  val LettersAndDigits = Letters + Digits
-
-  /* A consistent random number generator to make tests repeatable */
-  val seededRandom = new Random(192348092834L)
-  val random = new Random()
+  val random = JTestUtils.RANDOM
 
   /* 0 gives a random port; you can then retrieve the assigned port from the Socket object. */
   val RandomPort = 0
@@ -81,9 +71,7 @@ object TestUtils extends Logging {
   /**
    * Create a temporary directory
    */
-  def tempDir(): File = {
-    tempRelativeDir(IoTmpDir)
-  }
+  def tempDir(): File = JTestUtils.tempDirectory()
 
   def tempTopic(): String = "testTopic" + random.nextInt(1000000)
 
@@ -94,7 +82,7 @@ object TestUtils extends Logging {
     val parentFile = new File(parent)
     parentFile.mkdirs()
 
-    org.apache.kafka.test.TestUtils.tempDirectory(parentFile.toPath, "kafka-")
+    JTestUtils.tempDirectory(parentFile.toPath, null)
   }
 
   /**
@@ -114,7 +102,7 @@ object TestUtils extends Logging {
   /**
    * Create a temporary file
    */
-  def tempFile(): File = org.apache.kafka.test.TestUtils.tempFile()
+  def tempFile(): File = JTestUtils.tempFile()
 
   /**
    * Create a temporary file and return an open file channel for this file
@@ -294,11 +282,7 @@ object TestUtils extends Logging {
    *
    * @param numBytes The size of the array
    */
-  def randomBytes(numBytes: Int): Array[Byte] = {
-    val bytes = new Array[Byte](numBytes)
-    seededRandom.nextBytes(bytes)
-    bytes
-  }
+  def randomBytes(numBytes: Int): Array[Byte] = JTestUtils.randomBytes(numBytes)
 
   /**
    * Generate a random string of letters and digits of the given length
@@ -306,12 +290,7 @@ object TestUtils extends Logging {
    * @param len The length of the string
    * @return The random string
    */
-  def randomString(len: Int): String = {
-    val b = new StringBuilder()
-    for(i <- 0 until len)
-      b.append(LettersAndDigits.charAt(seededRandom.nextInt(LettersAndDigits.length)))
-    b.toString
-  }
+  def randomString(len: Int): String = JTestUtils.randomString(len)
 
   /**
    * Check that the buffer content from buffer.position() to buffer.limit() is equal
@@ -762,7 +741,7 @@ object TestUtils extends Logging {
   /**
    * Wait until the given condition is true or throw an exception if the given wait time elapses.
    */
-  def waitUntilTrue(condition: () => Boolean, msg: String, waitTime: Long = 5000L): Boolean = {
+  def waitUntilTrue(condition: () => Boolean, msg: String, waitTime: Long = JTestUtils.DEFAULT_MAX_WAIT_MS): Boolean = {
     val startTime = System.currentTimeMillis()
     while (true) {
       if (condition())