You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@druid.apache.org by GitBox <gi...@apache.org> on 2018/07/10 20:02:17 UTC

[GitHub] jihoonson closed pull request #5978: Extend various test timeouts.

jihoonson closed pull request #5978: Extend various test timeouts.
URL: https://github.com/apache/incubator-druid/pull/5978
 
 
   

This is a PR merged from a forked repository.
As GitHub hides the original diff on merge, it is displayed below for
the sake of provenance:

As this is a foreign pull request (from a fork), the diff is supplied
below (as it won't show otherwise due to GitHub magic):

diff --git a/common/src/test/java/io/druid/collections/BlockingPoolTest.java b/common/src/test/java/io/druid/collections/BlockingPoolTest.java
index a1d673a902a..409ee4796a2 100644
--- a/common/src/test/java/io/druid/collections/BlockingPoolTest.java
+++ b/common/src/test/java/io/druid/collections/BlockingPoolTest.java
@@ -79,7 +79,7 @@ public void testDrainFromEmptyPool()
     emptyPool.takeBatch(1, 0);
   }
 
-  @Test(timeout = 5000)
+  @Test(timeout = 60_000L)
   public void testTake()
   {
     final ReferenceCountingResourceHolder<Integer> holder = pool.take(100);
@@ -89,7 +89,7 @@ public void testTake()
     assertEquals(10, pool.getPoolSize());
   }
 
-  @Test(timeout = 5000)
+  @Test(timeout = 60_000L)
   public void testTakeTimeout()
   {
     final List<ReferenceCountingResourceHolder<Integer>> batchHolder = pool.takeBatch(10, 100L);
@@ -98,7 +98,7 @@ public void testTakeTimeout()
     batchHolder.forEach(ReferenceCountingResourceHolder::close);
   }
 
-  @Test(timeout = 5000)
+  @Test(timeout = 60_000L)
   public void testTakeBatch()
   {
     final List<ReferenceCountingResourceHolder<Integer>> holder = pool.takeBatch(6, 100L);
@@ -109,7 +109,7 @@ public void testTakeBatch()
     assertEquals(10, pool.getPoolSize());
   }
 
-  @Test(timeout = 5000)
+  @Test(timeout = 60_000L)
   public void testWaitAndTakeBatch() throws InterruptedException, ExecutionException
   {
     List<ReferenceCountingResourceHolder<Integer>> batchHolder = pool.takeBatch(10, 10);
@@ -132,14 +132,14 @@ public void testWaitAndTakeBatch() throws InterruptedException, ExecutionExcepti
     assertEquals(10, pool.getPoolSize());
   }
 
-  @Test(timeout = 5000)
+  @Test(timeout = 60_000L)
   public void testTakeBatchTooManyObjects()
   {
     final List<ReferenceCountingResourceHolder<Integer>> holder = pool.takeBatch(100, 100L);
     assertTrue(holder.isEmpty());
   }
 
-  @Test(timeout = 5000)
+  @Test(timeout = 60_000L)
   public void testConcurrentTake() throws ExecutionException, InterruptedException
   {
     final int limit1 = pool.maxSize() / 2;
@@ -225,7 +225,7 @@ public void run()
     assertEquals(pool.maxSize(), pool.getPoolSize());
   }
 
-  @Test(timeout = 5000)
+  @Test(timeout = 60_000L)
   public void testConcurrentTakeBatch() throws ExecutionException, InterruptedException
   {
     final int batch1 = pool.maxSize() / 2;
@@ -255,7 +255,7 @@ public void testConcurrentTakeBatch() throws ExecutionException, InterruptedExce
     assertEquals(pool.maxSize(), pool.getPoolSize());
   }
 
-  @Test(timeout = 5000)
+  @Test(timeout = 60_000L)
   public void testConcurrentBatchClose() throws ExecutionException, InterruptedException
   {
     final int batch1 = pool.maxSize() / 2;
@@ -299,7 +299,7 @@ public void run()
     assertEquals(pool.maxSize(), pool.getPoolSize());
   }
 
-  @Test(timeout = 5000)
+  @Test(timeout = 60_000L)
   public void testConcurrentTakeBatchClose() throws ExecutionException, InterruptedException
   {
     final List<ReferenceCountingResourceHolder<Integer>> r1 = pool.takeBatch(1, 10);
diff --git a/common/src/test/java/io/druid/collections/ReferenceCountingResourceHolderTest.java b/common/src/test/java/io/druid/collections/ReferenceCountingResourceHolderTest.java
index 4321e2ba07c..2a36e341410 100644
--- a/common/src/test/java/io/druid/collections/ReferenceCountingResourceHolderTest.java
+++ b/common/src/test/java/io/druid/collections/ReferenceCountingResourceHolderTest.java
@@ -83,7 +83,7 @@ public void close()
           });
   }
 
-  @Test(timeout = 60_000)
+  @Test(timeout = 60_000L)
   public void testResourceHandlerClearedByJVM() throws InterruptedException
   {
     long initialLeakedResources = ReferenceCountingResourceHolder.leakedResources();
@@ -92,7 +92,7 @@ public void testResourceHandlerClearedByJVM() throws InterruptedException
     verifyCleanerRun(released, initialLeakedResources);
   }
 
-  @Test(timeout = 60_000)
+  @Test(timeout = 60_000L)
   public void testResourceHandlerWithReleaserClearedByJVM() throws InterruptedException
   {
     long initialLeakedResources = ReferenceCountingResourceHolder.leakedResources();
diff --git a/common/src/test/java/io/druid/collections/StupidPoolTest.java b/common/src/test/java/io/druid/collections/StupidPoolTest.java
index 3cfdc3b878c..2a4d138317a 100644
--- a/common/src/test/java/io/druid/collections/StupidPoolTest.java
+++ b/common/src/test/java/io/druid/collections/StupidPoolTest.java
@@ -68,7 +68,7 @@ public void testExceptionInResourceHolderGet()
     resourceHolderObj.get();
   }
 
-  @Test(timeout = 60_000)
+  @Test(timeout = 60_000L)
   public void testResourceHandlerClearedByJVM() throws InterruptedException
   {
     String leakedString = createDanglingObjectHandler();
diff --git a/extensions-contrib/materialized-view-selection/src/test/java/io/druid/query/materializedview/DatasourceOptimizerTest.java b/extensions-contrib/materialized-view-selection/src/test/java/io/druid/query/materializedview/DatasourceOptimizerTest.java
index 0d34cfe73a5..b8a338f8776 100644
--- a/extensions-contrib/materialized-view-selection/src/test/java/io/druid/query/materializedview/DatasourceOptimizerTest.java
+++ b/extensions-contrib/materialized-view-selection/src/test/java/io/druid/query/materializedview/DatasourceOptimizerTest.java
@@ -133,7 +133,7 @@ public void tearDown() throws IOException
     tearDownServerAndCurator();
   }
   
