You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by nk...@apache.org on 2013/04/09 18:57:38 UTC

svn commit: r1466128 - in /hbase/branches/0.95: hbase-client/src/test/java/org/apache/hadoop/hbase/client/ hbase-server/src/test/java/org/apache/hadoop/hbase/ hbase-server/src/test/java/org/apache/hadoop/hbase/client/ hbase-server/src/test/java/org/apa...

Author: nkeywal
Date: Tue Apr  9 16:57:37 2013
New Revision: 1466128

URL: http://svn.apache.org/r1466128
Log:
HBASE-8303  Increse the test timeout to 60s when they are less than 20s

Modified:
    hbase/branches/0.95/hbase-client/src/test/java/org/apache/hadoop/hbase/client/TestSnapshotFromAdmin.java
    hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/TestZooKeeper.java
    hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/client/TestHCM.java
    hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/constraint/TestConstraint.java
    hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/errorhandling/TestTimeoutExceptionInjector.java
    hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/master/TestAssignmentManager.java
    hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/master/cleaner/TestSnapshotFromMaster.java
    hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedure.java
    hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureCoordinator.java
    hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureMember.java
    hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestZKProcedureControllers.java
    hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerNoMaster.java
    hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestSplitTransactionOnCluster.java
    hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/snapshot/TestFlushSnapshotFromClient.java
    hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/thrift/TestCallQueue.java

