You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by li...@apache.org on 2014/04/17 02:49:14 UTC

svn commit: r1588117 - in /hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase: ./ client/ io/encoding/ regionserver/ thrift/swift/

Author: liyin
Date: Thu Apr 17 00:49:13 2014
New Revision: 1588117

URL: http://svn.apache.org/r1588117
Log:
[HBASE-10986] Add Test timeouts to all hanging JUnit tests

Author: elliott

Summary: Some tests are hanging on Jenkins.  Add timeouts to all the junit4 tests.

Test Plan: mvn test

Reviewers: liyintang, daviddeng

Reviewed By: daviddeng

CC: hbase-eng@

Differential Revision: https://phabricator.fb.com/D1277417

Task ID: 4142789

Modified:
    hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/TestRegionRebalancing.java
    hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestBatchedUpload.java
    hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestClientLocalScanner.java
    hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestFromClientSide.java
    hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/io/encoding/TestChangingEncoding.java
    hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/io/encoding/TestUpgradeFromHFileV1ToEncoding.java
    hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionClose.java
    hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionFavoredNodes.java
    hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/thrift/swift/TestSimpleOperations.java

Modified: hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/TestRegionRebalancing.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/TestRegionRebalancing.java?rev=1588117&r1=1588116&r2=1588117&view=diff
==============================================================================
--- hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/TestRegionRebalancing.java (original)
+++ hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/TestRegionRebalancing.java Thu Apr 17 00:49:13 2014
@@ -105,7 +105,6 @@ public class TestRegionRebalancing exten
    * Set the slot number near 0, so no server's load will large than 4.
    * The load balance algorithm should handle this case properly. 
    */