-  @Test(timeout = 10 * 1000)
+  @Test(timeout = 60_000L)
   public void testOptimize() throws InterruptedException
   {
     // insert datasource metadata
diff --git a/extensions-core/kafka-indexing-service/src/test/java/io/druid/indexing/kafka/KafkaIndexTaskTest.java b/extensions-core/kafka-indexing-service/src/test/java/io/druid/indexing/kafka/KafkaIndexTaskTest.java
index f76788d4984..965651c19eb 100644
--- a/extensions-core/kafka-indexing-service/src/test/java/io/druid/indexing/kafka/KafkaIndexTaskTest.java
+++ b/extensions-core/kafka-indexing-service/src/test/java/io/druid/indexing/kafka/KafkaIndexTaskTest.java
@@ -1641,7 +1641,7 @@ public void testRunWithPauseAndResume() throws Exception
     Assert.assertEquals(ImmutableList.of("d", "e"), readSegmentColumn("dim1", desc2));
   }
 
-  @Test(timeout = 30_000L)
+  @Test(timeout = 60_000L)
   public void testRunWithOffsetOutOfRangeExceptionAndPause() throws Exception
   {
     final KafkaIndexTask task = createTask(
@@ -1671,7 +1671,7 @@ public void testRunWithOffsetOutOfRangeExceptionAndPause() throws Exception
     }
   }
 
-  @Test(timeout = 30_000L)
+  @Test(timeout = 60_000L)
   public void testRunWithOffsetOutOfRangeExceptionAndNextOffsetGreaterThanLeastAvailable() throws Exception
   {
     resetOffsetAutomatically = true;
diff --git a/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/NamespacedExtractorModuleTest.java b/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/NamespacedExtractorModuleTest.java
index d3e9d842074..f2d1a5b042d 100644
--- a/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/NamespacedExtractorModuleTest.java
+++ b/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/NamespacedExtractorModuleTest.java
@@ -136,7 +136,7 @@ public void testListNamespaces() throws Exception
     }
   }
 
-  @Test//(timeout = 10_000)
+  @Test//(timeout = 60_000L)
   public void testDeleteNamespaces() throws Exception
   {
     final File tmpFile = temporaryFolder.newFile();
diff --git a/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/UriCacheGeneratorTest.java b/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/UriCacheGeneratorTest.java
index f77d2be3901..b5216d2eea5 100644
--- a/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/UriCacheGeneratorTest.java
+++ b/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/UriCacheGeneratorTest.java
@@ -507,7 +507,7 @@ public void testWeirdSchemaOnExactURI() throws Exception
     Assert.assertNotNull(generator.generateCache(extractionNamespace, null, null, scheduler));
   }
 