Modified: hbase/branches/0.95/hbase-client/src/test/java/org/apache/hadoop/hbase/client/TestSnapshotFromAdmin.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-client/src/test/java/org/apache/hadoop/hbase/client/TestSnapshotFromAdmin.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-client/src/test/java/org/apache/hadoop/hbase/client/TestSnapshotFromAdmin.java (original)
+++ hbase/branches/0.95/hbase-client/src/test/java/org/apache/hadoop/hbase/client/TestSnapshotFromAdmin.java Tue Apr  9 16:57:37 2013
@@ -52,7 +52,7 @@ public class TestSnapshotFromAdmin {
    * passed from the server ensures the correct overall waiting for the snapshot to finish.
    * @throws Exception
    */
-  @Test(timeout = 10000)
+  @Test(timeout = 60000)
   public void testBackoffLogic() throws Exception {
     final int maxWaitTime = 7500;
     final int numRetries = 10;

Modified: hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/TestZooKeeper.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/TestZooKeeper.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/TestZooKeeper.java (original)
+++ hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/TestZooKeeper.java Tue Apr  9 16:57:37 2013
@@ -217,7 +217,7 @@ public class TestZooKeeper {
    *  test differs from {@link #testMasterSessionExpired} because here
    *  the master znode will exist in ZK.
    */
-  @Test(timeout=20000)
+  @Test(timeout = 60000)
   public void testMasterZKSessionRecoveryFailure() throws Exception {
     MiniHBaseCluster cluster = TEST_UTIL.getHBaseCluster();
     HMaster m = cluster.getMaster();

Modified: hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/client/TestHCM.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/client/TestHCM.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/client/TestHCM.java (original)
+++ hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/client/TestHCM.java Tue Apr  9 16:57:37 2013
@@ -595,7 +595,7 @@ public class TestHCM {
    *  ZooKeeper quorum set. Other stuff like master address will be read
    *  from ZK by the client.
    */
-  @Test(timeout = 10000)
+  @Test(timeout = 60000)
   public void testConnection() throws Exception{
     // We create an empty config and add the ZK address.
     Configuration c = new Configuration();

Modified: hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/constraint/TestConstraint.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/constraint/TestConstraint.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/constraint/TestConstraint.java (original)
+++ hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/constraint/TestConstraint.java Tue Apr  9 16:57:37 2013
@@ -95,7 +95,7 @@ public class TestConstraint {
    * @throws Exception
    */
   @SuppressWarnings("unchecked")
-  @Test(timeout = 10000)
+  @Test(timeout = 60000)
   public void testConstraintFails() throws Exception {
 
     // create the table

Modified: hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/errorhandling/TestTimeoutExceptionInjector.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/errorhandling/TestTimeoutExceptionInjector.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/errorhandling/TestTimeoutExceptionInjector.java (original)
+++ hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/errorhandling/TestTimeoutExceptionInjector.java Tue Apr  9 16:57:37 2013
@@ -37,7 +37,7 @@ public class TestTimeoutExceptionInjecto
   /**
    * Test that a manually triggered timer fires an exception.
    */
-  @Test(timeout = 1000)
+  @Test(timeout = 60000)
   public void testTimerTrigger() {
     final long time = 10000000; // pick a value that is very far in the future
     ForeignExceptionListener listener = Mockito.mock(ForeignExceptionListener.class);
@@ -64,7 +64,7 @@ public class TestTimeoutExceptionInjecto
    * Demonstrate TimeoutExceptionInjector semantics -- completion means no more exceptions passed to
    * error listener.
    */
-  @Test(timeout = 1000)
+  @Test(timeout = 60000)
   public void testStartAfterComplete() throws InterruptedException {
     final long time = 10;
     ForeignExceptionListener listener = Mockito.mock(ForeignExceptionListener.class);
@@ -84,7 +84,7 @@ public class TestTimeoutExceptionInjecto
    * Demonstrate TimeoutExceptionInjector semantics -- triggering fires exception and completes
    * the timer.
    */
-  @Test(timeout = 1000)
+  @Test(timeout = 60000)
   public void testStartAfterTrigger() throws InterruptedException {
     final long time = 10;
     ForeignExceptionListener listener = Mockito.mock(ForeignExceptionListener.class);

Modified: hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/master/TestAssignmentManager.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/master/TestAssignmentManager.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/master/TestAssignmentManager.java (original)
+++ hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/master/TestAssignmentManager.java Tue Apr  9 16:57:37 2013
@@ -185,7 +185,7 @@ public class TestAssignmentManager {
    * @throws InterruptedException
    * @throws DeserializationException
    */
-  @Test(timeout = 5000)
+  @Test(timeout = 60000)
   public void testBalanceOnMasterFailoverScenarioWithOpenedNode()
   throws IOException, KeeperException, InterruptedException, ServiceException, DeserializationException {
     AssignmentManagerWithExtrasForTesting am =
@@ -233,7 +233,7 @@ public class TestAssignmentManager {
     }
   }
 
-  @Test(timeout = 5000)
+  @Test(timeout = 60000)
   public void testBalanceOnMasterFailoverScenarioWithClosedNode()
   throws IOException, KeeperException, InterruptedException, ServiceException, DeserializationException {
     AssignmentManagerWithExtrasForTesting am =
@@ -282,7 +282,7 @@ public class TestAssignmentManager {
     }
   }
 
-  @Test(timeout = 5000)
+  @Test(timeout = 60000)
   public void testBalanceOnMasterFailoverScenarioWithOfflineNode()
   throws IOException, KeeperException, InterruptedException, ServiceException, DeserializationException {
     AssignmentManagerWithExtrasForTesting am =
@@ -686,7 +686,7 @@ public class TestAssignmentManager {
    * situation
    * @throws ServiceException
    */
-  @Test(timeout = 5000)
+  @Test(timeout = 60000)
   public void testProcessDeadServersAndRegionsInTransitionShouldNotFailWithNPE()
       throws IOException, KeeperException, InterruptedException, ServiceException {
     final RecoverableZooKeeper recoverableZk = Mockito
@@ -716,7 +716,7 @@ public class TestAssignmentManager {
    * TestCase verifies that the regionPlan is updated whenever a region fails to open
    * and the master tries to process RS_ZK_FAILED_OPEN state.(HBASE-5546).
    */
-  @Test(timeout = 5000)
+  @Test(timeout = 60000)
   public void testRegionPlanIsUpdatedWhenRegionFailsToOpen() throws IOException, KeeperException,
       ServiceException, InterruptedException {
     this.server.getConfiguration().setClass(
@@ -814,7 +814,7 @@ public class TestAssignmentManager {
    * region which is in Opening state on a dead RS. Master should immediately
    * assign the region and not wait for Timeout Monitor.(Hbase-5882).
    */
-  @Test(timeout = 5000)
+  @Test(timeout = 60000)
   public void testRegionInOpeningStateOnDeadRSWhileMasterFailover() throws IOException,
       KeeperException, ServiceException, InterruptedException {
     AssignmentManagerWithExtrasForTesting am = setUpMockedAssignmentManager(
@@ -846,7 +846,7 @@ public class TestAssignmentManager {
    * @throws IOException
    * @throws Exception
    */
-  @Test(timeout = 10000)
+  @Test(timeout = 60000)
   public void testDisablingTableRegionsAssignmentDuringCleanClusterStartup()
       throws KeeperException, IOException, Exception {
     this.server.getConfiguration().setClass(HConstants.HBASE_MASTER_LOADBALANCER_CLASS,

Modified: hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/master/cleaner/TestSnapshotFromMaster.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/master/cleaner/TestSnapshotFromMaster.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/master/cleaner/TestSnapshotFromMaster.java (original)
+++ hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/master/cleaner/TestSnapshotFromMaster.java Tue Apr  9 16:57:37 2013
@@ -171,7 +171,7 @@ public class TestSnapshotFromMaster {
    * <li>If asking about a snapshot has hasn't occurred, you should get an error.</li>
    * </ol>
    */
-  @Test(timeout = 15000)
+  @Test(timeout = 60000)
   public void testIsDoneContract() throws Exception {
 
     IsSnapshotDoneRequest.Builder builder = IsSnapshotDoneRequest.newBuilder();

Modified: hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedure.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedure.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedure.java (original)
+++ hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedure.java Tue Apr  9 16:57:37 2013
@@ -82,7 +82,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 = 1000)
+  @Test(timeout = 60000)
   public void testSingleMember() throws Exception {
     // The member
     List<String> members =  new ArrayList<String>();
@@ -126,7 +126,7 @@ public class TestProcedure {
     verify(procspy, never()).receive(any(ForeignException.class));
   }
 
-  @Test(timeout=1000)
+  @Test(timeout = 60000)
   public void testMultipleMember() throws Exception {
     // 2 members
     List<String> members =  new ArrayList<String>();
@@ -178,7 +178,7 @@ public class TestProcedure {
     verify(procspy, never()).receive(any(ForeignException.class));
   }
 
-  @Test(timeout = 1000)
+  @Test(timeout = 60000)
   public void testErrorPropagation() throws Exception {
     List<String> members =  new ArrayList<String>();
     members.add("member");
@@ -203,7 +203,7 @@ public class TestProcedure {
     verify(procspy).sendGlobalBarrierComplete();
   }
 
-  @Test(timeout = 1000)
+  @Test(timeout = 60000)
   public void testBarrieredErrorPropagation() throws Exception {
     List<String> members =  new ArrayList<String>();
     members.add("member");

Modified: hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureCoordinator.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureCoordinator.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureCoordinator.java (original)
+++ hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureCoordinator.java Tue Apr  9 16:57:37 2013
@@ -116,7 +116,7 @@ public class TestProcedureCoordinator {
   /**
    * Check handling a connection failure correctly if we get it during the acquiring phase
    */
-  @Test(timeout = 5000)
+  @Test(timeout = 60000)
   public void testUnreachableControllerDuringPrepare() throws Exception {
     coordinator = buildNewCoordinator();
     // setup the proc
@@ -147,7 +147,7 @@ public class TestProcedureCoordinator {
   /**
    * Check handling a connection failure correctly if we get it during the barrier phase
    */
-  @Test(timeout = 5000)
+  @Test(timeout = 60000)
   public void testUnreachableControllerDuringCommit() throws Exception {
     coordinator = buildNewCoordinator();
 
@@ -177,17 +177,17 @@ public class TestProcedureCoordinator {
         anyListOf(String.class));
   }
 
-  @Test(timeout = 1000)
+  @Test(timeout = 60000)
   public void testNoCohort() throws Exception {
     runSimpleProcedure();
   }
 
-  @Test(timeout = 1000)
+  @Test(timeout = 60000)
   public void testSingleCohortOrchestration() throws Exception {
     runSimpleProcedure("one");
   }
 
-  @Test(timeout = 1000)
+  @Test(timeout = 60000)
   public void testMultipleCohortOrchestration() throws Exception {
     runSimpleProcedure("one", "two", "three", "four");
   }
@@ -203,7 +203,7 @@ public class TestProcedureCoordinator {
   /**
    * Test that if nodes join the barrier early we still correctly handle the progress
    */
-  @Test(timeout = 1000)
+  @Test(timeout = 60000)
   public void testEarlyJoiningBarrier() throws Exception {
     final String[] cohort = new String[] { "one", "two", "three", "four" };
     coordinator = buildNewCoordinator();

Modified: hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureMember.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureMember.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureMember.java (original)
+++ hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestProcedureMember.java Tue Apr  9 16:57:37 2013
@@ -155,7 +155,7 @@ public class TestProcedureMember {
    * Make sure we call cleanup etc, when we have an exception during
    * {@link Subprocedure#acquireBarrier()}.
    */
-  @Test(timeout = 1000)
+  @Test(timeout = 60000)
   public void testMemberPrepareException() throws Exception {
     buildCohortMemberPair();
 
@@ -190,7 +190,7 @@ public class TestProcedureMember {
   /**
    * Make sure we call cleanup etc, when we have an exception during prepare.
    */
-  @Test(timeout = 1000)
+  @Test(timeout = 60000)
   public void testSendMemberAcquiredCommsFailure() throws Exception {
     buildCohortMemberPair();
 
@@ -229,7 +229,7 @@ public class TestProcedureMember {
    * is checked.  Thus, the {@link Subprocedure#prepare} should succeed but later get rolled back
    * via {@link Subprocedure#cleanup}.
    */
-  @Test(timeout = 1000)
+  @Test(timeout = 60000)
   public void testCoordinatorAbort() throws Exception {
     buildCohortMemberPair();
 
@@ -274,7 +274,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 = 1000)
+  @Test(timeout = 60000)
   public void testMemberCommitException() throws Exception {
     buildCohortMemberPair();
 
@@ -315,7 +315,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 = 1000)
+  @Test(timeout = 60000)
   public void testMemberCommitCommsFailure() throws Exception {
     buildCohortMemberPair();
     final TimeoutException oate = new TimeoutException("bogus timeout",1,2,0);
@@ -353,7 +353,7 @@ public class TestProcedureMember {
    * Fail correctly on getting an external error while waiting for the prepared latch
    * @throws Exception on failure
    */
-  @Test(timeout = 1000)
+  @Test(timeout = 60000)
   public void testPropagateConnectionErrorBackToManager() throws Exception {
     // setup the operation
     member = buildCohortMember();

Modified: hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestZKProcedureControllers.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestZKProcedureControllers.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestZKProcedureControllers.java (original)
+++ hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/procedure/TestZKProcedureControllers.java Tue Apr  9 16:57:37 2013
@@ -74,7 +74,7 @@ public class TestZKProcedureControllers 
    * Smaller test to just test the actuation on the cohort member
    * @throws Exception on failure
    */
-  @Test(timeout = 15000)
+  @Test(timeout = 60000)
   public void testSimpleZKCohortMemberController() throws Exception {
     ZooKeeperWatcher watcher = UTIL.getZooKeeperWatcher();
     final String operationName = "instanceTest";
@@ -137,7 +137,7 @@ public class TestZKProcedureControllers 
     assertEquals("Didn't delete commit node", -1, ZKUtil.checkExists(watcher, commit));
   }
 
-  @Test(timeout = 15000)
+  @Test(timeout = 60000)
   public void testZKCoordinatorControllerWithNoCohort() throws Exception {
     final String operationName = "no cohort controller test";
     final byte[] data = new byte[] { 1, 2, 3 };
@@ -146,7 +146,7 @@ public class TestZKProcedureControllers 
     runMockCommitWithOrchestratedControllers(startCohortFirst, operationName, data);
   }
 
-  @Test(timeout = 15000)
+  @Test(timeout = 60000)
   public void testZKCoordinatorControllerWithSingleMemberCohort() throws Exception {
     final String operationName = "single member controller test";
     final byte[] data = new byte[] { 1, 2, 3 };
@@ -155,7 +155,7 @@ public class TestZKProcedureControllers 
     runMockCommitWithOrchestratedControllers(startCohortFirst, operationName, data, "cohort");
   }
 
-  @Test(timeout = 15000)
+  @Test(timeout = 60000)
   public void testZKCoordinatorControllerMultipleCohort() throws Exception {
     final String operationName = "multi member controller test";
     final byte[] data = new byte[] { 1, 2, 3 };

Modified: hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerNoMaster.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerNoMaster.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerNoMaster.java (original)
+++ hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerNoMaster.java Tue Apr  9 16:57:37 2013
@@ -157,13 +157,13 @@ public class TestRegionServerNoMaster {
   }
 
 
-  @Test(timeout = 20000)
+  @Test(timeout = 60000)
   public void testCloseByRegionServer() throws Exception {
     closeNoZK();
     reopenRegion();
   }
 
-  @Test(timeout = 20000)
+  @Test(timeout = 60000)
   public void testCloseByMasterWithoutZNode() throws Exception {
 
     // Transition in ZK on. This should fail, as there is no znode
@@ -181,7 +181,7 @@ public class TestRegionServerNoMaster {
     Assert.assertTrue("The close should have failed", getRS().getRegion(regionName).isAvailable());
   }
 
-  @Test(timeout = 20000)
+  @Test(timeout = 60000)
   public void testOpenCloseByMasterWithZNode() throws Exception {
 
     ZKAssign.createNodeClosing(HTU.getZooKeeperWatcher(), hri, getRS().getServerName());
@@ -208,7 +208,7 @@ public class TestRegionServerNoMaster {
    * the region server has received the query or not. Only solution to be efficient: re-ask
    * immediately.
    */
-  @Test(timeout = 20000)
+  @Test(timeout = 60000)
   public void testMultipleOpen() throws Exception {
 
     // We close
@@ -234,7 +234,7 @@ public class TestRegionServerNoMaster {
     checkRegionIsOpened();
   }
 
-  @Test(timeout = 20000)
+  @Test(timeout = 60000)
   public void testMultipleCloseFromMaster() throws Exception {
 
     // As opening, we must support multiple requests on the same region
@@ -264,7 +264,7 @@ public class TestRegionServerNoMaster {
   /**
    * Test that if we do a close while opening it stops the opening.
    */
-  @Test(timeout = 20000)
+  @Test(timeout = 60000)
   public void testCancelOpeningWithoutZK() throws Exception {
     // We close
     closeNoZK();
@@ -307,7 +307,7 @@ public class TestRegionServerNoMaster {
    * Test an open then a close with ZK. This is going to mess-up the ZK states, so
    * the opening will fail as well because it doesn't find what it expects in ZK.
    */
-  @Test(timeout = 20000)
+  @Test(timeout = 60000)
   public void testCancelOpeningWithZK() throws Exception {
     // We close
     closeNoZK();

Modified: hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestSplitTransactionOnCluster.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestSplitTransactionOnCluster.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestSplitTransactionOnCluster.java (original)
+++ hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestSplitTransactionOnCluster.java Tue Apr  9 16:57:37 2013
@@ -125,7 +125,7 @@ public class TestSplitTransactionOnClust
     return regions.get(0).getRegionInfo();
   }
 
-  @Test(timeout = 20000)
+  @Test(timeout = 60000)
   public void testShouldFailSplitIfZNodeDoesNotExistDueToPrevRollBack() throws Exception {
     final byte[] tableName = Bytes
         .toBytes("testShouldFailSplitIfZNodeDoesNotExistDueToPrevRollBack");
@@ -586,7 +586,7 @@ public class TestSplitTransactionOnClust
     testSplitBeforeSettingSplittingInZKInternals();
   }
 
-  @Test(timeout = 20000)
+  @Test(timeout = 60000)
   public void testTableExistsIfTheSpecifiedTableRegionIsSplitParent() throws Exception {
     final byte[] tableName =
         Bytes.toBytes("testTableExistsIfTheSpecifiedTableRegionIsSplitParent");

Modified: hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/snapshot/TestFlushSnapshotFromClient.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/snapshot/TestFlushSnapshotFromClient.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/snapshot/TestFlushSnapshotFromClient.java (original)
+++ hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/snapshot/TestFlushSnapshotFromClient.java Tue Apr  9 16:57:37 2013
@@ -219,7 +219,7 @@ public class TestFlushSnapshotFromClient
     }
   }
 
-  @Test(timeout = 15000)
+  @Test(timeout = 60000)
   public void testAsyncFlushSnapshot() throws Exception {
     HBaseAdmin admin = UTIL.getHBaseAdmin();
     SnapshotDescription snapshot = SnapshotDescription.newBuilder().setName("asyncSnapshot")

Modified: hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/thrift/TestCallQueue.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/thrift/TestCallQueue.java?rev=1466128&r1=1466127&r2=1466128&view=diff
==============================================================================
--- hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/thrift/TestCallQueue.java (original)
+++ hbase/branches/0.95/hbase-server/src/test/java/org/apache/hadoop/hbase/thrift/TestCallQueue.java Tue Apr  9 16:57:37 2013
@@ -76,7 +76,7 @@ public class TestCallQueue {
 
   }
 
-  @Test(timeout=3000)
+  @Test(timeout = 60000)
   public void testPutTake() throws Exception {
     ThriftMetrics metrics = createMetrics();
     CallQueue callQueue = new CallQueue(
@@ -90,7 +90,7 @@ public class TestCallQueue {
     verifyMetrics(metrics, "timeInQueue_num_ops", elementsRemoved);
   }
 
-  @Test(timeout=3000)
+  @Test(timeout = 60000)
   public void testOfferPoll() throws Exception {
     ThriftMetrics metrics = createMetrics();
     CallQueue callQueue = new CallQueue(