You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by zh...@apache.org on 2018/02/11 07:13:24 UTC

[03/15] hbase git commit: HBASE-19951 Cleanup the explicit timeout value for test method

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestProcedureAdmin.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestProcedureAdmin.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestProcedureAdmin.java
index 9a1c2d2..c003379 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestProcedureAdmin.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestProcedureAdmin.java
@@ -94,7 +94,7 @@ public class TestProcedureAdmin {
     }
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testAbortProcedureSuccess() throws Exception {
     final TableName tableName = TableName.valueOf(name.getMethodName());
     final ProcedureExecutor<MasterProcedureEnv> procExec = getMasterProcedureExecutor();
@@ -119,7 +119,7 @@ public class TestProcedureAdmin {
       tableName);
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testAbortProcedureFailure() throws Exception {
     final TableName tableName = TableName.valueOf(name.getMethodName());
     final ProcedureExecutor<MasterProcedureEnv> procExec = getMasterProcedureExecutor();
@@ -151,7 +151,7 @@ public class TestProcedureAdmin {
       UTIL.getHBaseCluster().getMaster(), tableName);
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testAbortProcedureInterruptedNotAllowed() throws Exception {
     final TableName tableName = TableName.valueOf(name.getMethodName());
     final ProcedureExecutor<MasterProcedureEnv> procExec = getMasterProcedureExecutor();
@@ -179,7 +179,7 @@ public class TestProcedureAdmin {
       UTIL.getHBaseCluster().getMaster(), tableName);
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testAbortNonExistProcedure() throws Exception {
     final ProcedureExecutor<MasterProcedureEnv> procExec = getMasterProcedureExecutor();
     Random randomGenerator = new Random();
@@ -193,7 +193,7 @@ public class TestProcedureAdmin {
     assertFalse(abortResult);
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testGetProcedure() throws Exception {
     final TableName tableName = TableName.valueOf(name.getMethodName());
     final ProcedureExecutor<MasterProcedureEnv> procExec = getMasterProcedureExecutor();

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestRestoreSnapshotProcedure.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestRestoreSnapshotProcedure.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestRestoreSnapshotProcedure.java
index 4995315..e9e5ebe 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestRestoreSnapshotProcedure.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestRestoreSnapshotProcedure.java
@@ -148,7 +148,7 @@ public class TestRestoreSnapshotProcedure extends TestTableDDLProcedureBase {
     return htd;
   }
 
-  @Test(timeout=600000)
+  @Test
   public void testRestoreSnapshot() throws Exception {
     final ProcedureExecutor<MasterProcedureEnv> procExec = getMasterProcedureExecutor();
 
@@ -160,7 +160,7 @@ public class TestRestoreSnapshotProcedure extends TestTableDDLProcedureBase {
     validateSnapshotRestore();
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testRestoreSnapshotToDifferentTable() throws Exception {
     final ProcedureExecutor<MasterProcedureEnv> procExec = getMasterProcedureExecutor();
     final TableName restoredTableName = TableName.valueOf(name.getMethodName());
@@ -175,7 +175,7 @@ public class TestRestoreSnapshotProcedure extends TestTableDDLProcedureBase {
       ProcedureTestingUtility.getExceptionCause(result) instanceof TableNotFoundException);
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testRestoreSnapshotToEnabledTable() throws Exception {
     final ProcedureExecutor<MasterProcedureEnv> procExec = getMasterProcedureExecutor();
 
@@ -195,7 +195,7 @@ public class TestRestoreSnapshotProcedure extends TestTableDDLProcedureBase {
     }
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testRecoveryAndDoubleExecution() throws Exception {
     final ProcedureExecutor<MasterProcedureEnv> procExec = getMasterProcedureExecutor();
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestSafemodeBringsDownMaster.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestSafemodeBringsDownMaster.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestSafemodeBringsDownMaster.java
index 274b4e5..44c5510 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestSafemodeBringsDownMaster.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestSafemodeBringsDownMaster.java
@@ -94,7 +94,7 @@ public class TestSafemodeBringsDownMaster {
   public void tearDown() throws Exception {
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testSafemodeBringsDownMaster() throws Exception {
     final TableName tableName = TableName.valueOf("testSafemodeBringsDownMaster");
     final byte[][] splitKeys = new byte[][] {

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestServerCrashProcedure.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestServerCrashProcedure.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestServerCrashProcedure.java
index f8899e7..58d5d46 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestServerCrashProcedure.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestServerCrashProcedure.java
@@ -87,17 +87,17 @@ public class TestServerCrashProcedure {
   }
 
 
-  @Test(timeout=60000)
+  @Test
   public void testCrashTargetRs() throws Exception {
     testRecoveryAndDoubleExecution(false, false);
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testRecoveryAndDoubleExecutionOnRsWithMeta() throws Exception {
     testRecoveryAndDoubleExecution(true, true);
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testRecoveryAndDoubleExecutionOnRsWithoutMeta() throws Exception {
     testRecoveryAndDoubleExecution(false, true);
   }

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestWALProcedureStoreOnHDFS.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestWALProcedureStoreOnHDFS.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestWALProcedureStoreOnHDFS.java
index ac6a3c5..99699ff 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestWALProcedureStoreOnHDFS.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/master/procedure/TestWALProcedureStoreOnHDFS.java
@@ -104,7 +104,7 @@ public class TestWALProcedureStoreOnHDFS {
     }
   }
 
-  @Test(timeout=60000, expected=RuntimeException.class)
+  @Test(expected=RuntimeException.class)
   public void testWalAbortOnLowReplication() throws Exception {
     setupDFS();
 
@@ -123,7 +123,7 @@ public class TestWALProcedureStoreOnHDFS {
     assertFalse(store.isRunning());
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testWalAbortOnLowReplicationWithQueuedWriters() throws Exception {
     setupDFS();
 
@@ -167,7 +167,7 @@ public class TestWALProcedureStoreOnHDFS {
                                    reCount.get() < thread.length);
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testWalRollOnLowReplication() throws Exception {
     UTIL.getConfiguration().setInt("dfs.namenode.replication.min", 1);
     setupDFS();

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/master/snapshot/TestSnapshotFileCache.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/master/snapshot/TestSnapshotFileCache.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/master/snapshot/TestSnapshotFileCache.java
index 80bb9ca..cc5e755 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/master/snapshot/TestSnapshotFileCache.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/master/snapshot/TestSnapshotFileCache.java
@@ -92,7 +92,7 @@ public class TestSnapshotFileCache {
     fs.delete(snapshotDir, true);
   }
 
-  @Test(timeout = 10000000)
+  @Test
   public void testLoadAndDelete() throws IOException {
     // don't refresh the cache unless we tell it to
     long period = Long.MAX_VALUE;

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/mob/compactions/TestMobCompactor.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/mob/compactions/TestMobCompactor.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/mob/compactions/TestMobCompactor.java
index 8ef8c7a..7c67cd8 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/mob/compactions/TestMobCompactor.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/mob/compactions/TestMobCompactor.java
@@ -278,7 +278,7 @@ public class TestMobCompactor {
     LOG.info("alter status finished");
   }
 
-  @Test(timeout = 300000)
+  @Test
   public void testMinorCompaction() throws Exception {
     resetConf();
     int mergeSize = 5000;
@@ -428,7 +428,7 @@ public class TestMobCompactor {
         new String[] { "20150907", "20151128", "20151205", "20160103" }, false);
   }
 
-  @Test(timeout = 300000)
+  @Test
   public void testCompactionWithHFileLink() throws IOException, InterruptedException {
     resetConf();
     String tableNameAsString = "testCompactionWithHFileLink";
@@ -517,7 +517,7 @@ public class TestMobCompactor {
     assertRefFileNameEqual(family1);
   }
 
-  @Test(timeout = 300000)
+  @Test
   public void testMajorCompactionFromAdmin() throws Exception {
     resetConf();
     int mergeSize = 5000;
@@ -592,7 +592,7 @@ public class TestMobCompactor {
     table.close();
   }
 
-  @Test(timeout = 300000)
+  @Test
   public void testScannerOnBulkLoadRefHFiles() throws Exception {
     resetConf();
     setUp("testScannerOnBulkLoadRefHFiles");
@@ -652,7 +652,7 @@ public class TestMobCompactor {
    * is compacted with some other normal hfiles. This is to make sure the mvcc is included
    * after compaction for mob enabled store files.
    */
-  @Test(timeout = 300000)
+  @Test
   public void testGetAfterCompaction() throws Exception {
     resetConf();
     conf.setLong(TimeToLiveHFileCleaner.TTL_CONF_KEY, 0);

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedure.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedure.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedure.java
index 0fe171f..def375d 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedure.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedure.java
@@ -88,7 +88,7 @@ public class TestProcedure {
    * With a single member, verify ordered execution.  The Coordinator side is run in a separate
    * thread so we can only trigger from members and wait for particular state latches.
    */
-  @Test(timeout = 60000)
+  @Test
   public void testSingleMember() throws Exception {
     // The member
     List<String> members =  new ArrayList<>();
@@ -133,7 +133,7 @@ public class TestProcedure {
     verify(procspy, never()).receive(any());
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testMultipleMember() throws Exception {
     // 2 members
     List<String> members =  new ArrayList<>();
@@ -186,7 +186,7 @@ public class TestProcedure {
     verify(procspy, never()).receive(any());
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testErrorPropagation() throws Exception {
     List<String> members =  new ArrayList<>();
     members.add("member");
@@ -212,7 +212,7 @@ public class TestProcedure {
     verify(procspy).sendGlobalBarrierComplete();
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testBarrieredErrorPropagation() throws Exception {
     List<String> members =  new ArrayList<>();
     members.add("member");

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureCoordinator.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureCoordinator.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureCoordinator.java
index 077ed19..6bc35d6 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureCoordinator.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureCoordinator.java
@@ -123,7 +123,7 @@ public class TestProcedureCoordinator {
   /**
    * Check handling a connection failure correctly if we get it during the acquiring phase
    */
-  @Test(timeout = 60000)
+  @Test
   public void testUnreachableControllerDuringPrepare() throws Exception {
     coordinator = buildNewCoordinator();
     // setup the proc
@@ -154,7 +154,7 @@ public class TestProcedureCoordinator {
   /**
    * Check handling a connection failure correctly if we get it during the barrier phase
    */
-  @Test(timeout = 60000)
+  @Test
   public void testUnreachableControllerDuringCommit() throws Exception {
     coordinator = buildNewCoordinator();
 
@@ -184,17 +184,17 @@ public class TestProcedureCoordinator {
         anyListOf(String.class));
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testNoCohort() throws Exception {
     runSimpleProcedure();
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testSingleCohortOrchestration() throws Exception {
     runSimpleProcedure("one");
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testMultipleCohortOrchestration() throws Exception {
     runSimpleProcedure("one", "two", "three", "four");
   }
@@ -210,7 +210,7 @@ public class TestProcedureCoordinator {
   /**
    * Test that if nodes join the barrier early we still correctly handle the progress
    */
-  @Test(timeout = 60000)
+  @Test
   public void testEarlyJoiningBarrier() throws Exception {
     final String[] cohort = new String[] { "one", "two", "three", "four" };
     coordinator = buildNewCoordinator();

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureMember.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureMember.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureMember.java
index 20406fe..b95ddf2 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureMember.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureMember.java
@@ -129,7 +129,7 @@ public class TestProcedureMember {
   /**
    * Test the normal sub procedure execution case.
    */
-  @Test(timeout = 500)
+  @Test
   public void testSimpleRun() throws Exception {
     member = buildCohortMember();
     EmptySubprocedure subproc = new EmptySubprocedure(member, mockListener);
@@ -160,7 +160,7 @@ public class TestProcedureMember {
    * Make sure we call cleanup etc, when we have an exception during
    * {@link Subprocedure#acquireBarrier()}.
    */
-  @Test(timeout = 60000)
+  @Test
   public void testMemberPrepareException() throws Exception {
     buildCohortMemberPair();
 
@@ -195,7 +195,7 @@ public class TestProcedureMember {
   /**
    * Make sure we call cleanup etc, when we have an exception during prepare.
    */
-  @Test(timeout = 60000)
+  @Test
   public void testSendMemberAcquiredCommsFailure() throws Exception {
     buildCohortMemberPair();
 
@@ -234,7 +234,7 @@ public class TestProcedureMember {
    * is checked.  Thus, the {@link Subprocedure#acquireBarrier()} should succeed but later get rolled back
    * via {@link Subprocedure#cleanup}.
    */
-  @Test(timeout = 60000)
+  @Test
   public void testCoordinatorAbort() throws Exception {
     buildCohortMemberPair();
 
@@ -279,7 +279,7 @@ public class TestProcedureMember {
    * member.  Members are then responsible for reading its TX log.  This implementation actually
    * rolls back, and thus breaks the normal TX guarantees.
   */
-  @Test(timeout = 60000)
+  @Test
   public void testMemberCommitException() throws Exception {
     buildCohortMemberPair();
 
@@ -320,7 +320,7 @@ public class TestProcedureMember {
    * member.  Members are then responsible for reading its TX log.  This implementation actually
    * rolls back, and thus breaks the normal TX guarantees.
   */
-  @Test(timeout = 60000)
+  @Test
   public void testMemberCommitCommsFailure() throws Exception {
     buildCohortMemberPair();
     final TimeoutException oate = new TimeoutException("bogus timeout",1,2,0);
@@ -358,7 +358,7 @@ public class TestProcedureMember {
    * Fail correctly on getting an external error while waiting for the prepared latch
    * @throws Exception on failure
    */
-  @Test(timeout = 60000)
+  @Test
   public void testPropagateConnectionErrorBackToManager() throws Exception {
     // setup the operation
     member = buildCohortMember();

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestZKProcedureControllers.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestZKProcedureControllers.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestZKProcedureControllers.java
index fef7794..143f30d 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestZKProcedureControllers.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestZKProcedureControllers.java
@@ -83,7 +83,7 @@ public class TestZKProcedureControllers {
    * Smaller test to just test the actuation on the cohort member
    * @throws Exception on failure
    */
-  @Test(timeout = 60000)
+  @Test
   public void testSimpleZKCohortMemberController() throws Exception {
     ZKWatcher watcher = UTIL.getZooKeeperWatcher();
     final String operationName = "instanceTest";
@@ -146,7 +146,7 @@ public class TestZKProcedureControllers {
     assertEquals("Didn't delete commit node", -1, ZKUtil.checkExists(watcher, commit));
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testZKCoordinatorControllerWithNoCohort() throws Exception {
     final String operationName = "no cohort controller test";
     final byte[] data = new byte[] { 1, 2, 3 };
@@ -155,7 +155,7 @@ public class TestZKProcedureControllers {
     runMockCommitWithOrchestratedControllers(startCohortFirst, operationName, data);
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testZKCoordinatorControllerWithSingleMemberCohort() throws Exception {
     final String operationName = "single member controller test";
     final byte[] data = new byte[] { 1, 2, 3 };
@@ -164,7 +164,7 @@ public class TestZKProcedureControllers {
     runMockCommitWithOrchestratedControllers(startCohortFirst, operationName, data, "cohort");
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testZKCoordinatorControllerMultipleCohort() throws Exception {
     final String operationName = "multi member controller test";
     final byte[] data = new byte[] { 1, 2, 3 };

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestQuotaState.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestQuotaState.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestQuotaState.java
index c16478b..b0d619e 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestQuotaState.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestQuotaState.java
@@ -49,7 +49,7 @@ public class TestQuotaState {
   @Rule
   public TestName name = new TestName();
 
-  @Test(timeout=60000)
+  @Test
   public void testQuotaStateBypass() {
     QuotaState quotaInfo = new QuotaState();
     assertTrue(quotaInfo.isBypass());
@@ -60,7 +60,7 @@ public class TestQuotaState {
     assertNoopLimiter(userQuotaState.getTableLimiter(UNKNOWN_TABLE_NAME));
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testSimpleQuotaStateOperation() {
     final TableName tableName = TableName.valueOf(name.getMethodName());
     final int NUM_GLOBAL_THROTTLE = 3;
@@ -81,7 +81,7 @@ public class TestQuotaState {
     assertThrottleException(quotaInfo.getTableLimiter(tableName), NUM_TABLE_THROTTLE);
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testQuotaStateUpdateBypassThrottle() {
     final long LAST_UPDATE = 10;
 
@@ -100,7 +100,7 @@ public class TestQuotaState {
     assertNoopLimiter(quotaInfo.getTableLimiter(UNKNOWN_TABLE_NAME));
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testQuotaStateUpdateGlobalThrottle() {
     final int NUM_GLOBAL_THROTTLE_1 = 3;
     final int NUM_GLOBAL_THROTTLE_2 = 11;
@@ -146,7 +146,7 @@ public class TestQuotaState {
     assertNoopLimiter(quotaInfo.getGlobalLimiter());
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testQuotaStateUpdateTableThrottle() {
     final TableName tableNameA = TableName.valueOf(name.getMethodName() + "A");
     final TableName tableNameB = TableName.valueOf(name.getMethodName() + "B");

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestQuotaThrottle.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestQuotaThrottle.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestQuotaThrottle.java
index 1c3eae4..a7b8d9d 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestQuotaThrottle.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestQuotaThrottle.java
@@ -117,7 +117,7 @@ public class TestQuotaThrottle {
     }
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testUserGlobalThrottle() throws Exception {
     final Admin admin = TEST_UTIL.getAdmin();
     final String userName = User.getCurrent().getShortName();
@@ -141,7 +141,7 @@ public class TestQuotaThrottle {
     assertEquals(60, doGets(60, tables));
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testUserGlobalReadAndWriteThrottle() throws Exception {
     final Admin admin = TEST_UTIL.getAdmin();
     final String userName = User.getCurrent().getShortName();
@@ -173,7 +173,7 @@ public class TestQuotaThrottle {
     assertEquals(60, doGets(60, tables));
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testUserTableThrottle() throws Exception {
     final Admin admin = TEST_UTIL.getAdmin();
     final String userName = User.getCurrent().getShortName();
@@ -198,7 +198,7 @@ public class TestQuotaThrottle {
     assertEquals(60, doGets(60, tables));
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testUserTableReadAndWriteThrottle() throws Exception {
     final Admin admin = TEST_UTIL.getAdmin();
     final String userName = User.getCurrent().getShortName();
@@ -239,7 +239,7 @@ public class TestQuotaThrottle {
     assertEquals(60, doGets(60, tables));
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testUserNamespaceThrottle() throws Exception {
     final Admin admin = TEST_UTIL.getAdmin();
     final String userName = User.getCurrent().getShortName();
@@ -264,7 +264,7 @@ public class TestQuotaThrottle {
     assertEquals(60, doGets(60, tables));
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testUserNamespaceReadAndWriteThrottle() throws Exception {
     final Admin admin = TEST_UTIL.getAdmin();
     final String userName = User.getCurrent().getShortName();
@@ -297,7 +297,7 @@ public class TestQuotaThrottle {
     assertEquals(60, doGets(60, tables));
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testTableGlobalThrottle() throws Exception {
     final Admin admin = TEST_UTIL.getAdmin();
 
@@ -321,7 +321,7 @@ public class TestQuotaThrottle {
     assertEquals(80, doGets(80, tables[0], tables[1]));
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testTableGlobalReadAndWriteThrottle() throws Exception {
     final Admin admin = TEST_UTIL.getAdmin();
 
@@ -358,7 +358,7 @@ public class TestQuotaThrottle {
     assertEquals(80, doGets(80, tables[0], tables[1]));
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testNamespaceGlobalThrottle() throws Exception {
     final Admin admin = TEST_UTIL.getAdmin();
     final String NAMESPACE = "default";
@@ -380,7 +380,7 @@ public class TestQuotaThrottle {
     assertEquals(40, doPuts(40, tables[0]));
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testNamespaceGlobalReadAndWriteThrottle() throws Exception {
     final Admin admin = TEST_UTIL.getAdmin();
     final String NAMESPACE = "default";
@@ -411,7 +411,7 @@ public class TestQuotaThrottle {
     assertEquals(40, doPuts(40, tables[0]));
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testUserAndTableThrottle() throws Exception {
     final Admin admin = TEST_UTIL.getAdmin();
     final String userName = User.getCurrent().getShortName();
@@ -460,7 +460,7 @@ public class TestQuotaThrottle {
     assertEquals(40, doGets(40, tables[0]));
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testUserGlobalBypassThrottle() throws Exception {
     final Admin admin = TEST_UTIL.getAdmin();
     final String userName = User.getCurrent().getShortName();

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestSpaceQuotas.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestSpaceQuotas.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestSpaceQuotas.java
index f49fa40..ae71b31 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestSpaceQuotas.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/quotas/TestSpaceQuotas.java
@@ -239,7 +239,7 @@ public class TestSpaceQuotas {
     }
   }
 
-  @Test(timeout=120000)
+  @Test
   public void testNoBulkLoadsWithNoWrites() throws Exception {
     Put p = new Put(Bytes.toBytes("to_reject"));
     p.addColumn(
@@ -259,7 +259,7 @@ public class TestSpaceQuotas {
     }
   }
 
-  @Test(timeout=120000)
+  @Test
   public void testAtomicBulkLoadUnderQuota() throws Exception {
     // Need to verify that if the batch of hfiles cannot be loaded, none are loaded.
     TableName tn = helper.createTableWithRegions(10);
@@ -330,7 +330,7 @@ public class TestSpaceQuotas {
     }
   }
 
-  @Test(timeout=120000)
+  @Test
   public void testTableQuotaOverridesNamespaceQuota() throws Exception {
     final SpaceViolationPolicy policy = SpaceViolationPolicy.NO_INSERTS;
     final TableName tn = helper.createTableWithRegions(10);

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestCompactSplitThread.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestCompactSplitThread.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestCompactSplitThread.java
index ca746c3..d58fb27 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestCompactSplitThread.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestCompactSplitThread.java
@@ -153,7 +153,7 @@ public class TestCompactSplitThread {
     }
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testFlushWithTableCompactionDisabled() throws Exception {
     HTableDescriptor htd = new HTableDescriptor(tableName);
     htd.setCompactionEnabled(false);

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestCompactionState.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestCompactionState.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestCompactionState.java
index e0f87a6..599db54 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestCompactionState.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestCompactionState.java
@@ -69,22 +69,22 @@ public class TestCompactionState {
     TEST_UTIL.shutdownMiniCluster();
   }
 
-  @Test(timeout=600000)
+  @Test
   public void testMajorCompaction() throws IOException, InterruptedException {
     compaction(name.getMethodName(), 8, CompactionState.MAJOR, false);
   }
 
-  @Test(timeout=600000)
+  @Test
   public void testMinorCompaction() throws IOException, InterruptedException {
     compaction(name.getMethodName(), 15, CompactionState.MINOR, false);
   }
 
-  @Test(timeout=600000)
+  @Test
   public void testMajorCompactionOnFamily() throws IOException, InterruptedException {
     compaction(name.getMethodName(), 8, CompactionState.MAJOR, true);
   }
 
-  @Test(timeout=600000)
+  @Test
   public void testMinorCompactionOnFamily() throws IOException, InterruptedException {
     compaction(name.getMethodName(), 15, CompactionState.MINOR, true);
   }

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestFSErrorsExposed.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestFSErrorsExposed.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestFSErrorsExposed.java
index a7e959f..b423b45 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestFSErrorsExposed.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestFSErrorsExposed.java
@@ -184,7 +184,7 @@ public class TestFSErrorsExposed {
    * removes the data from HDFS underneath it, and ensures that
    * errors are bubbled to the client.
    */
-  @Test(timeout=5 * 60 * 1000)
+  @Test
   public void testFullSystemBubblesFSErrors() throws Exception {
     // We won't have an error if the datanode is not there if we use short circuit
     //  it's a known 'feature'.

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestFailedAppendAndSync.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestFailedAppendAndSync.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestFailedAppendAndSync.java
index e27a986..7cb3e63 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestFailedAppendAndSync.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestFailedAppendAndSync.java
@@ -108,7 +108,7 @@ public class TestFailedAppendAndSync {
    * First I need to set up some mocks for Server and RegionServerServices. I also need to
    * set up a dodgy WAL that will throw an exception when we go to append to it.
    */
-  @Test (timeout=300000)
+  @Test
   public void testLockupAroundBadAssignSync() throws IOException {
     final AtomicLong rolls = new AtomicLong(0);
     // Dodgy WAL. Will throw exceptions when flags set.

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionOnCluster.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionOnCluster.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionOnCluster.java
index fd44802..22ffeb0 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionOnCluster.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionOnCluster.java
@@ -68,7 +68,7 @@ public class TestHRegionOnCluster {
   @Rule
   public TestName name = new TestName();
 
-  @Test (timeout=300000)
+  @Test
   public void testDataCorrectnessReplayingRecoveredEdits() throws Exception {
     final int NUM_MASTERS = 1;
     final int NUM_RS = 3;

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionReplayEvents.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionReplayEvents.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionReplayEvents.java
index ca324de..44ff84d 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionReplayEvents.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionReplayEvents.java
@@ -254,7 +254,7 @@ public class TestHRegionReplayEvents {
    * Tests a case where we replay only a flush start marker, then the region is closed. This region
    * should not block indefinitely
    */
-  @Test (timeout = 60000)
+  @Test
   public void testOnlyReplayingFlushStartDoesNotHoldUpRegionClose() throws IOException {
     // load some data to primary and flush
     int start = 0;

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHStore.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHStore.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHStore.java
index c2bd83a..ea40200 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHStore.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestHStore.java
@@ -1465,7 +1465,7 @@ public class TestHStore {
    * @throws IOException
    * @throws InterruptedException
    */
-  @Test (timeout=30000)
+  @Test
   public void testRunDoubleMemStoreCompactors() throws IOException, InterruptedException {
     int flushSize = 500;
     Configuration conf = HBaseConfiguration.create();

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestMobStoreScanner.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestMobStoreScanner.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestMobStoreScanner.java
index 0135350..bcbc525 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestMobStoreScanner.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestMobStoreScanner.java
@@ -158,7 +158,7 @@ public class TestMobStoreScanner {
     testGetFromArchive(true);
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testGetMassive() throws Exception {
     setUp(defaultThreshold, TableName.valueOf(name.getMethodName()));
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestPerColumnFamilyFlush.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestPerColumnFamilyFlush.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestPerColumnFamilyFlush.java
index 8266a88..353cc28 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestPerColumnFamilyFlush.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestPerColumnFamilyFlush.java
@@ -127,7 +127,7 @@ public class TestPerColumnFamilyFlush {
       Arrays.equals(r.getFamilyMap(family).get(qf), val));
   }
 
-  @Test(timeout = 180000)
+  @Test
   public void testSelectiveFlushWhenEnabled() throws IOException {
     // Set up the configuration, use new one to not conflict with minicluster in other tests
     Configuration conf = new HBaseTestingUtility().getConfiguration();
@@ -269,7 +269,7 @@ public class TestPerColumnFamilyFlush {
     HBaseTestingUtility.closeRegionAndWAL(region);
   }
 
-  @Test(timeout = 180000)
+  @Test
   public void testSelectiveFlushWhenNotEnabled() throws IOException {
     // Set up the configuration, use new one to not conflict with minicluster in other tests
     Configuration conf = new HBaseTestingUtility().getConfiguration();
@@ -423,7 +423,7 @@ public class TestPerColumnFamilyFlush {
   }
 
   // Test Log Replay with Distributed log split on.
-  @Test(timeout = 180000)
+  @Test
   public void testLogReplayWithDistributedLogSplit() throws Exception {
     doTestLogReplay();
   }
@@ -442,7 +442,7 @@ public class TestPerColumnFamilyFlush {
    * test ensures that we do a full-flush in that scenario.
    * @throws IOException
    */
-  @Test(timeout = 180000)
+  @Test
   public void testFlushingWhenLogRolling() throws Exception {
     TableName tableName = TableName.valueOf("testFlushingWhenLogRolling");
     Configuration conf = TEST_UTIL.getConfiguration();
@@ -559,7 +559,7 @@ public class TestPerColumnFamilyFlush {
 
   // Under the same write load, small stores should have less store files when
   // percolumnfamilyflush enabled.
-  @Test(timeout = 180000)
+  @Test
   public void testCompareStoreFileCount() throws Exception {
     long memstoreFlushSize = 1024L * 1024;
     Configuration conf = TEST_UTIL.getConfiguration();

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRecoveredEdits.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRecoveredEdits.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRecoveredEdits.java
index f5bb735..cdf4801 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRecoveredEdits.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRecoveredEdits.java
@@ -77,7 +77,7 @@ public class TestRecoveredEdits {
    * made it in.
    * @throws IOException
    */
-  @Test (timeout=180000)
+  @Test
   public void testReplayWorksThoughLotsOfFlushing() throws
       IOException {
     for(MemoryCompactionPolicy policy : MemoryCompactionPolicy.values()) {

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionOpen.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionOpen.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionOpen.java
index 05d80e5..7190d84 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionOpen.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionOpen.java
@@ -82,7 +82,7 @@ public class TestRegionOpen {
     return HTU.getHBaseCluster().getLiveRegionServerThreads().get(0).getRegionServer();
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testPriorityRegionIsOpenedWithSeparateThreadPool() throws Exception {
     final TableName tableName = TableName.valueOf(TestRegionOpen.class.getSimpleName());
     ThreadPoolExecutor exec = getRS().getExecutorService()
@@ -100,7 +100,7 @@ public class TestRegionOpen {
     assertEquals(completed + 1, exec.getCompletedTaskCount());
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testNonExistentRegionReplica() throws Exception {
     final TableName tableName = TableName.valueOf(name.getMethodName());
     final byte[] FAMILYNAME = Bytes.toBytes("fam");

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicaFailover.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicaFailover.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicaFailover.java
index 67ed5c9..5cf1979 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicaFailover.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicaFailover.java
@@ -108,7 +108,7 @@ public class TestRegionReplicaFailover {
    * Tests the case where a newly created table with region replicas and no data, the secondary
    * region replicas are available to read immediately.
    */
-  @Test(timeout = 60000)
+  @Test
   public void testSecondaryRegionWithEmptyRegion() throws IOException {
     // Create a new table with region replication, don't put any data. Test that the secondary
     // region replica is available to read.
@@ -127,7 +127,7 @@ public class TestRegionReplicaFailover {
    * (enable/disable table, etc) makes the region replicas readable.
    * @throws IOException
    */
-  @Test(timeout = 60000)
+  @Test
   public void testSecondaryRegionWithNonEmptyRegion() throws IOException {
     // Create a new table with region replication and load some data
     // than disable and enable the table again and verify the data from secondary
@@ -146,7 +146,7 @@ public class TestRegionReplicaFailover {
   /**
    * Tests the case where killing a primary region with unflushed data recovers
    */
-  @Test (timeout = 120000)
+  @Test
   public void testPrimaryRegionKill() throws Exception {
     try (Connection connection = ConnectionFactory.createConnection(HTU.getConfiguration());
         Table table = connection.getTable(htd.getTableName())) {
@@ -209,7 +209,7 @@ public class TestRegionReplicaFailover {
    * Tests the case where killing a secondary region with unflushed data recovers, and the replica
    * becomes available to read again shortly.
    */
-  @Test (timeout = 120000)
+  @Test
   public void testSecondaryRegionKill() throws Exception {
     try (Connection connection = ConnectionFactory.createConnection(HTU.getConfiguration());
         Table table = connection.getTable(htd.getTableName())) {
@@ -250,7 +250,7 @@ public class TestRegionReplicaFailover {
    * new writes while one of the secondaries is killed. Verification is done for both of the
    * secondary replicas.
    */
-  @Test (timeout = 120000)
+  @Test
   public void testSecondaryRegionKillWhilePrimaryIsAcceptingWrites() throws Exception {
     try (Connection connection = ConnectionFactory.createConnection(HTU.getConfiguration());
         Table table = connection.getTable(htd.getTableName());
@@ -322,7 +322,7 @@ public class TestRegionReplicaFailover {
    * Tests the case where we are creating a table with a lot of regions and replicas. Opening region
    * replicas should not block handlers on RS indefinitely.
    */
-  @Test (timeout = 120000)
+  @Test
   public void testLotsOfRegionReplicas() throws IOException {
     int numRegions = NB_SERVERS * 20;
     int regionReplication = 10;

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicas.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicas.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicas.java
index c9a2260..263b0dd 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicas.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicas.java
@@ -122,7 +122,7 @@ public class TestRegionReplicas {
     return HTU.getMiniHBaseCluster().getRegionServer(0);
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testOpenRegionReplica() throws Exception {
     openRegion(HTU, getRS(), hriSecondary);
     try {
@@ -138,7 +138,7 @@ public class TestRegionReplicas {
   }
 
   /** Tests that the meta location is saved for secondary regions */
-  @Test(timeout = 60000)
+  @Test
   public void testRegionReplicaUpdatesMetaLocation() throws Exception {
     openRegion(HTU, getRS(), hriSecondary);
     Table meta = null;
@@ -152,7 +152,7 @@ public class TestRegionReplicas {
     }
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testRegionReplicaGets() throws Exception {
     try {
       //load some data to primary
@@ -176,7 +176,7 @@ public class TestRegionReplicas {
     }
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testGetOnTargetRegionReplica() throws Exception {
     try {
       //load some data to primary
@@ -233,7 +233,7 @@ public class TestRegionReplicas {
     before();
   }
 
-  @Test(timeout = 300000)
+  @Test
   public void testRefresStoreFiles() throws Exception {
     // enable store file refreshing
     final int refreshPeriod = 2000; // 2 sec
@@ -310,7 +310,7 @@ public class TestRegionReplicas {
     }
   }
 
-  @Test(timeout = 300000)
+  @Test
   public void testFlushAndCompactionsInPrimary() throws Exception {
 
     long runtime = 30 * 1000;
@@ -431,7 +431,7 @@ public class TestRegionReplicas {
     }
   }
 
-  @Test(timeout = 300000)
+  @Test
   public void testVerifySecondaryAbilityToReadWithOnFiles() throws Exception {
     // disable the store file refresh chore (we do this by hand)
     HTU.getConfiguration().setInt(StorefileRefresherChore.REGIONSERVER_STOREFILE_REFRESH_PERIOD, 0);

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicasAreDistributed.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicasAreDistributed.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicasAreDistributed.java
index 4e9972f..56c335b 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicasAreDistributed.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicasAreDistributed.java
@@ -112,7 +112,7 @@ public class TestRegionReplicasAreDistributed {
     return HTU.getMiniHBaseCluster().getRegionServer(2);
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testRegionReplicasCreatedAreDistributed() throws Exception {
     try {
       checkAndAssertRegionDistribution(false);

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicasWithModifyTable.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicasWithModifyTable.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicasWithModifyTable.java
index c3ae3fa..2a604b4 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicasWithModifyTable.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionReplicasWithModifyTable.java
@@ -107,7 +107,7 @@ public class TestRegionReplicasWithModifyTable {
     return HTU.getMiniHBaseCluster().getRegionServer(2);
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testRegionReplicasUsingEnableTable() throws Exception {
     TableName tableName = null;
     try {
@@ -128,7 +128,7 @@ public class TestRegionReplicasWithModifyTable {
     HTU.getAdmin().deleteTable(tableName);
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testRegionReplicasUsingEnableTableForMultipleRegions() throws Exception {
     TableName tableName = null;
     try {
@@ -144,7 +144,7 @@ public class TestRegionReplicasWithModifyTable {
     }
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testRegionReplicasByEnableTableWhenReplicaCountIsIncreased() throws Exception {
     TableName tableName = null;
     try {
@@ -160,7 +160,7 @@ public class TestRegionReplicasWithModifyTable {
     }
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testRegionReplicasByEnableTableWhenReplicaCountIsDecreased() throws Exception {
     TableName tableName = null;
     try {
@@ -176,7 +176,7 @@ public class TestRegionReplicasWithModifyTable {
     }
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testRegionReplicasByEnableTableWhenReplicaCountIsDecreasedWithMultipleRegions()
       throws Exception {
     TableName tableName = null;
@@ -193,7 +193,7 @@ public class TestRegionReplicasWithModifyTable {
     }
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testRegionReplicasByEnableTableWhenReplicaCountIsIncreasedWithmultipleRegions()
       throws Exception {
     TableName tableName = null;

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerHostname.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerHostname.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerHostname.java
index d2ff7a3..1b51ae4 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerHostname.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerHostname.java
@@ -71,7 +71,7 @@ public class TestRegionServerHostname {
     TEST_UTIL.shutdownMiniCluster();
   }
 
-  @Test (timeout=30000)
+  @Test
   public void testInvalidRegionServerHostnameAbortsServer() throws Exception {
     String invalidHostname = "hostAddr.invalid";
     TEST_UTIL.getConfiguration().set(HRegionServer.RS_HOSTNAME_KEY, invalidHostname);
@@ -86,7 +86,7 @@ public class TestRegionServerHostname {
     assertNull("Failed to validate against invalid hostname", hrs);
   }
 
-  @Test(timeout=120000)
+  @Test
   public void testRegionServerHostname() throws Exception {
     Enumeration<NetworkInterface> netInterfaceList = NetworkInterface.getNetworkInterfaces();
     while (netInterfaceList.hasMoreElements()) {
@@ -122,7 +122,7 @@ public class TestRegionServerHostname {
     }
   }
 
-  @Test(timeout=30000)
+  @Test
   public void testConflictRegionServerHostnameConfigurationsAbortServer() throws Exception {
     Enumeration<NetworkInterface> netInterfaceList = NetworkInterface.getNetworkInterfaces();
     while (netInterfaceList.hasMoreElements()) {
@@ -159,7 +159,7 @@ public class TestRegionServerHostname {
     }
   }
 
-  @Test(timeout=30000)
+  @Test
   public void testRegionServerHostnameReportedToMaster() throws Exception {
     TEST_UTIL.getConfiguration().setBoolean(HRegionServer.RS_HOSTNAME_DISABLE_MASTER_REVERSEDNS_KEY,
     true);

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerNoMaster.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerNoMaster.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerNoMaster.java
index ad839bb..af2861f 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerNoMaster.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerNoMaster.java
@@ -214,13 +214,13 @@ public class TestRegionServerNoMaster {
   }
 
 
-  @Test(timeout = 60000)
+  @Test
   public void testCloseByRegionServer() throws Exception {
     closeRegionNoZK();
     openRegion(HTU, getRS(), hri);
   }
 
-  @Test(timeout = 60000)
+  @Test
   public void testMultipleCloseFromMaster() throws Exception {
     for (int i = 0; i < 10; i++) {
       AdminProtos.CloseRegionRequest crr =
@@ -242,7 +242,7 @@ public class TestRegionServerNoMaster {
   /**
    * Test that if we do a close while opening it stops the opening.
    */
-  @Test(timeout = 60000)
+  @Test
   public void testCancelOpeningWithoutZK() throws Exception {
     // We close
     closeRegionNoZK();

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestScannerRetriableFailure.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestScannerRetriableFailure.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestScannerRetriableFailure.java
index aaee8cb..9345f7c 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestScannerRetriableFailure.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestScannerRetriableFailure.java
@@ -114,7 +114,7 @@ public class TestScannerRetriableFailure {
     }
   }
 
-  @Test(timeout=180000)
+  @Test
   public void testFaultyScanner() throws Exception {
     TableName tableName = TEST_TABLE.getTableName();
     Table table = UTIL.createTable(tableName, FAMILY_NAME);

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestSplitLogWorker.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestSplitLogWorker.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestSplitLogWorker.java
index 5e3fa39..b3e9e8c 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestSplitLogWorker.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestSplitLogWorker.java
@@ -247,7 +247,7 @@ public class TestSplitLogWorker {
 
   };
 
-  @Test(timeout=60000)
+  @Test
   public void testAcquireTaskAtStartup() throws Exception {
     LOG.info("testAcquireTaskAtStartup");
     SplitLogCounters.resetCounters();
@@ -283,7 +283,7 @@ public class TestSplitLogWorker {
     }
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testRaceForTask() throws Exception {
     LOG.info("testRaceForTask");
     SplitLogCounters.resetCounters();
@@ -317,7 +317,7 @@ public class TestSplitLogWorker {
     }
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testPreemptTask() throws Exception {
     LOG.info("testPreemptTask");
     SplitLogCounters.resetCounters();
@@ -350,7 +350,7 @@ public class TestSplitLogWorker {
     }
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testMultipleTasks() throws Exception {
     LOG.info("testMultipleTasks");
     SplitLogCounters.resetCounters();
@@ -394,7 +394,7 @@ public class TestSplitLogWorker {
     }
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testRescan() throws Exception {
     LOG.info("testRescan");
     SplitLogCounters.resetCounters();
@@ -446,7 +446,7 @@ public class TestSplitLogWorker {
     assertEquals(2, num);
   }
 
-  @Test(timeout=60000)
+  @Test
   public void testAcquireMultiTasks() throws Exception {
     LOG.info("testAcquireMultiTasks");
     SplitLogCounters.resetCounters();
@@ -481,7 +481,7 @@ public class TestSplitLogWorker {
    * RS
    * @throws Exception
    */
-  @Test(timeout=60000)
+  @Test
   public void testAcquireMultiTasksByAvgTasksPerRS() throws Exception {
     LOG.info("testAcquireMultiTasks");
     SplitLogCounters.resetCounters();

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestWalAndCompactingMemStoreFlush.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestWalAndCompactingMemStoreFlush.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestWalAndCompactingMemStoreFlush.java
index 8b20b20..3f73d37 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestWalAndCompactingMemStoreFlush.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestWalAndCompactingMemStoreFlush.java
@@ -142,7 +142,7 @@ public class TestWalAndCompactingMemStoreFlush {
     conf.setDouble(CompactingMemStore.IN_MEMORY_FLUSH_THRESHOLD_FACTOR_KEY, 0.5);
   }
 
-  @Test(timeout = 180000)
+  @Test
   public void testSelectiveFlushWithEager() throws IOException {
     // Set up the configuration
     conf.setLong(HConstants.HREGION_MEMSTORE_FLUSH_SIZE, 300 * 1024);
@@ -376,7 +376,7 @@ public class TestWalAndCompactingMemStoreFlush {
 
   /*------------------------------------------------------------------------------*/
   /* Check the same as above but for index-compaction type of compacting memstore */
-  @Test(timeout = 180000)
+  @Test
   public void testSelectiveFlushWithIndexCompaction() throws IOException {
     /*------------------------------------------------------------------------------*/
     /* SETUP */
@@ -632,7 +632,7 @@ public class TestWalAndCompactingMemStoreFlush {
     HBaseTestingUtility.closeRegionAndWAL(region);
   }
 
-  @Test(timeout = 180000)
+  @Test
   public void testSelectiveFlushAndWALinDataCompaction() throws IOException {
     // Set up the configuration
     conf.setLong(HConstants.HREGION_MEMSTORE_FLUSH_SIZE, 300 * 1024);
@@ -764,7 +764,7 @@ public class TestWalAndCompactingMemStoreFlush {
     HBaseTestingUtility.closeRegionAndWAL(region);
   }
 
-  @Test(timeout = 180000)
+  @Test
   public void testSelectiveFlushWithBasicAndMerge() throws IOException {
     // Set up the configuration
     conf.setLong(HConstants.HREGION_MEMSTORE_FLUSH_SIZE, 300 * 1024);
@@ -907,7 +907,7 @@ public class TestWalAndCompactingMemStoreFlush {
   }
 
   // should end in 300 seconds (5 minutes)
-  @Test(timeout = 300000)
+  @Test
   public void testStressFlushAndWALinIndexCompaction() throws IOException {
     // Set up the configuration
     conf.setLong(HConstants.HREGION_MEMSTORE_FLUSH_SIZE, 600 * 1024);

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/AbstractTestLogRollPeriod.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/AbstractTestLogRollPeriod.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/AbstractTestLogRollPeriod.java
index 84a6216..9322c5e 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/AbstractTestLogRollPeriod.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/AbstractTestLogRollPeriod.java
@@ -85,7 +85,7 @@ public abstract class AbstractTestLogRollPeriod {
   /**
    * Tests that the LogRoller perform the roll with some data in the log
    */
-  @Test(timeout=60000)
+  @Test
   public void testWithEdits() throws Exception {
     final TableName tableName = TableName.valueOf("TestLogRollPeriodWithEdits");
     final String family = "cf";

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/TestAsyncLogRolling.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/TestAsyncLogRolling.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/TestAsyncLogRolling.java
index aecb273..992e6a5 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/TestAsyncLogRolling.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/TestAsyncLogRolling.java
@@ -52,7 +52,7 @@ public class TestAsyncLogRolling extends AbstractTestLogRolling {
     AbstractTestLogRolling.setUpBeforeClass();
   }
 
-  @Test(timeout = 180000)
+  @Test
   public void testLogRollOnDatanodeDeath() throws IOException, InterruptedException {
     dfsCluster.startDataNodes(TEST_UTIL.getConfiguration(), 3, true, null, null);
     tableName = getName();

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/TestLogRollAbort.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/TestLogRollAbort.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/TestLogRollAbort.java
index 3476aaf..e2b4809 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/TestLogRollAbort.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/wal/TestLogRollAbort.java
@@ -185,7 +185,7 @@ public class TestLogRollAbort {
    * comes back online after the master declared it dead and started to split.
    * Want log rolling after a master split to fail. See HBASE-2312.
    */
-  @Test (timeout=300000)
+  @Test
   public void testLogRollAfterSplitStart() throws IOException {
     LOG.info("Verify wal roll after split starts will fail.");
     String logName = ServerName.valueOf("testLogRollAfterSplitStart",

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestMasterReplication.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestMasterReplication.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestMasterReplication.java
index cd0b2bf..75913d2 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestMasterReplication.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestMasterReplication.java
@@ -149,7 +149,7 @@ public class TestMasterReplication {
    * replicated. It also tests that the puts and deletes are not replicated back
    * to the originating cluster.
    */
-  @Test(timeout = 300000)
+  @Test
   public void testCyclicReplication1() throws Exception {
     LOG.info("testSimplePutDelete");
     int numClusters = 2;
@@ -179,7 +179,7 @@ public class TestMasterReplication {
    * {@link BaseReplicationEndpoint#canReplicateToSameCluster()} returns false, so the
    * ReplicationSource should terminate, and no further logs should get enqueued
    */
-  @Test(timeout = 300000)
+  @Test
   public void testLoopedReplication() throws Exception {
     LOG.info("testLoopedReplication");
     startMiniClusters(1);
@@ -216,7 +216,7 @@ public class TestMasterReplication {
    * It tests the replication scenario involving 0 -> 1 -> 0. It does it by bulk loading a set of
    * HFiles to a table in each cluster, checking if it's replicated.
    */
-  @Test(timeout = 300000)
+  @Test
   public void testHFileCyclicReplication() throws Exception {
     LOG.info("testHFileCyclicReplication");
     int numClusters = 2;
@@ -272,7 +272,7 @@ public class TestMasterReplication {
    * originating from itself and also the edits that it received using replication from a different
    * cluster. The scenario is explained in HBASE-9158
    */
-  @Test(timeout = 300000)
+  @Test
   public void testCyclicReplication2() throws Exception {
     LOG.info("testCyclicReplication2");
     int numClusters = 3;
@@ -324,7 +324,7 @@ public class TestMasterReplication {
    * It tests the multi slave hfile replication scenario involving 0 -> 1, 2. It does it by bulk
    * loading a set of HFiles to a table in master cluster, checking if it's replicated in its peers.
    */
-  @Test(timeout = 300000)
+  @Test
   public void testHFileMultiSlaveReplication() throws Exception {
     LOG.info("testHFileMultiSlaveReplication");
     int numClusters = 3;
@@ -382,7 +382,7 @@ public class TestMasterReplication {
    * families. It does it by bulk loading a set of HFiles belonging to both the CFs of table and set
    * only one CF data to replicate.
    */
-  @Test(timeout = 300000)
+  @Test
   public void testHFileReplicationForConfiguredTableCfs() throws Exception {
     LOG.info("testHFileReplicationForConfiguredTableCfs");
     int numClusters = 2;
@@ -436,7 +436,7 @@ public class TestMasterReplication {
   /**
    * Tests cyclic replication scenario of 0 -> 1 -> 2 -> 1.
    */
-  @Test(timeout = 300000)
+  @Test
   public void testCyclicReplication3() throws Exception {
     LOG.info("testCyclicReplication2");
     int numClusters = 3;

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestMultiSlaveReplication.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestMultiSlaveReplication.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestMultiSlaveReplication.java
index 53b8ba3..f30c48d 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestMultiSlaveReplication.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestMultiSlaveReplication.java
@@ -124,7 +124,7 @@ public class TestMultiSlaveReplication {
     table.addFamily(fam);
   }
 
-  @Test(timeout=300000)
+  @Test
   public void testMultiSlaveReplication() throws Exception {
     LOG.info("testCyclicReplication");
     MiniHBaseCluster master = utility1.startMiniCluster();

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestPerTableCFReplication.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestPerTableCFReplication.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestPerTableCFReplication.java
index 1dd0c19..cb5c125 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestPerTableCFReplication.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestPerTableCFReplication.java
@@ -371,7 +371,7 @@ public class TestPerTableCFReplication {
     assertTrue(tabCFsMap.get(tableName3).contains("cf3"));
   }
 
-  @Test(timeout=300000)
+  @Test
   public void testPerTableCFReplication() throws Exception {
     LOG.info("testPerTableCFReplication");
     ReplicationAdmin replicationAdmin = new ReplicationAdmin(conf1);

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationChangingPeerRegionservers.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationChangingPeerRegionservers.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationChangingPeerRegionservers.java
index 96e0ede..5492cf6 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationChangingPeerRegionservers.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationChangingPeerRegionservers.java
@@ -92,7 +92,7 @@ public class TestReplicationChangingPeerRegionservers extends TestReplicationBas
     }
   }
 
-  @Test(timeout = 300000)
+  @Test
   public void testChangingNumberOfPeerRegionServers() throws IOException, InterruptedException {
 
     LOG.info("testSimplePutDelete");

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationDisableInactivePeer.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationDisableInactivePeer.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationDisableInactivePeer.java
index bfed922..8b795aa 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationDisableInactivePeer.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationDisableInactivePeer.java
@@ -51,7 +51,7 @@ public class TestReplicationDisableInactivePeer extends TestReplicationBase {
    *
    * @throws Exception
    */
-  @Test(timeout = 600000)
+  @Test
   public void testDisableInactivePeer() throws Exception {
     utility2.shutdownMiniHBaseCluster();
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationDroppedTables.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationDroppedTables.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationDroppedTables.java
index 6de4a42..ffa03a2 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationDroppedTables.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationDroppedTables.java
@@ -96,7 +96,7 @@ public class TestReplicationDroppedTables extends TestReplicationBase {
     }
   }
 
-  @Test(timeout = 600000)
+  @Test
   public void testEditsStuckBehindDroppedTable() throws Exception {
     // Sanity check
     // Make sure by default edits for dropped tables stall the replication queue, even when the
@@ -104,14 +104,14 @@ public class TestReplicationDroppedTables extends TestReplicationBase {
     testEditsBehindDroppedTable(false, "test_dropped");
   }
 
-  @Test(timeout = 600000)
+  @Test
   public void testEditsDroppedWithDroppedTable() throws Exception {
     // Make sure by default edits for dropped tables are themselves dropped when the
     // table(s) in question have been deleted on both ends.
     testEditsBehindDroppedTable(true, "test_dropped");
   }
 
-  @Test(timeout = 600000)
+  @Test
   public void testEditsDroppedWithDroppedTableNS() throws Exception {
     // also try with a namespace
     Connection connection1 = ConnectionFactory.createConnection(conf1);
@@ -192,7 +192,7 @@ public class TestReplicationDroppedTables extends TestReplicationBase {
     conf1.setBoolean(HConstants.REPLICATION_DROP_ON_DELETED_TABLE_KEY, false);
   }
 
-  @Test(timeout = 600000)
+  @Test
   public void testEditsBehindDroppedTableTiming() throws Exception {
     conf1.setBoolean(HConstants.REPLICATION_DROP_ON_DELETED_TABLE_KEY, true);
     conf1.setInt(HConstants.REPLICATION_SOURCE_MAXTHREADS_KEY, 1);

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationEndpoint.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationEndpoint.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationEndpoint.java
index 25cc3c4..173287c 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationEndpoint.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationEndpoint.java
@@ -126,7 +126,7 @@ public class TestReplicationEndpoint extends TestReplicationBase {
     });
   }
 
-  @Test (timeout=120000)
+  @Test
   public void testCustomReplicationEndpoint() throws Exception {
     // test installing a custom replication endpoint other than the default one.
     admin.addPeer("testCustomReplicationEndpoint",
@@ -165,7 +165,7 @@ public class TestReplicationEndpoint extends TestReplicationBase {
     admin.removePeer("testCustomReplicationEndpoint");
   }
 
-  @Test (timeout=120000)
+  @Test
   public void testReplicationEndpointReturnsFalseOnReplicate() throws Exception {
     Assert.assertEquals(0, ReplicationEndpointForTest.replicateCount.get());
     Assert.assertTrue(!ReplicationEndpointReturningFalse.replicated.get());
@@ -201,7 +201,7 @@ public class TestReplicationEndpoint extends TestReplicationBase {
     admin.removePeer("testReplicationEndpointReturnsFalseOnReplicate");
   }
 
-  @Test (timeout=120000)
+  @Test
   public void testInterClusterReplication() throws Exception {
     final String id = "testInterClusterReplication";
 
@@ -247,7 +247,7 @@ public class TestReplicationEndpoint extends TestReplicationBase {
     utility1.deleteTableData(tableName);
   }
 
-  @Test (timeout=120000)
+  @Test
   public void testWALEntryFilterFromReplicationEndpoint() throws Exception {
     ReplicationPeerConfig rpc =  new ReplicationPeerConfig().setClusterKey(ZKConfig.getZooKeeperClusterKey(conf1))
         .setReplicationEndpointImpl(ReplicationEndpointWithWALEntryFilter.class.getName());
@@ -276,7 +276,7 @@ public class TestReplicationEndpoint extends TestReplicationBase {
     admin.removePeer("testWALEntryFilterFromReplicationEndpoint");
   }
 
-  @Test (timeout=120000, expected=IOException.class)
+  @Test (expected=IOException.class)
   public void testWALEntryFilterAddValidation() throws Exception {
     ReplicationPeerConfig rpc =  new ReplicationPeerConfig().setClusterKey(ZKConfig.getZooKeeperClusterKey(conf1))
         .setReplicationEndpointImpl(ReplicationEndpointWithWALEntryFilter.class.getName());
@@ -286,7 +286,7 @@ public class TestReplicationEndpoint extends TestReplicationBase {
     admin.addPeer("testWALEntryFilterAddValidation", rpc);
   }
 
-  @Test (timeout=120000, expected=IOException.class)
+  @Test (expected=IOException.class)
   public void testWALEntryFilterUpdateValidation() throws Exception {
     ReplicationPeerConfig rpc =  new ReplicationPeerConfig().setClusterKey(ZKConfig.getZooKeeperClusterKey(conf1))
         .setReplicationEndpointImpl(ReplicationEndpointWithWALEntryFilter.class.getName());

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationKillMasterRS.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationKillMasterRS.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationKillMasterRS.java
index c92c4d4..4b8e634 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationKillMasterRS.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationKillMasterRS.java
@@ -38,7 +38,7 @@ public class TestReplicationKillMasterRS extends TestReplicationKillRS {
   public static final HBaseClassTestRule CLASS_RULE =
       HBaseClassTestRule.forClass(TestReplicationKillMasterRS.class);
 
-  @Test(timeout=300000)
+  @Test
   public void killOneMasterRS() throws Exception {
     loadTableAndKillRS(utility1);
   }

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationKillSlaveRS.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationKillSlaveRS.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationKillSlaveRS.java
index 15f667b..a6a5738 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationKillSlaveRS.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationKillSlaveRS.java
@@ -38,7 +38,7 @@ public class TestReplicationKillSlaveRS extends TestReplicationKillRS {
   public static final HBaseClassTestRule CLASS_RULE =
       HBaseClassTestRule.forClass(TestReplicationKillSlaveRS.class);
 
-  @Test(timeout=300000)
+  @Test
   public void killOneSlaveRS() throws Exception {
     loadTableAndKillRS(utility2);
   }

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationStatus.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationStatus.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationStatus.java
index 0bd0260..7f2a0f1 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationStatus.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationStatus.java
@@ -57,7 +57,7 @@ public class TestReplicationStatus extends TestReplicationBase {
    * test : status.getLoad(server).getReplicationLoadSink()
    * * @throws Exception
    */
-  @Test(timeout = 300000)
+  @Test
   public void testReplicationStatus() throws Exception {
     LOG.info("testReplicationStatus");
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationTrackerZKImpl.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationTrackerZKImpl.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationTrackerZKImpl.java
index 52b914e..77b4c1b 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationTrackerZKImpl.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationTrackerZKImpl.java
@@ -134,7 +134,7 @@ public class TestReplicationTrackerZKImpl {
     assertEquals(0, rt.getListOfRegionServers().size());
   }
 
-  @Test(timeout = 30000)
+  @Test
   public void testRegionServerRemovedEvent() throws Exception {
     ZKUtil.createAndWatch(zkw,
       ZNodePaths.joinZNode(zkw.znodePaths.rsZNode, "hostname2.example.org:1234"),
@@ -150,7 +150,7 @@ public class TestReplicationTrackerZKImpl {
     assertEquals("hostname2.example.org:1234", rsRemovedData);
   }
 
-  @Test(timeout = 30000)
+  @Test
   public void testPeerNameControl() throws Exception {
     int exists = 0;
     rp.getPeerStorage().addPeer("6",

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationWithTags.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationWithTags.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationWithTags.java
index 0a47737..8c5299e 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationWithTags.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/TestReplicationWithTags.java
@@ -171,7 +171,7 @@ public class TestReplicationWithTags {
     utility1.shutdownMiniCluster();
   }
 
-  @Test(timeout = 300000)
+  @Test
   public void testReplicationWithCellTags() throws Exception {
     LOG.info("testSimplePutDelete");
     Put put = new Put(ROW);

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestRegionReplicaReplicationEndpoint.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestRegionReplicaReplicationEndpoint.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestRegionReplicaReplicationEndpoint.java
index 80eed96..61a1fbf 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestRegionReplicaReplicationEndpoint.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestRegionReplicaReplicationEndpoint.java
@@ -157,7 +157,7 @@ public class TestRegionReplicaReplicationEndpoint {
     admin.close();
   }
 
-  @Test (timeout=240000)
+  @Test
   public void testRegionReplicaReplicationPeerIsCreatedForModifyTable() throws Exception {
     // modify a table by adding region replicas. Check whether the replication peer is created
     // and replication started.
@@ -280,22 +280,22 @@ public class TestRegionReplicaReplicationEndpoint {
     }
   }
 
-  @Test(timeout = 240000)
+  @Test
   public void testRegionReplicaReplicationWith2Replicas() throws Exception {
     testRegionReplicaReplication(2);
   }
 
-  @Test(timeout = 240000)
+  @Test
   public void testRegionReplicaReplicationWith3Replicas() throws Exception {
     testRegionReplicaReplication(3);
   }
 
-  @Test(timeout = 240000)
+  @Test
   public void testRegionReplicaReplicationWith10Replicas() throws Exception {
     testRegionReplicaReplication(10);
   }
 
-  @Test (timeout = 240000)
+  @Test
   public void testRegionReplicaWithoutMemstoreReplication() throws Exception {
     int regionReplication = 3;
     final TableName tableName = TableName.valueOf(name.getMethodName());
@@ -327,7 +327,7 @@ public class TestRegionReplicaReplicationEndpoint {
     }
   }
 
-  @Test (timeout = 240000)
+  @Test
   public void testRegionReplicaReplicationForFlushAndCompaction() throws Exception {
     // Tests a table with region replication 3. Writes some data, and causes flushes and
     // compactions. Verifies that the data is readable from the replicas. Note that this
@@ -362,12 +362,12 @@ public class TestRegionReplicaReplicationEndpoint {
     }
   }
 
-  @Test (timeout = 240000)
+  @Test
   public void testRegionReplicaReplicationIgnoresDisabledTables() throws Exception {
     testRegionReplicaReplicationIgnoresDisabledTables(false);
   }
 
-  @Test (timeout = 240000)
+  @Test
   public void testRegionReplicaReplicationIgnoresDroppedTables() throws Exception {
     testRegionReplicaReplicationIgnoresDisabledTables(true);
   }

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestRegionReplicaReplicationEndpointNoMaster.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestRegionReplicaReplicationEndpointNoMaster.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestRegionReplicaReplicationEndpointNoMaster.java
index 15066dd..ab67d94 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestRegionReplicaReplicationEndpointNoMaster.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestRegionReplicaReplicationEndpointNoMaster.java
@@ -174,7 +174,7 @@ public class TestRegionReplicaReplicationEndpointNoMaster {
     }
   }
 
-  @Test (timeout = 240000)
+  @Test
   public void testReplayCallable() throws Exception {
     // tests replaying the edits to a secondary region replica using the Callable directly
     openRegion(HTU, rs0, hriSecondary);
@@ -214,7 +214,7 @@ public class TestRegionReplicaReplicationEndpointNoMaster {
     }
   }
 
-  @Test (timeout = 240000)
+  @Test
   public void testReplayCallableWithRegionMove() throws Exception {
     // tests replaying the edits to a secondary region replica using the Callable directly while
     // the region is moved to another location.It tests handling of RME.
@@ -249,7 +249,7 @@ public class TestRegionReplicaReplicationEndpointNoMaster {
     connection.close();
   }
 
-  @Test (timeout = 240000)
+  @Test
   public void testRegionReplicaReplicationEndpointReplicate() throws Exception {
     // tests replaying the edits to a secondary region replica using the RRRE.replicate()
     openRegion(HTU, rs0, hriSecondary);

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestReplicationThrottler.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestReplicationThrottler.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestReplicationThrottler.java
index 5f7be5c..c4d529e 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestReplicationThrottler.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/replication/regionserver/TestReplicationThrottler.java
@@ -41,7 +41,7 @@ public class TestReplicationThrottler {
   /**
    * unit test for throttling
    */
-  @Test(timeout=10000)
+  @Test
   public void testThrottling() {
     LOG.info("testThrottling");
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/0593dda6/hbase-server/src/test/java/org/apache/hadoop/hbase/security/access/TestAccessControlFilter.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/security/access/TestAccessControlFilter.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/security/access/TestAccessControlFilter.java
index e62c76e..e6f07f1 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/security/access/TestAccessControlFilter.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/security/access/TestAccessControlFilter.java
@@ -99,7 +99,7 @@ public class TestAccessControlFilter extends SecureTestUtil {
     TEST_UTIL.shutdownMiniCluster();
   }
 
-  @Test (timeout=180000)
+  @Test
   public void testQualifierAccess() throws Exception {
     final Table table = createTable(TEST_UTIL, TABLE, new byte[][] { FAMILY });
     try {