-  @Test(timeout=10000)
   public void testRebalancing() throws IOException {
 
     for (int i = 1; i <= 16; i++){

Modified: hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestBatchedUpload.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestBatchedUpload.java?rev=1588117&r1=1588116&r2=1588117&view=diff
==============================================================================
--- hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestBatchedUpload.java (original)
+++ hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestBatchedUpload.java Thu Apr 17 00:49:13 2014
@@ -90,12 +90,13 @@ public class TestBatchedUpload {
     ht.close();
   }
 
-  @Test(timeout = 200000)
+
   /*
    * Test to make sure that if a region moves benignly, and both
    * the source and dest region servers are alive, then the batch
    * should succeed.
    */
+  @Test(timeout = 200000)
   public void testBatchedUploadWithRegionMoves() throws Exception {
     byte [] TABLE = Bytes.toBytes("testBatchedUploadWithRegionMoves");
     int NUM_REGIONS = 10;

Modified: hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestClientLocalScanner.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestClientLocalScanner.java?rev=1588117&r1=1588116&r2=1588117&view=diff
==============================================================================
--- hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestClientLocalScanner.java (original)
+++ hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestClientLocalScanner.java Thu Apr 17 00:49:13 2014
@@ -53,7 +53,7 @@ import org.junit.BeforeClass;
 import org.junit.Test;
 
 public class TestClientLocalScanner {
-  final Log LOG = LogFactory.getLog(getClass());
+  private final static Log LOG = LogFactory.getLog(TestClientLocalScanner.class);
   private final static HBaseTestingUtility TEST_UTIL =
       new HBaseTestingUtility();
   private static byte [] FAMILY = Bytes.toBytes("testFamily");
@@ -76,7 +76,7 @@ public class TestClientLocalScanner {
     TEST_UTIL.shutdownMiniCluster();
   }
 
-  @Test(timeout=200000)
+  @Test(timeout=180000)
   public void testCompareLocalScanToRemoteScan() throws IOException {
     byte [] name = Bytes.toBytes("testCompareLocalScanToRemoteScan");
     HTable t = TEST_UTIL.createTable(name, new byte[][] {FAMILY, FAMILY2}, 3,
@@ -138,7 +138,7 @@ public class TestClientLocalScanner {
    * failure by observing the logs.
    * @throws IOException
    */
-  @Test
+  @Test(timeout=180000)
   public void testCompactionWhileSnapshotting() throws IOException {
     final byte [] name = Bytes.toBytes("testCompactionWhileSnapshotting");
     final HTable t = TEST_UTIL.createTable(name, FAMILY);
@@ -172,7 +172,7 @@ public class TestClientLocalScanner {
    * With a small difference that the data is flushed to disk
    * since the scan works only on the data present in files.
    */
-  @Test
+  @Test(timeout=180000)
   public void testFilterAcrossMutlipleRegionsWithLocalScan() throws IOException {
     byte [] name = Bytes.toBytes("testFilterAcrossMutlipleRegionsWithLocalScan");
     HTable t = TEST_UTIL.createTable(name, FAMILY);
@@ -236,7 +236,7 @@ public class TestClientLocalScanner {
     t.close();
   }
 
-  @Test
+  @Test(timeout=180000)
   public void testInconsistentRegionDirectories() throws IOException {
     byte [] tableName = Bytes.toBytes("testInconsistentRegionDirectories");
     String rootDir = TEST_UTIL.getConfiguration().get("hbase.rootdir");
@@ -263,7 +263,7 @@ public class TestClientLocalScanner {
     assertTrue(false);
   }
 
-  @Test
+  @Test(timeout=180000)
   public void testLocalScannerWithoutHardlinks() throws IOException {
     byte [] tableName = Bytes.toBytes("testLocalScannerWithoutHardlinks");
     HTable t = TEST_UTIL.createTable(tableName, FAMILY);
@@ -394,7 +394,7 @@ public class TestClientLocalScanner {
 
   /**
    * @param t
-   * @param s
+   * @param scanner
    * @return Count of rows in table.
    * @throws IOException
    */

Modified: hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestFromClientSide.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestFromClientSide.java?rev=1588117&r1=1588116&r2=1588117&view=diff
==============================================================================
--- hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestFromClientSide.java (original)
+++ hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/client/TestFromClientSide.java Thu Apr 17 00:49:13 2014
@@ -130,7 +130,7 @@ public class TestFromClientSide {
     // Nothing to do.
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testEmptyColumn() throws Exception {
     byte [] TABLE = Bytes.toBytes("testEmptyColumn");
     byte [][] FAMILIES = new byte[][] {FAMILY};
@@ -174,7 +174,7 @@ public class TestFromClientSide {
     assertEquals(result1.raw().length, result2.raw().length);
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testFlashBackTime() throws Exception {
     byte[] TABLE = Bytes.toBytes("testFlashBackTime");
     HColumnDescriptor[] expected = new HColumnDescriptor[10];
@@ -196,7 +196,7 @@ public class TestFromClientSide {
    * Verifies that getConfiguration returns the same Configuration object used
    * to create the HTable instance.
    */
-  @Test
+  @Test(timeout = 180000)
   public void testGetConfiguration() throws Exception {
     byte[] TABLE = Bytes.toBytes("testGetConfiguration");
     byte[][] FAMILIES = new byte[][] { Bytes.toBytes("foo") };
@@ -211,7 +211,7 @@ public class TestFromClientSide {
    *
    * @throws Exception
    */
-  @Test
+  @Test(timeout = 180000)
   public void testWeirdCacheBehaviour() throws Exception {
     byte [] TABLE = Bytes.toBytes("testWeirdCacheBehaviour");
     byte [][] FAMILIES = new byte[][] { Bytes.toBytes("trans-blob"),
@@ -342,7 +342,7 @@ public class TestFromClientSide {
    * Related to the TestFilterAcrossRegions over in the o.a.h.h.filter package.
    * @throws IOException
    */
-  @Test
+  @Test(timeout = 180000)
   public void testFilterAcrossMutlipleRegions() throws IOException {
     byte [] name = Bytes.toBytes("testFilterAcrossMutlipleRegions");
     HTable t = TEST_UTIL.createTable(name, FAMILY);
@@ -514,7 +514,7 @@ public class TestFromClientSide {
     return regions;
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testSuperSimple() throws Exception {
     byte [] TABLE = Bytes.toBytes("testSuperSimple");
     HTable ht = TEST_UTIL.createTable(TABLE, FAMILY);
@@ -530,7 +530,7 @@ public class TestFromClientSide {
     System.out.println("Done.");
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testMaxKeyValueSize() throws Exception {
     byte [] TABLE = Bytes.toBytes("testMaxKeyValueSize");
     Configuration conf = TEST_UTIL.getConfiguration();
@@ -552,7 +552,7 @@ public class TestFromClientSide {
     conf.set("hbase.client.keyvalue.maxsize", oldMaxSize);
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testFilters() throws Exception {
     byte [] TABLE = Bytes.toBytes("testFilters");
     HTable ht = TEST_UTIL.createTable(TABLE, FAMILY);
@@ -587,7 +587,7 @@ public class TestFromClientSide {
     scanner.close();
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testKeyOnlyFilter() throws Exception {
     byte [] TABLE = Bytes.toBytes("testKeyOnlyFilter");
     HTable ht = TEST_UTIL.createTable(TABLE, FAMILY);
@@ -623,7 +623,7 @@ public class TestFromClientSide {
   /**
    * Test simple table and non-existent row cases.
    */
-  @Test
+  @Test(timeout = 180000)
   public void testSimpleMissing() throws Exception {
     byte [] TABLE = Bytes.toBytes("testSimpleMissing");
     HTable ht = TEST_UTIL.createTable(TABLE, FAMILY);
@@ -735,7 +735,7 @@ public class TestFromClientSide {
    * we should get an exception instead of the server trying until
    * OOM.
    */
-  @Test
+  @Test(timeout = 180000)
   public void testResultLimits() throws Exception {
     // We want to set the max result size to something small
     HRegionServer.setResponseSizeLimit(40000L);
@@ -806,7 +806,7 @@ public class TestFromClientSide {
    * Test basic puts, gets, scans, and deletes for a single row
    * in a multiple family table.
    */
-  @Test
+  @Test(timeout = 180000)
   public void testSingleRowMultipleFamily() throws Exception {
     byte [] TABLE = Bytes.toBytes("testSingleRowMultipleFamily");
     byte [][] ROWS = makeN(ROW, 3);
@@ -1107,7 +1107,7 @@ public class TestFromClientSide {
 
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testNull() throws Exception {
     byte [] TABLE = Bytes.toBytes("testNull");
 
@@ -1215,7 +1215,7 @@ public class TestFromClientSide {
     }
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testVersions() throws Exception {
     byte [] TABLE = Bytes.toBytes("testVersions");
 
@@ -1429,7 +1429,7 @@ public class TestFromClientSide {
 
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testVersionLimits() throws Exception {
     byte [] TABLE = Bytes.toBytes("testVersionLimits");
     byte [][] FAMILIES = makeNAscii(FAMILY, 3);
@@ -1623,7 +1623,7 @@ public class TestFromClientSide {
 
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testDeletes() throws Exception {
     byte [] TABLE = Bytes.toBytes("testDeletes");
 
@@ -2005,7 +2005,7 @@ public class TestFromClientSide {
    *    To test at scale, up numColsPerRow to the millions
    *    (have not gotten that to work running as junit though)
    */
-  @Test
+  @Test(timeout = 180000)
   public void testJiraTest867() throws Exception {
     int numRows = 10;
     int numColsPerRow = 2000;
@@ -2090,7 +2090,7 @@ public class TestFromClientSide {
    *    get with timestamp will return a value if there is a version with an
    *    earlier timestamp
    */
-  @Test
+  @Test(timeout = 180000)
   public void testJiraTest861() throws Exception {
 
     byte [] TABLE = Bytes.toBytes("testJiraTest861");
@@ -2154,7 +2154,7 @@ public class TestFromClientSide {
    *    Add a HTable get/obtainScanner method that retrieves all versions of a
    *    particular column and row between two timestamps
    */
-  @Test
+  @Test(timeout = 180000)
   public void testJiraTest33() throws Exception {
 
     byte [] TABLE = Bytes.toBytes("testJiraTest33");
@@ -2203,7 +2203,7 @@ public class TestFromClientSide {
    * HBASE-1014
    *    commit(BatchUpdate) method should return timestamp
    */
-  @Test
+  @Test(timeout = 180000)
   public void testJiraTest1014() throws Exception {
 
     byte [] TABLE = Bytes.toBytes("testJiraTest1014");
@@ -2228,7 +2228,7 @@ public class TestFromClientSide {
    * HBASE-1182
    *    Scan for columns > some timestamp
    */
-  @Test
+  @Test(timeout = 180000)
   public void testJiraTest1182() throws Exception {
 
     byte [] TABLE = Bytes.toBytes("testJiraTest1182");
@@ -2272,7 +2272,7 @@ public class TestFromClientSide {
    * HBASE-52
    *    Add a means of scanning over all versions
    */
-  @Test
+  @Test(timeout = 180000)
   public void testJiraTest52() throws Exception {
     byte [] TABLE = Bytes.toBytes("testJiraTest52");
     byte [][] VALUES = makeNAscii(VALUE, 7);
@@ -3074,7 +3074,7 @@ public class TestFromClientSide {
     return Bytes.equals(left, right);
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testDuplicateVersions() throws Exception {
     byte [] TABLE = Bytes.toBytes("testDuplicateVersions");
 
@@ -3288,7 +3288,7 @@ public class TestFromClientSide {
         0, 9);
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testUpdates() throws Exception {
 
     byte [] TABLE = Bytes.toBytes("testUpdates");
@@ -3338,7 +3338,7 @@ public class TestFromClientSide {
     assertEquals("DDD", Bytes.toString(navigableMap.get(2L)));
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testUpdatesWithMajorCompaction() throws Exception {
 
     String tableName = "testUpdatesWithMajorCompaction";
@@ -3400,7 +3400,7 @@ public class TestFromClientSide {
     assertEquals("DDD", Bytes.toString(navigableMap.get(2L)));
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testMajorCompactionBetweenTwoUpdates() throws Exception {
 
     String tableName = "testMajorCompactionBetweenTwoUpdates";
@@ -3468,7 +3468,7 @@ public class TestFromClientSide {
     assertEquals("DDD", Bytes.toString(navigableMap.get(2L)));
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testGet_EmptyTable() throws IOException {
     HTable table = TEST_UTIL.createTable(Bytes.toBytes("testGet_EmptyTable"), FAMILY);
     Get get = new Get(ROW);
@@ -3477,7 +3477,7 @@ public class TestFromClientSide {
     assertTrue(r.isEmpty());
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testGet_NonExistentRow() throws IOException {
     HTable table = TEST_UTIL.createTable(Bytes.toBytes("testGet_NonExistentRow"), FAMILY);
     Put put = new Put(ROW);
@@ -3499,7 +3499,7 @@ public class TestFromClientSide {
     LOG.info("Row missing as it should be");
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testPut() throws IOException {
     final byte [] CONTENTS_FAMILY = Bytes.toBytes("contents");
     final byte [] SMALL_FAMILY = Bytes.toBytes("smallfam");
@@ -3539,7 +3539,7 @@ public class TestFromClientSide {
   }
 
 
-  @Test
+  @Test(timeout = 180000)
   public void testRowsPutMultiGet() throws IOException {
     final byte[] CONTENTS_FAMILY = Bytes.toBytes("contents");
     final byte[] SMALL_FAMILY = Bytes.toBytes("smallfam");
@@ -3604,7 +3604,7 @@ public class TestFromClientSide {
     }
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testRowsPutBufferedOneFlush() throws IOException {
     final byte [] CONTENTS_FAMILY = Bytes.toBytes("contents");
     final byte [] SMALL_FAMILY = Bytes.toBytes("smallfam");
@@ -3644,7 +3644,7 @@ public class TestFromClientSide {
     assertEquals(NB_BATCH_ROWS * 10, nbRows);
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testRowsPutBufferedManyManyFlushes() throws IOException {
     final byte[] CONTENTS_FAMILY = Bytes.toBytes("contents");
     final byte[] SMALL_FAMILY = Bytes.toBytes("smallfam");
@@ -3675,7 +3675,7 @@ public class TestFromClientSide {
     assertEquals(NB_BATCH_ROWS * 10, nbRows);
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testAddKeyValue() throws IOException {
     final byte[] CONTENTS_FAMILY = Bytes.toBytes("contents");
     final byte[] value = Bytes.toBytes("abcd");
@@ -3709,7 +3709,7 @@ public class TestFromClientSide {
    * test for HBASE-737
    * @throws IOException
    */
-  @Test
+  @Test(timeout = 180000)
   public void testHBase737 () throws IOException {
     final byte [] FAM1 = Bytes.toBytes("fam1");
     final byte [] FAM2 = Bytes.toBytes("fam2");
@@ -3800,7 +3800,7 @@ public class TestFromClientSide {
     }
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testListTables() throws IOException {
     byte [] t1 = Bytes.toBytes("testListTables1");
     byte [] t2 = Bytes.toBytes("testListTables2");
@@ -3829,7 +3829,7 @@ public class TestFromClientSide {
     }
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testMiscHTableStuff() throws IOException {
     final byte[] tableAname = Bytes.toBytes("testMiscHTableStuffA");
     final byte[] tableBname = Bytes.toBytes("testMiscHTableStuffB");
@@ -3906,7 +3906,7 @@ public class TestFromClientSide {
     }
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testGetClosestRowBefore() throws IOException {
     final byte [] tableAname = Bytes.toBytes("testGetClosestRowBefore");
     final byte [] row = Bytes.toBytes("row");
@@ -3960,6 +3960,7 @@ public class TestFromClientSide {
    * For HBASE-2156
    * @throws Exception
    */
+  @Test(timeout = 180000)
   public void testScanVariableReuse() throws Exception {
     Scan scan = new Scan();
     scan.addFamily(FAMILY);
@@ -3976,7 +3977,7 @@ public class TestFromClientSide {
   /**
    * HBASE-2468 use case 1 and 2: region info de/serialization
    */
-   @Test
+   @Test(timeout = 180000)
    public void testRegionCacheDeSerialization() throws Exception {
      // 1. test serialization.
      LOG.info("Starting testRegionCacheDeSerialization");
@@ -4041,7 +4042,7 @@ public class TestFromClientSide {
   /**
    * HBASE-2468 use case 3:
    */
-  @Test
+  @Test(timeout = 180000)
   public void testRegionCachePreWarm() throws Exception {
     LOG.info("Starting testRegionCachePreWarm");
     final StringBytes TABLENAME = new StringBytes("testCachePrewarm");
@@ -4280,12 +4281,12 @@ public class TestFromClientSide {
     }
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testCompactCFRegion() throws Exception {
     compactCFRegion(0);
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testCacheOnWriteEvictOnClose() throws Exception {
     byte [] tableName = Bytes.toBytes("testCOWEOCfromClient");
     byte [] data = Bytes.toBytes("data");
@@ -4387,35 +4388,35 @@ public class TestFromClientSide {
     assertEquals(count, store.getNumberOfStoreFiles());
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testMajorCompactCFRegion() throws Exception {
     compactCFRegion(1);
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testCompactMultipleCFRegion() throws Exception {
     compactMultipleCFRegion(0);
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testMajorCompactMultipleCFRegion() throws Exception {
     compactMultipleCFRegion(1);
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testCompactCFTable() throws Exception {
     compactCFTable(0);
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testMajorCompactCFTable() throws Exception {
     compactCFTable(1);
   }
 
-  @Test
   /**
    * Tests the non cached version of getRegionLocation by moving a region.
    */
+  @Test(timeout = 180000)
   public void testNonCachedGetRegionLocation() throws Exception {
     // Test Initialization.
     String tableName = "testNonCachedGetRegionLocation";
@@ -4463,7 +4464,7 @@ public class TestFromClientSide {
     assertEquals(addrAfter.getPort(), addrNoCache.getPort());
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testAtomicRowMutation() throws Exception {
     LOG.info("Starting testAtomicRowMutation");
     final byte [] TABLENAME = Bytes.toBytes("testAtomicRowMutation");
@@ -4491,7 +4492,7 @@ public class TestFromClientSide {
     assertTrue(r.isEmpty());
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testGetWithFilter() throws IOException {
     final byte [] TABLENAME = Bytes.toBytes("testGetWithFilter");
     HTable t = TEST_UTIL.createTable(TABLENAME, FAMILY);

Modified: hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/io/encoding/TestChangingEncoding.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/io/encoding/TestChangingEncoding.java?rev=1588117&r1=1588116&r2=1588117&view=diff
==============================================================================
--- hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/io/encoding/TestChangingEncoding.java (original)
+++ hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/io/encoding/TestChangingEncoding.java Thu Apr 17 00:49:13 2014
@@ -235,7 +235,7 @@ public class TestChangingEncoding {
     LOG.debug("Compaction queue size reached 0, continuing");
   }
 
-  @Test
+  @Test(timeout=TIMEOUT_MS)
   public void testCrazyRandomChanges() throws Exception {
     prepareTest("RandomChanges");
     Random rand = new Random(2934298742974297L);
@@ -255,7 +255,7 @@ public class TestChangingEncoding {
             metrics.getDataBlockEncodingMismatchMetricNames(isCompaction));
   }
 
-  @Test
+  @Test(timeout=TIMEOUT_MS)
   public void testDataBlockEncodingMismatchMetrics() throws Exception {
     prepareTest("DataEncodingMismatchMetrics");
 

Modified: hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/io/encoding/TestUpgradeFromHFileV1ToEncoding.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/io/encoding/TestUpgradeFromHFileV1ToEncoding.java?rev=1588117&r1=1588116&r2=1588117&view=diff
==============================================================================
--- hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/io/encoding/TestUpgradeFromHFileV1ToEncoding.java (original)
+++ hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/io/encoding/TestUpgradeFromHFileV1ToEncoding.java Thu Apr 17 00:49:13 2014
@@ -63,7 +63,7 @@ public class TestUpgradeFromHFileV1ToEnc
     TEST_UTIL.shutdownMiniCluster();
   }
 
-  @Test
+  @Test(timeout=180000)
   public void testUpgrade() throws Exception {
     int numBatches = 0;
     HTableDescriptor htd = new HTableDescriptor(TABLE);

Modified: hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionClose.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionClose.java?rev=1588117&r1=1588116&r2=1588117&view=diff
==============================================================================
--- hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionClose.java (original)
+++ hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegionClose.java Thu Apr 17 00:49:13 2014
@@ -36,6 +36,7 @@ import org.apache.hadoop.hbase.zookeeper
 import org.apache.zookeeper.data.Stat;
 import org.junit.After;
 import org.junit.Before;
+import org.junit.BeforeClass;
 import org.junit.Test;
 
 public class TestHRegionClose {

Modified: hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionFavoredNodes.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionFavoredNodes.java?rev=1588117&r1=1588116&r2=1588117&view=diff
==============================================================================
--- hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionFavoredNodes.java (original)
+++ hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionFavoredNodes.java Thu Apr 17 00:49:13 2014
@@ -43,7 +43,7 @@ public class TestRegionFavoredNodes {
     TEST_UTIL.shutdownMiniCluster();
   }
 
-  @Test
+  @Test(timeout = 180000)
   public void testFavoredNodes() throws Exception {
     // Get the addresses of the datanodes in the cluster.
     InetSocketAddress[] nodes = new InetSocketAddress[REGION_SERVERS];

Modified: hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/thrift/swift/TestSimpleOperations.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/thrift/swift/TestSimpleOperations.java?rev=1588117&r1=1588116&r2=1588117&view=diff
==============================================================================
--- hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/thrift/swift/TestSimpleOperations.java (original)
+++ hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/thrift/swift/TestSimpleOperations.java Thu Apr 17 00:49:13 2014
@@ -28,7 +28,9 @@ import org.apache.hadoop.hbase.client.Sc
 import org.apache.hadoop.hbase.ipc.HRegionInterface;
 import org.apache.hadoop.hbase.util.Bytes;
 import org.junit.After;
+import org.junit.AfterClass;
 import org.junit.Before;
+import org.junit.BeforeClass;
 import org.junit.Test;
 
 import static org.junit.Assert.assertEquals;
@@ -50,7 +52,7 @@ public class TestSimpleOperations {
   static final byte[] QUALIFIER1 = Bytes.toBytes("q1");
   static final byte[] QUALIFIER2 = Bytes.toBytes("q2");
 
-  @Before
+  @BeforeClass
   public void setUp() throws Exception {
     TEST_UTIL.getConfiguration().setBoolean(
         HConstants.REGION_SERVER_WRITE_THRIFT_INFO_TO_META, true);
@@ -61,7 +63,7 @@ public class TestSimpleOperations {
     TEST_UTIL.startMiniCluster(SLAVES);
   }
 
-  @After
+  @AfterClass
   public void tearDown() throws Exception {
     TEST_UTIL.shutdownMiniCluster();
   }
@@ -71,7 +73,7 @@ public class TestSimpleOperations {
    * on that row (using thrift, this time), works or not.
    * @throws IOException
    */
-  @Test
+  @Test(timeout=180000)
   public void testSimpleGetUsingThrift() throws IOException {
     byte[] r1 = Bytes.toBytes("r1");
     byte[] value = Bytes.toBytes("test-value");
@@ -96,7 +98,7 @@ public class TestSimpleOperations {
    *
    * @throws IOException
    */
-  @Test
+  @Test(timeout=180000)
   public void testPutMultiViaThrift() throws IOException {
     HTable ht = TEST_UTIL.createTable(TABLE, FAMILIES);
     List<Mutation> mutations = new ArrayList<>();
@@ -121,7 +123,7 @@ public class TestSimpleOperations {
    * get on that row (using thrift), works or not.
    * @throws Exception
    */
-  @Test
+  @Test(timeout=180000)
   public void testSimpleAsynchronousGet() throws Exception {
     byte[] r1 = Bytes.toBytes("r1");
     byte[] value = Bytes.toBytes("test-value");
@@ -143,7 +145,7 @@ public class TestSimpleOperations {
    * on that row (using Hadoop RPC, this time), works or not.
    * @throws IOException
    */
-  @Test
+  @Test(timeout=180000)
   public void testSimplePutUsingThrift() throws IOException {
     byte[] r1 = Bytes.toBytes("r1");
     byte[] value = Bytes.toBytes("test-value");
@@ -167,7 +169,7 @@ public class TestSimpleOperations {
    *
    * @throws Exception
    */
-  @Test
+  @Test(timeout=180000)
   public void testMultiPutUsingThrift() throws Exception {
     HTable table = TEST_UTIL.createTable(TABLE, FAMILIES);
     List<Put> puts = createDummyPuts(10);
@@ -208,7 +210,7 @@ public class TestSimpleOperations {
    * Only the Delete is done using Thrift.
    * @throws Exception
    */
-  @Test
+  @Test(timeout=180000)
   public void testDeleteUsingThrift() throws Exception {
     HTable table = TEST_UTIL.createTable(TABLE, FAMILIES);
     byte[] r1 = Bytes.toBytes("r1");
@@ -242,7 +244,7 @@ public class TestSimpleOperations {
    * Only the Delete is done using Thrift.
    * @throws Exception
    */
-  @Test
+  @Test(timeout=180000)
   public void testSimpleAsynchronousDelete() throws Exception {
     HTableAsyncInterface table = TEST_UTIL.createTable(TABLE, FAMILIES);
     byte[] r1 = Bytes.toBytes("r1");
@@ -274,7 +276,7 @@ public class TestSimpleOperations {
    * earlier delete would let you.
    * @throws Exception
    */
-  @Test
+  @Test(timeout=180000)
   public void testDeleteThriftAnnotationIsSufficient() throws Exception {
     HTable table = TEST_UTIL.createTable(TABLE, FAMILIES1);
     byte[] r1 = Bytes.toBytes("r1");
@@ -340,7 +342,7 @@ public class TestSimpleOperations {
    * Only the Deletes use Thrift.
    * @throws IOException
    */
-  @Test
+  @Test(timeout=180000)
   public void testBatchOfDeletesUsingThrift() throws IOException {
     HTable table = TEST_UTIL.createTable(TABLE, FAMILIES);
     Result result;
@@ -381,7 +383,7 @@ public class TestSimpleOperations {
    * earlier Put would let you.
    * @throws Exception
    */
-  @Test
+  @Test(timeout=180000)
   public void testPutThriftAnnotationIsSufficient() throws Exception {
     HTable table = TEST_UTIL.createTable(TABLE, FAMILIES1);
     byte[] r1 = Bytes.toBytes("r1");
@@ -430,7 +432,7 @@ public class TestSimpleOperations {
    * Test getRowOrBefore test
    * @throws IOException
    */
-  @Test
+  @Test(timeout=180000)
   public void testGetRowOrBefore() throws IOException {
     HTable table = TEST_UTIL.createTable(Bytes.toBytes("testGetRowOrBefore"),
         FAMILY);
@@ -451,7 +453,7 @@ public class TestSimpleOperations {
    * Test getRowOrBeforeAsync
    * @throws Exception
    */
-  @Test
+  @Test(timeout=180000)
   public void testGetRowOrBeforeAsync() throws Exception {
     HTableAsyncInterface table = TEST_UTIL.createTable(Bytes.toBytes("testGetRowOrBefore"),
         FAMILY);
@@ -473,7 +475,7 @@ public class TestSimpleOperations {
    *
    * @throws IOException
    */
-  @Test
+  @Test(timeout=180000)
   public void testSimpleMultiAction() throws IOException {
     byte[] r1 = Bytes.toBytes("r1");
     byte[] value = Bytes.toBytes("test-value");
@@ -500,7 +502,7 @@ public class TestSimpleOperations {
    *
    * @throws Exception
    */
-  @Test
+  @Test(timeout=180000)
   public void testBatchGetAsyncAction() throws Exception {
     byte[] r1 = Bytes.toBytes("r1");
     byte[] value = Bytes.toBytes("test-value");
@@ -532,7 +534,7 @@ public class TestSimpleOperations {
    *
    * @throws Exception
    */
-  @Test
+  @Test(timeout=180000)
   public void testMultiAsyncActions() throws Exception {
     HTableAsyncInterface ht = TEST_UTIL.createTable(TABLE, FAMILIES);
     List<Mutation> mutations = new ArrayList<>();
@@ -576,7 +578,7 @@ public class TestSimpleOperations {
    *
    * @throws Exception
    */
-  @Test
+  @Test(timeout=180000)
   public void testRowLock() throws Exception {
     HTableAsyncInterface ht = TEST_UTIL.createTable(TABLE, FAMILIES);
     byte[] row = Bytes.toBytes("test-row");