-  @Test(timeout = 10_000)
+  @Test(timeout = 60_000L)
   public void testDeleteOnScheduleFail() throws Exception
   {
     Assert.assertNull(scheduler.scheduleAndWait(
diff --git a/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/cache/CacheSchedulerTest.java b/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/cache/CacheSchedulerTest.java
index 2bfff068228..dd142857f81 100644
--- a/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/cache/CacheSchedulerTest.java
+++ b/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/cache/CacheSchedulerTest.java
@@ -180,7 +180,7 @@ public void tearDown()
     lifecycle.stop();
   }
 
-  @Test(timeout = 10_000)
+  @Test(timeout = 60_000L)
   public void testSimpleSubmission() throws InterruptedException
   {
     UriExtractionNamespace namespace = new UriExtractionNamespace(
@@ -199,7 +199,7 @@ public void testSimpleSubmission() throws InterruptedException
     Assert.assertEquals("val", cache.get("key"));
   }
 
-  @Test(timeout = 10_000)
+  @Test(timeout = 60_000L)
   public void testPeriodicUpdatesScheduled() throws InterruptedException
   {
     final int repeatCount = 5;
@@ -233,7 +233,7 @@ public void testPeriodicUpdatesScheduled() throws InterruptedException
   }
 
 
-  @Test(timeout = 10_000) // This is very fast when run locally. Speed on Travis completely depends on noisy neighbors.
+  @Test(timeout = 60_000L) // This is very fast when run locally. Speed on Travis completely depends on noisy neighbors.
   public void testConcurrentAddDelete() throws InterruptedException
   {
     final int threads = 10;
@@ -306,7 +306,7 @@ public void run()
     checkNoMoreRunning();
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testSimpleDelete() throws InterruptedException
   {
     testDelete();
@@ -355,7 +355,7 @@ private UriExtractionNamespace getUriExtractionNamespace(long period)
     );
   }
 
-  @Test(timeout = 10_000)
+  @Test(timeout = 60_000L)
   public void testShutdown()
       throws InterruptedException
   {
@@ -389,7 +389,7 @@ public void testShutdown()
     Assert.assertTrue(cacheManager.scheduledExecutorService().isTerminated());
   }
 
-  @Test(timeout = 10_000)
+  @Test(timeout = 60_000L)
   public void testRunCount() throws InterruptedException
   {
     final int numWaits = 5;
@@ -415,7 +415,7 @@ public void testRunCount() throws InterruptedException
    * Tests that even if entry.close() wasn't called, the scheduled task is cancelled when the entry becomes
    * unreachable.
    */
-  @Test(timeout = 60_000)
+  @Test(timeout = 60_000L)
   public void testEntryCloseForgotten() throws InterruptedException
   {
     scheduleDanglingEntry();
diff --git a/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/cache/JdbcExtractionNamespaceTest.java b/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/cache/JdbcExtractionNamespaceTest.java
index f44385bce06..ccc04dafb79 100644
--- a/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/cache/JdbcExtractionNamespaceTest.java
+++ b/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/cache/JdbcExtractionNamespaceTest.java
@@ -362,7 +362,7 @@ private void insertValues(
     Thread.sleep(2);
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testMappingWithoutFilter()
       throws InterruptedException
   {
@@ -389,7 +389,7 @@ public void testMappingWithoutFilter()
     }
   }
 
-  @Test(timeout = 20_000L)
+  @Test(timeout = 60_000L)
   public void testMappingWithFilter()
       throws InterruptedException
   {
@@ -421,7 +421,7 @@ public void testMappingWithFilter()
     }
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testSkipOld()
       throws InterruptedException
   {
diff --git a/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/cache/NamespaceExtractionCacheManagersTest.java b/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/cache/NamespaceExtractionCacheManagersTest.java
index 66d94d16812..3d2d5aefc8f 100644
--- a/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/cache/NamespaceExtractionCacheManagersTest.java
+++ b/extensions-core/lookups-cached-global/src/test/java/io/druid/server/lookup/namespace/cache/NamespaceExtractionCacheManagersTest.java
@@ -70,7 +70,7 @@ public void setUp() throws Exception
     manager = createCacheManager.apply(lifecycle);
   }
 
-  @Test(timeout = 30000L)
+  @Test(timeout = 60_000L)
   public void testRacyCreation() throws Exception
   {
     final int concurrentThreads = 10;
@@ -116,7 +116,7 @@ public void run()
   /**
    * Tests that even if CacheHandler.close() wasn't called, the cache is cleaned up when it becomes unreachable.
    */
-  @Test(timeout = 60_000)
+  @Test(timeout = 60_000L)
   public void testCacheCloseForgotten() throws InterruptedException
   {
     Assert.assertEquals(0, manager.cacheCount());
diff --git a/indexing-service/src/test/java/io/druid/indexing/common/actions/LockAcquireActionTest.java b/indexing-service/src/test/java/io/druid/indexing/common/actions/LockAcquireActionTest.java
index 16638713d73..4fd0f85933f 100644
--- a/indexing-service/src/test/java/io/druid/indexing/common/actions/LockAcquireActionTest.java
+++ b/indexing-service/src/test/java/io/druid/indexing/common/actions/LockAcquireActionTest.java
@@ -71,7 +71,7 @@ public void testSerdeFromJsonWithMissingFields() throws IOException
     Assert.assertEquals(expected.getTimeoutMs(), actual.getTimeoutMs());
   }
 
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testWithLockType()
   {
     final Task task = NoopTask.create();
@@ -86,7 +86,7 @@ public void testWithLockType()
     Assert.assertNotNull(lock);
   }
 
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testWithoutLockType()
   {
     final Task task = NoopTask.create();
diff --git a/indexing-service/src/test/java/io/druid/indexing/common/actions/LockTryAcquireActionTest.java b/indexing-service/src/test/java/io/druid/indexing/common/actions/LockTryAcquireActionTest.java
index 29f06f52172..8ee0c0eb857 100644
--- a/indexing-service/src/test/java/io/druid/indexing/common/actions/LockTryAcquireActionTest.java
+++ b/indexing-service/src/test/java/io/druid/indexing/common/actions/LockTryAcquireActionTest.java
@@ -67,7 +67,7 @@ public void testSerdeFromJsonWithMissingFields() throws IOException
     Assert.assertEquals(expected.getInterval(), actual.getInterval());
   }
 
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testWithLockType()
   {
     final Task task = NoopTask.create();
@@ -81,7 +81,7 @@ public void testWithLockType()
     Assert.assertNotNull(lock);
   }
 
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testWithoutLockType()
   {
     final Task task = NoopTask.create();
diff --git a/indexing-service/src/test/java/io/druid/indexing/overlord/OverlordBlinkLeadershipTest.java b/indexing-service/src/test/java/io/druid/indexing/overlord/OverlordBlinkLeadershipTest.java
index 2b54f18651f..fb79e1fbc26 100644
--- a/indexing-service/src/test/java/io/druid/indexing/overlord/OverlordBlinkLeadershipTest.java
+++ b/indexing-service/src/test/java/io/druid/indexing/overlord/OverlordBlinkLeadershipTest.java
@@ -69,7 +69,7 @@ public void tearDown() throws Exception
    * org.apache.curator.framework.recipes.leader.LeaderSelectorListener#takeLeadership} implementation in
    * {@link TaskMaster} and start it again.
    */
-  @Test(timeout = 10_000)
+  @Test(timeout = 60_000L)
   public void testOverlordBlinkLeadership()
   {
     try {
diff --git a/indexing-service/src/test/java/io/druid/indexing/overlord/RemoteTaskRunnerRunPendingTasksConcurrencyTest.java b/indexing-service/src/test/java/io/druid/indexing/overlord/RemoteTaskRunnerRunPendingTasksConcurrencyTest.java
index 9d8903411f0..21f549a7fa5 100644
--- a/indexing-service/src/test/java/io/druid/indexing/overlord/RemoteTaskRunnerRunPendingTasksConcurrencyTest.java
+++ b/indexing-service/src/test/java/io/druid/indexing/overlord/RemoteTaskRunnerRunPendingTasksConcurrencyTest.java
@@ -57,7 +57,7 @@ public void tearDown() throws Exception
   }
 
   // This task reproduces the races described in https://github.com/druid-io/druid/issues/2842
-  @Test(timeout = 60_000)
+  @Test(timeout = 60_000L)
   public void testConcurrency() throws Exception
   {
     rtrTestUtils.makeWorker("worker0", 3);
diff --git a/indexing-service/src/test/java/io/druid/indexing/overlord/TaskLockBoxConcurrencyTest.java b/indexing-service/src/test/java/io/druid/indexing/overlord/TaskLockBoxConcurrencyTest.java
index 7c73e088c5c..a9bbc173cb1 100644
--- a/indexing-service/src/test/java/io/druid/indexing/overlord/TaskLockBoxConcurrencyTest.java
+++ b/indexing-service/src/test/java/io/druid/indexing/overlord/TaskLockBoxConcurrencyTest.java
@@ -82,7 +82,7 @@ public void teardown()
     service.shutdownNow();
   }
 
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testDoInCriticalSectionWithDifferentTasks()
       throws ExecutionException, InterruptedException, EntryExistsException
   {
@@ -163,7 +163,7 @@ public void testDoInCriticalSectionWithDifferentTasks()
     Assert.assertTrue(result.isRevoked());
   }
 
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testDoInCriticalSectionWithOverlappedIntervals() throws Exception
   {
     final List<Interval> intervals = ImmutableList.of(
diff --git a/indexing-service/src/test/java/io/druid/indexing/overlord/TaskLockboxTest.java b/indexing-service/src/test/java/io/druid/indexing/overlord/TaskLockboxTest.java
index 4238459cd0b..5318708404a 100644
--- a/indexing-service/src/test/java/io/druid/indexing/overlord/TaskLockboxTest.java
+++ b/indexing-service/src/test/java/io/druid/indexing/overlord/TaskLockboxTest.java
@@ -408,7 +408,7 @@ public void testDoInCriticalSectionWithRevokedLock() throws Exception
     );
   }
 
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testAcquireLockAfterRevoked() throws EntryExistsException, InterruptedException
   {
     final Interval interval = Intervals.of("2017-01-01/2017-01-02");
diff --git a/indexing-service/src/test/java/io/druid/indexing/overlord/hrtr/HttpRemoteTaskRunnerTest.java b/indexing-service/src/test/java/io/druid/indexing/overlord/hrtr/HttpRemoteTaskRunnerTest.java
index c46c12052ce..d696940c9bf 100644
--- a/indexing-service/src/test/java/io/druid/indexing/overlord/hrtr/HttpRemoteTaskRunnerTest.java
+++ b/indexing-service/src/test/java/io/druid/indexing/overlord/hrtr/HttpRemoteTaskRunnerTest.java
@@ -79,7 +79,7 @@
   Simulates startup of Overlord and Workers being discovered with no previously known tasks. Fresh tasks are given
   and expected to be completed.
    */
-  @Test(timeout = 30000L)
+  @Test(timeout = 60_000L)
   public void testFreshStart() throws Exception
   {
     TestDruidNodeDiscovery druidNodeDiscovery = new TestDruidNodeDiscovery();
@@ -167,7 +167,7 @@ protected WorkerHolder createWorkerHolder(
   Simulates one task not getting acknowledged to be running after assigning it to a worker. But, other tasks are
   successfully assigned to other worker and get completed.
    */
-  @Test(timeout = 10000L)
+  @Test(timeout = 60_000L)
   public void testOneStuckTaskAssignmentDoesntBlockOthers() throws Exception
   {
     TestDruidNodeDiscovery druidNodeDiscovery = new TestDruidNodeDiscovery();
@@ -254,7 +254,7 @@ protected WorkerHolder createWorkerHolder(
   /*
   Simulates restart of the Overlord where taskRunner, on start, discovers workers with prexisting tasks.
    */
-  @Test(timeout = 10000L)
+  @Test(timeout = 60_000L)
   public void testTaskRunnerRestart() throws Exception
   {
     TestDruidNodeDiscovery druidNodeDiscovery = new TestDruidNodeDiscovery();
@@ -399,7 +399,7 @@ protected WorkerHolder createWorkerHolder(
 
   }
 
-  @Test(timeout = 10000L)
+  @Test(timeout = 60_000L)
   public void testWorkerDisapperAndReappearBeforeItsCleanup() throws Exception
   {
     TestDruidNodeDiscovery druidNodeDiscovery = new TestDruidNodeDiscovery();
@@ -562,7 +562,7 @@ protected WorkerHolder createWorkerHolder(
     Assert.assertTrue(future2.get().isSuccess());
   }
 
-  @Test(timeout = 10000L)
+  @Test(timeout = 60_000L)
   public void testWorkerDisapperAndReappearAfterItsCleanup() throws Exception
   {
     TestDruidNodeDiscovery druidNodeDiscovery = new TestDruidNodeDiscovery();
@@ -725,7 +725,7 @@ protected WorkerHolder createWorkerHolder(
     Assert.assertTrue(taskRunner.run(task2).get().isFailure());
   }
 
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testMarkWorkersLazy() throws Exception
   {
     TestDruidNodeDiscovery druidNodeDiscovery = new TestDruidNodeDiscovery();
diff --git a/indexing-service/src/test/java/io/druid/indexing/overlord/http/OverlordTest.java b/indexing-service/src/test/java/io/druid/indexing/overlord/http/OverlordTest.java
index ea1d7429774..468146f7a63 100644
--- a/indexing-service/src/test/java/io/druid/indexing/overlord/http/OverlordTest.java
+++ b/indexing-service/src/test/java/io/druid/indexing/overlord/http/OverlordTest.java
@@ -199,7 +199,7 @@ public void announce(DruidNode node)
     EmittingLogger.registerEmitter(serviceEmitter);
   }
 
-  @Test(timeout = 2000L)
+  @Test(timeout = 60_000L)
   public void testOverlordRun() throws Exception
   {
     // basic task master lifecycle test
diff --git a/indexing-service/src/test/java/io/druid/indexing/worker/WorkerTaskManagerTest.java b/indexing-service/src/test/java/io/druid/indexing/worker/WorkerTaskManagerTest.java
index ddf162cf264..6eac5993cca 100644
--- a/indexing-service/src/test/java/io/druid/indexing/worker/WorkerTaskManagerTest.java
+++ b/indexing-service/src/test/java/io/druid/indexing/worker/WorkerTaskManagerTest.java
@@ -163,7 +163,7 @@ public void tearDown() throws Exception
     workerTaskManager.stop();
   }
 
-  @Test(timeout = 10000L)
+  @Test(timeout = 60_000L)
   public void testTaskRun() throws Exception
   {
     Task task1 = createNoopTask("task1-assigned-via-assign-dir");
diff --git a/indexing-service/src/test/java/io/druid/indexing/worker/WorkerTaskMonitorTest.java b/indexing-service/src/test/java/io/druid/indexing/worker/WorkerTaskMonitorTest.java
index 0c8781aa995..f3abe4dd4e3 100644
--- a/indexing-service/src/test/java/io/druid/indexing/worker/WorkerTaskMonitorTest.java
+++ b/indexing-service/src/test/java/io/druid/indexing/worker/WorkerTaskMonitorTest.java
@@ -215,7 +215,7 @@ public void tearDown() throws Exception
     testingCluster.stop();
   }
 
-  @Test(timeout = 30_000L)
+  @Test(timeout = 60_000L)
   public void testRunTask() throws Exception
   {
     Assert.assertTrue(
@@ -271,7 +271,7 @@ public boolean isValid()
     Assert.assertEquals(TaskState.SUCCESS, taskAnnouncement.getTaskStatus().getStatusCode());
   }
 
-  @Test(timeout = 30_000L)
+  @Test(timeout = 60_000L)
   public void testGetAnnouncements() throws Exception
   {
     cf.create()
@@ -309,7 +309,7 @@ public boolean isValid()
     Assert.assertEquals(DUMMY_NODE.getPlaintextPort(), announcements.get(0).getTaskLocation().getPort());
   }
 
-  @Test(timeout = 30_000L)
+  @Test(timeout = 60_000L)
   public void testRestartCleansOldStatus() throws Exception
   {
     task = TestTasks.unending("test");
@@ -345,7 +345,7 @@ public boolean isValid()
     Assert.assertEquals(TaskState.FAILED, announcements.get(0).getTaskStatus().getStatusCode());
   }
 
-  @Test(timeout = 30_000L)
+  @Test(timeout = 60_000L)
   public void testStatusAnnouncementsArePersistent() throws Exception
   {
     cf.create()
diff --git a/java-util/src/test/java/io/druid/concurrent/ConcurrentAwaitableCounterTest.java b/java-util/src/test/java/io/druid/concurrent/ConcurrentAwaitableCounterTest.java
index c13fa7b7d7c..8757571a5db 100644
--- a/java-util/src/test/java/io/druid/concurrent/ConcurrentAwaitableCounterTest.java
+++ b/java-util/src/test/java/io/druid/concurrent/ConcurrentAwaitableCounterTest.java
@@ -28,7 +28,7 @@
 public class ConcurrentAwaitableCounterTest
 {
 
-  @Test(timeout = 1000)
+  @Test(timeout = 60_000L)
   public void smokeTest() throws InterruptedException
   {
     ConcurrentAwaitableCounter counter = new ConcurrentAwaitableCounter();
diff --git a/java-util/src/test/java/io/druid/java/util/emitter/core/EmitterTest.java b/java-util/src/test/java/io/druid/java/util/emitter/core/EmitterTest.java
index 0320c76d24c..fc695ed5b09 100644
--- a/java-util/src/test/java/io/druid/java/util/emitter/core/EmitterTest.java
+++ b/java-util/src/test/java/io/druid/java/util/emitter/core/EmitterTest.java
@@ -367,7 +367,7 @@ public void testTimeBasedEmission() throws Exception
     Assert.assertTrue("httpClient.succeeded()", httpClient.succeeded());
   }
 
-  @Test(timeout = 60_000)
+  @Test(timeout = 60_000L)
   public void testFailedEmission() throws Exception
   {
     final UnitEvent event1 = new UnitEvent("test", 1);
diff --git a/java-util/src/test/java/io/druid/java/util/metrics/JvmMonitorTest.java b/java-util/src/test/java/io/druid/java/util/metrics/JvmMonitorTest.java
index 1a01a74a610..3b7b6469cfc 100644
--- a/java-util/src/test/java/io/druid/java/util/metrics/JvmMonitorTest.java
+++ b/java-util/src/test/java/io/druid/java/util/metrics/JvmMonitorTest.java
@@ -31,7 +31,7 @@
 public class JvmMonitorTest
 {
 
-  @Test(timeout = 60000)
+  @Test(timeout = 60_000L)
   public void testGcCounts() throws InterruptedException
   {
     GcTrackingEmitter emitter = new GcTrackingEmitter();
diff --git a/processing/src/test/java/io/druid/query/ChainedExecutionQueryRunnerTest.java b/processing/src/test/java/io/druid/query/ChainedExecutionQueryRunnerTest.java
index f83cf51b12a..d1ad6f0e0dd 100644
--- a/processing/src/test/java/io/druid/query/ChainedExecutionQueryRunnerTest.java
+++ b/processing/src/test/java/io/druid/query/ChainedExecutionQueryRunnerTest.java
@@ -58,7 +58,7 @@ public void setup()
     neverRelease.lock();
   }
   
-  @Test(timeout = 60000)
+  @Test(timeout = 60_000L)
   public void testQueryCancellation() throws Exception
   {
     ExecutorService exec = PrioritizedExecutorService.create(
@@ -182,7 +182,7 @@ public void run()
     EasyMock.verify(watcher);
   }
 
-  @Test(timeout = 60000)
+  @Test(timeout = 60_000L)
   public void testQueryTimeout() throws Exception
   {
     ExecutorService exec = PrioritizedExecutorService.create(
diff --git a/processing/src/test/java/io/druid/query/groupby/GroupByQueryRunnerFailureTest.java b/processing/src/test/java/io/druid/query/groupby/GroupByQueryRunnerFailureTest.java
index 55c05ddec98..83c632a1f4d 100644
--- a/processing/src/test/java/io/druid/query/groupby/GroupByQueryRunnerFailureTest.java
+++ b/processing/src/test/java/io/druid/query/groupby/GroupByQueryRunnerFailureTest.java
@@ -180,7 +180,7 @@ public GroupByQueryRunnerFailureTest(QueryRunner<Row> runner)
     this.runner = factory.mergeRunners(MoreExecutors.sameThreadExecutor(), ImmutableList.of(runner));
   }
 
-  @Test(timeout = 10000)
+  @Test(timeout = 60_000L)
   public void testNotEnoughMergeBuffersOnQueryable()
   {
     expectedException.expect(QueryInterruptedException.class);
@@ -209,7 +209,7 @@ public void testNotEnoughMergeBuffersOnQueryable()
     GroupByQueryRunnerTestHelper.runQuery(factory, runner, query);
   }
 
-  @Test(timeout = 10000)
+  @Test(timeout = 60_000L)
   public void testResourceLimitExceededOnBroker()
   {
     expectedException.expect(ResourceLimitExceededException.class);
@@ -247,7 +247,7 @@ public void testResourceLimitExceededOnBroker()
     GroupByQueryRunnerTestHelper.runQuery(factory, runner, query);
   }
 
-  @Test(timeout = 10000, expected = InsufficientResourcesException.class)
+  @Test(timeout = 60_000L, expected = InsufficientResourcesException.class)
   public void testInsufficientResourcesOnBroker()
   {
     final GroupByQuery query = GroupByQuery
diff --git a/processing/src/test/java/io/druid/query/groupby/epinephelinae/StreamingMergeSortedGrouperTest.java b/processing/src/test/java/io/druid/query/groupby/epinephelinae/StreamingMergeSortedGrouperTest.java
index e66cd77b0ac..8045fdc6836 100644
--- a/processing/src/test/java/io/druid/query/groupby/epinephelinae/StreamingMergeSortedGrouperTest.java
+++ b/processing/src/test/java/io/druid/query/groupby/epinephelinae/StreamingMergeSortedGrouperTest.java
@@ -80,7 +80,7 @@ public void testAggregate()
     );
   }
 
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testEmptyIterator()
   {
     final TestColumnSelectorFactory columnSelectorFactory = GrouperTestUtil.newColumnSelectorFactory();
@@ -91,13 +91,13 @@ public void testEmptyIterator()
     Assert.assertTrue(!grouper.iterator(true).hasNext());
   }
 
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testStreamingAggregateWithLargeBuffer() throws ExecutionException, InterruptedException
   {
     testStreamingAggregate(1024);
   }
 
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testStreamingAggregateWithMinimumBuffer() throws ExecutionException, InterruptedException
   {
     testStreamingAggregate(60);
diff --git a/processing/src/test/java/io/druid/segment/data/CompressionStrategyTest.java b/processing/src/test/java/io/druid/segment/data/CompressionStrategyTest.java
index 7c817867fa0..659f55dc9dd 100644
--- a/processing/src/test/java/io/druid/segment/data/CompressionStrategyTest.java
+++ b/processing/src/test/java/io/druid/segment/data/CompressionStrategyTest.java
@@ -119,7 +119,7 @@ public void testDirectMemoryOperations()
     Assert.assertArrayEquals("Uncompressed data does not match", originalData, checkArray);
   }
 
-  @Test(timeout = 60000)
+  @Test(timeout = 60_000L)
   public void testConcurrency() throws Exception
   {
     final int numThreads = 20;
diff --git a/server/src/test/java/io/druid/client/HttpServerInventoryViewTest.java b/server/src/test/java/io/druid/client/HttpServerInventoryViewTest.java
index 7f7f8883518..b1823afee84 100644
--- a/server/src/test/java/io/druid/client/HttpServerInventoryViewTest.java
+++ b/server/src/test/java/io/druid/client/HttpServerInventoryViewTest.java
@@ -67,7 +67,7 @@
  */
 public class HttpServerInventoryViewTest
 {
-  @Test(timeout = 10000)
+  @Test(timeout = 60_000L)
   public void testSimple() throws Exception
   {
     ObjectMapper jsonMapper = TestHelper.makeJsonMapper();
diff --git a/server/src/test/java/io/druid/curator/CuratorUtilsTest.java b/server/src/test/java/io/druid/curator/CuratorUtilsTest.java
index d327868d0e4..239ee9063f6 100644
--- a/server/src/test/java/io/druid/curator/CuratorUtilsTest.java
+++ b/server/src/test/java/io/druid/curator/CuratorUtilsTest.java
@@ -40,7 +40,7 @@ public void tearDown()
     tearDownServerAndCurator();
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testCreateIfNotExists() throws Exception
   {
     curator.start();
@@ -65,7 +65,7 @@ public void testCreateIfNotExists() throws Exception
     Assert.assertEquals("baz", StringUtils.fromUtf8(curator.getData().forPath("/foo/bar")));
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testCreateIfNotExistsPayloadTooLarge() throws Exception
   {
     curator.start();
@@ -89,7 +89,7 @@ public void testCreateIfNotExistsPayloadTooLarge() throws Exception
     Assert.assertNull(curator.checkExists().forPath("/foo/bar"));
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testCreateOrSet() throws Exception
   {
     curator.start();
@@ -116,7 +116,7 @@ public void testCreateOrSet() throws Exception
     Assert.assertEquals("qux", StringUtils.fromUtf8(curator.getData().forPath("/foo/bar")));
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testCreateOrSetPayloadTooLarge() throws Exception
   {
     curator.start();
diff --git a/server/src/test/java/io/druid/curator/discovery/CuratorDruidLeaderSelectorTest.java b/server/src/test/java/io/druid/curator/discovery/CuratorDruidLeaderSelectorTest.java
index 8182737da63..546a2034459 100644
--- a/server/src/test/java/io/druid/curator/discovery/CuratorDruidLeaderSelectorTest.java
+++ b/server/src/test/java/io/druid/curator/discovery/CuratorDruidLeaderSelectorTest.java
@@ -47,7 +47,7 @@ public void setUp() throws Exception
     setupServerAndCurator();
   }
 
-  @Test(timeout = 15000)
+  @Test(timeout = 60_000L)
   public void testSimple() throws Exception
   {
     curator.start();
diff --git a/server/src/test/java/io/druid/curator/discovery/CuratorDruidNodeAnnouncerAndDiscoveryTest.java b/server/src/test/java/io/druid/curator/discovery/CuratorDruidNodeAnnouncerAndDiscoveryTest.java
index d3ec923a43b..d8a11a2b900 100644
--- a/server/src/test/java/io/druid/curator/discovery/CuratorDruidNodeAnnouncerAndDiscoveryTest.java
+++ b/server/src/test/java/io/druid/curator/discovery/CuratorDruidNodeAnnouncerAndDiscoveryTest.java
@@ -52,7 +52,7 @@ public void setUp() throws Exception
     setupServerAndCurator();
   }
 
-  @Test(timeout = 5000)
+  @Test(timeout = 60_000L)
   public void testAnnouncementAndDiscovery() throws Exception
   {
     ObjectMapper objectMapper = new DefaultObjectMapper();
diff --git a/server/src/test/java/io/druid/metadata/SQLMetadataStorageActionHandlerTest.java b/server/src/test/java/io/druid/metadata/SQLMetadataStorageActionHandlerTest.java
index 7f4f6178c2e..d0466f5aa86 100644
--- a/server/src/test/java/io/druid/metadata/SQLMetadataStorageActionHandlerTest.java
+++ b/server/src/test/java/io/druid/metadata/SQLMetadataStorageActionHandlerTest.java
@@ -217,7 +217,7 @@ public void testGetRecentStatuses2() throws EntryExistsException
     }
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testRepeatInsert() throws Exception
   {
     final String entryId = "abcd";
diff --git a/server/src/test/java/io/druid/query/lookup/LookupReferencesManagerTest.java b/server/src/test/java/io/druid/query/lookup/LookupReferencesManagerTest.java
index a1898e5436b..843e147876c 100644
--- a/server/src/test/java/io/druid/query/lookup/LookupReferencesManagerTest.java
+++ b/server/src/test/java/io/druid/query/lookup/LookupReferencesManagerTest.java
@@ -434,7 +434,7 @@ public void testGetAllLookupsState() throws Exception
     Assert.assertTrue(state.getToDrop().contains("one"));
   }
 
-  @Test(timeout = 20000)
+  @Test(timeout = 60_000L)
   public void testRealModeWithMainThread() throws Exception
   {
     LookupReferencesManager lookupReferencesManager = new LookupReferencesManager(
diff --git a/server/src/test/java/io/druid/segment/realtime/RealtimeManagerTest.java b/server/src/test/java/io/druid/segment/realtime/RealtimeManagerTest.java
index 25533ac4d1e..81f67006b4e 100644
--- a/server/src/test/java/io/druid/segment/realtime/RealtimeManagerTest.java
+++ b/server/src/test/java/io/druid/segment/realtime/RealtimeManagerTest.java
@@ -376,7 +376,7 @@ public void testRunV2() throws Exception
     Assert.assertEquals(0, plumber2.getPersistCount());
   }
 
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testNormalStop() throws InterruptedException
   {
     final TestFirehose firehose = new TestFirehose(rows.iterator());
@@ -421,7 +421,7 @@ public Firehose connect(InputRowParser parser, File temporaryDirectory)
     Assert.assertTrue(plumber2.isFinishedJob());
   }
 
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testStopByInterruption()
   {
     final SleepingFirehose firehose = new SleepingFirehose();
@@ -454,7 +454,7 @@ public Firehose connect(InputRowParser parser, File temporaryDirectory)
     Assert.assertFalse(plumber.isFinishedJob());
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testQueryWithInterval() throws InterruptedException
   {
     List<Row> expectedResults = Arrays.asList(
@@ -532,7 +532,7 @@ private void awaitStarted() throws InterruptedException
     }
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testQueryWithSegmentSpec() throws InterruptedException
   {
     List<Row> expectedResults = Arrays.asList(
@@ -611,7 +611,7 @@ public void testQueryWithSegmentSpec() throws InterruptedException
 
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testQueryWithMultipleSegmentSpec() throws InterruptedException
   {
 
diff --git a/server/src/test/java/io/druid/segment/realtime/appenderator/AppenderatorTest.java b/server/src/test/java/io/druid/segment/realtime/appenderator/AppenderatorTest.java
index a052583ed88..3b74c71d244 100644
--- a/server/src/test/java/io/druid/segment/realtime/appenderator/AppenderatorTest.java
+++ b/server/src/test/java/io/druid/segment/realtime/appenderator/AppenderatorTest.java
@@ -414,7 +414,7 @@ public void run()
     }
   }
 
-  @Test(timeout = 10000L)
+  @Test(timeout = 60_000L)
   public void testTotalRowCount() throws Exception
   {
     try (final AppenderatorTester tester = new AppenderatorTester(3, true)) {
diff --git a/server/src/test/java/io/druid/segment/realtime/appenderator/StreamAppenderatorDriverTest.java b/server/src/test/java/io/druid/segment/realtime/appenderator/StreamAppenderatorDriverTest.java
index 603d5db13d3..5592a99858b 100644
--- a/server/src/test/java/io/druid/segment/realtime/appenderator/StreamAppenderatorDriverTest.java
+++ b/server/src/test/java/io/druid/segment/realtime/appenderator/StreamAppenderatorDriverTest.java
@@ -126,7 +126,7 @@ public void tearDown() throws Exception
     driver.close();
   }
 
-  @Test(timeout = 2000L)
+  @Test(timeout = 60_000L)
   public void testSimple() throws Exception
   {
     final TestCommitterSupplier<Integer> committerSupplier = new TestCommitterSupplier<>();
@@ -204,7 +204,7 @@ public void testMaxRowsPerSegment() throws Exception
     Assert.assertEquals(numSegments * MAX_ROWS_PER_SEGMENT, segmentsAndMetadata.getCommitMetadata());
   }
 
-  @Test(timeout = 5000L, expected = TimeoutException.class)
+  @Test(timeout = 60_000L, expected = TimeoutException.class)
   public void testHandoffTimeout() throws Exception
   {
     final TestCommitterSupplier<Integer> committerSupplier = new TestCommitterSupplier<>();
diff --git a/server/src/test/java/io/druid/segment/realtime/firehose/EventReceiverFirehoseTest.java b/server/src/test/java/io/druid/segment/realtime/firehose/EventReceiverFirehoseTest.java
index ffe066f5d02..02aa14a412d 100644
--- a/server/src/test/java/io/druid/segment/realtime/firehose/EventReceiverFirehoseTest.java
+++ b/server/src/test/java/io/druid/segment/realtime/firehose/EventReceiverFirehoseTest.java
@@ -241,7 +241,7 @@ public void testDuplicateRegistering()
             );
   }
 
-  @Test(timeout = 40_000L)
+  @Test(timeout = 60_000L)
   public void testShutdownWithPrevTime() throws Exception
   {
     EasyMock.expect(req.getAttribute(AuthConfig.DRUID_AUTHORIZATION_CHECKED))
@@ -261,7 +261,7 @@ public void testShutdownWithPrevTime() throws Exception
     }
   }
 
-  @Test(timeout = 40_000L)
+  @Test(timeout = 60_000L)
   public void testShutdown() throws Exception
   {
     EasyMock.expect(req.getAttribute(AuthConfig.DRUID_AUTHORIZATION_CHECKED))
diff --git a/server/src/test/java/io/druid/segment/realtime/plumber/RealtimePlumberSchoolTest.java b/server/src/test/java/io/druid/segment/realtime/plumber/RealtimePlumberSchoolTest.java
index 5dfc753f686..f7e1df3c041 100644
--- a/server/src/test/java/io/druid/segment/realtime/plumber/RealtimePlumberSchoolTest.java
+++ b/server/src/test/java/io/druid/segment/realtime/plumber/RealtimePlumberSchoolTest.java
@@ -248,13 +248,13 @@ public void tearDown() throws Exception
     FileUtils.deleteDirectory(tmpDir);
   }
 
-  @Test(timeout = 60000)
+  @Test(timeout = 60_000L)
   public void testPersist() throws Exception
   {
     testPersist(null);
   }
 
-  @Test(timeout = 60000)
+  @Test(timeout = 60_000L)
   public void testPersistWithCommitMetadata() throws Exception
   {
     final Object commitMetadata = "dummyCommitMetadata";
@@ -309,7 +309,7 @@ public void run()
     plumber.finishJob();
   }
 
-  @Test(timeout = 60000)
+  @Test(timeout = 60_000L)
   public void testPersistFails() throws Exception
   {
     Sink sink = new Sink(
@@ -356,7 +356,7 @@ public void run()
     Assert.assertEquals(1, metrics.failedPersists());
   }
 
-  @Test(timeout = 60000)
+  @Test(timeout = 60_000L)
   public void testPersistHydrantGaps() throws Exception
   {
     final Object commitMetadata = "dummyCommitMetadata";
@@ -461,7 +461,7 @@ public void run()
     Assert.assertEquals(0, restoredPlumber2.getSinks().size());
   }
 
-  @Test(timeout = 60000)
+  @Test(timeout = 60_000L)
   public void testDimOrderInheritance() throws Exception
   {
     final Object commitMetadata = "dummyCommitMetadata";
diff --git a/server/src/test/java/io/druid/server/AsyncQueryForwardingServletTest.java b/server/src/test/java/io/druid/server/AsyncQueryForwardingServletTest.java
index c7c91ff5a94..3870eb09487 100644
--- a/server/src/test/java/io/druid/server/AsyncQueryForwardingServletTest.java
+++ b/server/src/test/java/io/druid/server/AsyncQueryForwardingServletTest.java
@@ -164,7 +164,7 @@ public void testProxyGzipCompression() throws Exception
     Assert.assertNotEquals("gzip", postNoGzip.getContentEncoding());
   }
 
-  @Test(timeout = 60_000)
+  @Test(timeout = 60_000L)
   public void testDeleteBroadcast() throws Exception
   {
     CountDownLatch latch = new CountDownLatch(2);
diff --git a/server/src/test/java/io/druid/server/audit/SQLAuditManagerTest.java b/server/src/test/java/io/druid/server/audit/SQLAuditManagerTest.java
index 24fb1496a57..6accd613b68 100644
--- a/server/src/test/java/io/druid/server/audit/SQLAuditManagerTest.java
+++ b/server/src/test/java/io/druid/server/audit/SQLAuditManagerTest.java
@@ -64,7 +64,7 @@ public void setUp()
     );
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testAuditEntrySerde() throws IOException
   {
     AuditEntry entry = new AuditEntry(
@@ -83,7 +83,7 @@ public void testAuditEntrySerde() throws IOException
     Assert.assertEquals(entry, serde);
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testCreateAuditEntry() throws IOException
   {
     AuditEntry entry = new AuditEntry(
@@ -109,7 +109,7 @@ public void testCreateAuditEntry() throws IOException
 
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testFetchAuditHistory()
   {
     AuditEntry entry = new AuditEntry(
@@ -135,7 +135,7 @@ public void testFetchAuditHistory()
     Assert.assertEquals(entry, auditEntries.get(1));
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testFetchAuditHistoryByKeyAndTypeWithLimit()
   {
     AuditEntry entry1 = new AuditEntry(
@@ -171,7 +171,7 @@ public void testFetchAuditHistoryByKeyAndTypeWithLimit()
     Assert.assertEquals(entry1, auditEntries.get(0));
   }
 
-  @Test(timeout = 10_000L)
+  @Test(timeout = 60_000L)
   public void testFetchAuditHistoryByTypeWithLimit()
   {
     AuditEntry entry1 = new AuditEntry(
diff --git a/server/src/test/java/io/druid/server/coordination/ChangeRequestHttpSyncerTest.java b/server/src/test/java/io/druid/server/coordination/ChangeRequestHttpSyncerTest.java
index 0af314bd4aa..73ba16accd7 100644
--- a/server/src/test/java/io/druid/server/coordination/ChangeRequestHttpSyncerTest.java
+++ b/server/src/test/java/io/druid/server/coordination/ChangeRequestHttpSyncerTest.java
@@ -50,7 +50,7 @@
  */
 public class ChangeRequestHttpSyncerTest
 {
-  @Test(timeout = 10000)
+  @Test(timeout = 60_000L)
   public void testSimple() throws Exception
   {
     ObjectMapper jsonMapper = TestHelper.makeJsonMapper();
diff --git a/server/src/test/java/io/druid/server/coordination/SegmentLoadDropHandlerTest.java b/server/src/test/java/io/druid/server/coordination/SegmentLoadDropHandlerTest.java
index 26eaeef058a..30ae75eb8bc 100644
--- a/server/src/test/java/io/druid/server/coordination/SegmentLoadDropHandlerTest.java
+++ b/server/src/test/java/io/druid/server/coordination/SegmentLoadDropHandlerTest.java
@@ -449,7 +449,7 @@ public int getAnnounceIntervalMillis()
     Assert.assertTrue(infoDir.delete());
   }
 
-  @Test(timeout = 1000L)
+  @Test(timeout = 60_000L)
   public void testProcessBatch() throws Exception
   {
     segmentLoadDropHandler.start();
diff --git a/server/src/test/java/io/druid/server/coordination/ZkCoordinatorTest.java b/server/src/test/java/io/druid/server/coordination/ZkCoordinatorTest.java
index 35433da5a44..bfbe8b34eb1 100644
--- a/server/src/test/java/io/druid/server/coordination/ZkCoordinatorTest.java
+++ b/server/src/test/java/io/druid/server/coordination/ZkCoordinatorTest.java
@@ -81,7 +81,7 @@ public void tearDown()
     tearDownServerAndCurator();
   }
 
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testLoadDrop() throws Exception
   {
     EmittingLogger.registerEmitter(new NoopServiceEmitter());
diff --git a/server/src/test/java/io/druid/server/coordinator/CuratorDruidCoordinatorTest.java b/server/src/test/java/io/druid/server/coordinator/CuratorDruidCoordinatorTest.java
index 256d819cd90..d1d13e2bca1 100644
--- a/server/src/test/java/io/druid/server/coordinator/CuratorDruidCoordinatorTest.java
+++ b/server/src/test/java/io/druid/server/coordinator/CuratorDruidCoordinatorTest.java
@@ -240,7 +240,7 @@ public void tearDown() throws Exception
     tearDownServerAndCurator();
   }
 
-  @Test(timeout = 10_000)
+  @Test(timeout = 60_000L)
   public void testMoveSegment() throws Exception
   {
     segmentViewInitLatch = new CountDownLatch(1);
diff --git a/server/src/test/java/io/druid/server/coordinator/HttpLoadQueuePeonTest.java b/server/src/test/java/io/druid/server/coordinator/HttpLoadQueuePeonTest.java
index c2388359a1e..069279d2b43 100644
--- a/server/src/test/java/io/druid/server/coordinator/HttpLoadQueuePeonTest.java
+++ b/server/src/test/java/io/druid/server/coordinator/HttpLoadQueuePeonTest.java
@@ -98,7 +98,7 @@ public int getHttpLoadQueuePeonBatchSize()
     }
   };
 
-  @Test(timeout = 10000)
+  @Test(timeout = 60_000L)
   public void testSimple() throws Exception
   {
     HttpLoadQueuePeon httpLoadQueuePeon = new HttpLoadQueuePeon(
@@ -135,7 +135,7 @@ public void testSimple() throws Exception
     httpLoadQueuePeon.stop();
   }
 
-  @Test(timeout = 10000)
+  @Test(timeout = 60_000L)
   public void testLoadDropAfterStop() throws Exception
   {
     HttpLoadQueuePeon httpLoadQueuePeon = new HttpLoadQueuePeon(
diff --git a/server/src/test/java/io/druid/server/initialization/jetty/LimitRequestsFilterTest.java b/server/src/test/java/io/druid/server/initialization/jetty/LimitRequestsFilterTest.java
index 70c620fcfc1..18893e3da48 100644
--- a/server/src/test/java/io/druid/server/initialization/jetty/LimitRequestsFilterTest.java
+++ b/server/src/test/java/io/druid/server/initialization/jetty/LimitRequestsFilterTest.java
@@ -33,7 +33,7 @@
  */
 public class LimitRequestsFilterTest
 {
-  @Test(timeout = 5000L)
+  @Test(timeout = 60_000L)
   public void testSimple() throws Exception
   {
     LimitRequestsFilter filter = new LimitRequestsFilter(2);
diff --git a/server/src/test/java/io/druid/server/lookup/cache/LookupCoordinatorManagerTest.java b/server/src/test/java/io/druid/server/lookup/cache/LookupCoordinatorManagerTest.java
index 3eb29e25494..f07adfd4db0 100644
--- a/server/src/test/java/io/druid/server/lookup/cache/LookupCoordinatorManagerTest.java
+++ b/server/src/test/java/io/druid/server/lookup/cache/LookupCoordinatorManagerTest.java
@@ -1028,7 +1028,7 @@ public void testGetLookupIgnoresNotReady()
   }
 
 
-  @Test(timeout = 2_000)
+  @Test(timeout = 60_000L)
   public void testLookupManagementLoop() throws Exception
   {
     Map<String, LookupExtractorFactoryMapContainer> lookup1 = ImmutableMap.of(
diff --git a/sql/src/test/java/io/druid/sql/avatica/DruidAvaticaHandlerTest.java b/sql/src/test/java/io/druid/sql/avatica/DruidAvaticaHandlerTest.java
index 1637369d0b9..e18384b1c27 100644
--- a/sql/src/test/java/io/druid/sql/avatica/DruidAvaticaHandlerTest.java
+++ b/sql/src/test/java/io/druid/sql/avatica/DruidAvaticaHandlerTest.java
@@ -551,7 +551,7 @@ public void testDatabaseMetaDataColumnsWithSuperuser() throws Exception
   }
 
 
-  @Test(timeout = 90000)
+  @Test(timeout = 90_000L)
   public void testConcurrentQueries() throws Exception
   {
     final List<ListenableFuture<Integer>> futures = new ArrayList<>();


 

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

---------------------------------------------------------------------
To unsubscribe, e-mail: dev-unsubscribe@druid.apache.org
For additional commands, e-mail: dev-help@druid.apache.org