You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by kl...@apache.org on 2016/05/24 00:31:31 UTC

[06/29] incubator-geode git commit: Converting dunits to junit 4 using dunits_to_junit4.sh

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUpdateRIDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUpdateRIDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUpdateRIDUnitTest.java
index e4904ca..a8ce07b 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUpdateRIDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUpdateRIDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.cache.query.dunit;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import java.io.IOException;
 import java.util.ArrayList;
 import java.util.Collection;
@@ -59,7 +68,8 @@ import com.gemstone.gemfire.cache30.CertifiableTestCacheListener;
  * 
  *
  */
-public class QueryIndexUpdateRIDUnitTest extends CacheTestCase{
+@Category(DistributedTest.class)
+public class QueryIndexUpdateRIDUnitTest extends JUnit4CacheTestCase{
 
   /** The port on which the bridge server was started in this VM */
   private static int bridgeServerPort;
@@ -76,8 +86,8 @@ public class QueryIndexUpdateRIDUnitTest extends CacheTestCase{
 
   private static final String ROOT = "root";
   
-  public QueryIndexUpdateRIDUnitTest(String name) {
-    super(name);
+  public QueryIndexUpdateRIDUnitTest() {
+    super();
   }
 
   /* Test creates 1 Client and 1 Server. Client and Server create same region in their cache.
@@ -85,6 +95,7 @@ public class QueryIndexUpdateRIDUnitTest extends CacheTestCase{
    * Query must fail as registerInterest does not update indexes on client.
    */
 
+  @Test
   public void testClientIndexUpdateWithRIOnKeys() throws Exception{
     
     CqQueryUsingPoolDUnitTest cqDUnitTest = new CqQueryUsingPoolDUnitTest("CqRegisterInterestIndexUpdateDunitTest");
@@ -130,6 +141,7 @@ public class QueryIndexUpdateRIDUnitTest extends CacheTestCase{
    * with client region on register interest.
    * @throws Exception
    */
+  @Test
   public void testClientIndexUpdateWithRIOnOverlapKeys() throws Exception{
     
     CqQueryUsingPoolDUnitTest cqDUnitTest = new CqQueryUsingPoolDUnitTest("CqRegisterInterestIndexUpdateDunitTest");
@@ -180,6 +192,7 @@ public class QueryIndexUpdateRIDUnitTest extends CacheTestCase{
     cqDUnitTest.closeServer(server);
   }
 
+  @Test
   public void testClientIndexUpdateWithRIOnRegion() throws Exception{
     
     CqQueryUsingPoolDUnitTest cqDUnitTest = new CqQueryUsingPoolDUnitTest("CqRegisterInterestIndexUpdateDunitTest");
@@ -220,6 +233,7 @@ public class QueryIndexUpdateRIDUnitTest extends CacheTestCase{
     cqDUnitTest.closeServer(server);
   }
 
+  @Test
   public void testClientIndexUpdateWithRIOnRegEx() throws Exception{
     
     CqQueryUsingPoolDUnitTest cqDUnitTest = new CqQueryUsingPoolDUnitTest("QueryIndexUpdateRIDunitTest");
@@ -266,6 +280,7 @@ public class QueryIndexUpdateRIDUnitTest extends CacheTestCase{
    * 
    * @throws Exception
    */
+  @Test
   public void testClientIndexUpdateWithRIOnClearedRegion() throws Exception{
     
     CqQueryUsingPoolDUnitTest cqDUnitTest = new CqQueryUsingPoolDUnitTest("QueryIndexUpdateRIDunitTest");
@@ -322,6 +337,7 @@ public class QueryIndexUpdateRIDUnitTest extends CacheTestCase{
    * Same tests as above using Partitioned Regions. 
    */
 
+  @Test
   public void testClientIndexUpdateWithRIOnPRRegion() throws Exception{
     
     CqQueryUsingPoolDUnitTest cqDUnitTest = new CqQueryUsingPoolDUnitTest("QueryIndexUpdateRIDunitTest");
@@ -362,6 +378,7 @@ public class QueryIndexUpdateRIDUnitTest extends CacheTestCase{
     cqDUnitTest.closeServer(server);
   }
 
+  @Test
   public void testClientIndexUpdateWithRIOnPRKeys() throws Exception{
     
     CqQueryUsingPoolDUnitTest cqDUnitTest = new CqQueryUsingPoolDUnitTest("QueryIndexUpdateRIDunitTest");
@@ -402,6 +419,7 @@ public class QueryIndexUpdateRIDUnitTest extends CacheTestCase{
     cqDUnitTest.closeServer(server);
   }
 
+  @Test
   public void testClientIndexUpdateWithRIOnPRRegEx() throws Exception{
     
     CqQueryUsingPoolDUnitTest cqDUnitTest = new CqQueryUsingPoolDUnitTest("QueryIndexUpdateRIDunitTest");

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryMonitorDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryMonitorDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryMonitorDUnitTest.java
index 7932e5c..0af3b74 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryMonitorDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryMonitorDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.cache.query.dunit;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import java.io.File;
 import java.io.IOException;
 import java.util.Properties;
@@ -66,7 +75,8 @@ import com.gemstone.gemfire.test.junit.categories.FlakyTest;
  * Tests for QueryMonitoring service.
  * @since 6.0
  */
-public class QueryMonitorDUnitTest extends CacheTestCase {
+@Category(DistributedTest.class)
+public class QueryMonitorDUnitTest extends JUnit4CacheTestCase {
 
   private static int bridgeServerPort;
 
@@ -137,8 +147,8 @@ public class QueryMonitorDUnitTest extends CacheTestCase {
   
   private int numServers;
 
-  public QueryMonitorDUnitTest(String name) {
-    super(name);
+  public QueryMonitorDUnitTest() {
+    super();
   }
 
   public void setup(int numServers) throws Exception {
@@ -310,6 +320,7 @@ public class QueryMonitorDUnitTest extends CacheTestCase {
   /**
    * Tests query execution from client to server (single server).
    */
+  @Test
   public void testQueryMonitorClientServer() throws Exception {
 
     setup(1);
@@ -386,6 +397,7 @@ public class QueryMonitorDUnitTest extends CacheTestCase {
   /**
    * Tests query execution from client to server (multi server).
    */
+  @Test
   public void testQueryMonitorMultiClientMultiServer() throws Exception {
 
     setup(2);
@@ -476,6 +488,7 @@ public class QueryMonitorDUnitTest extends CacheTestCase {
    * Tests query execution on local vm.
    */
   @Category(FlakyTest.class) // GEODE-577: eats exceptions
+  @Test
   public void testQueryExecutionLocally() throws Exception {
 
     setup(2);
@@ -554,6 +567,7 @@ public class QueryMonitorDUnitTest extends CacheTestCase {
   /**
    * Tests query execution on local vm.
    */
+  @Test
   public void testQueryExecutionLocallyAndCacheOp() throws Exception {
 
     setup(2);
@@ -640,6 +654,7 @@ public class QueryMonitorDUnitTest extends CacheTestCase {
   /**
    * Tests query execution from client to server (multiple server) on Partition Region .
    */
+  @Test
   public void testQueryMonitorOnPR() throws Exception {
 
     setup(2);
@@ -723,6 +738,7 @@ public class QueryMonitorDUnitTest extends CacheTestCase {
   /**
    * Tests query execution on Partition Region, executes query locally.
    */
+  @Test
   public void testQueryMonitorWithLocalQueryOnPR() throws Exception {
 
     setup(2);
@@ -878,6 +894,7 @@ public class QueryMonitorDUnitTest extends CacheTestCase {
   /**
    * Tests query execution on region with indexes.
    */
+  @Test
   public void testQueryMonitorRegionWithIndex() throws Exception {
 
     setup(2);
@@ -1011,6 +1028,7 @@ public class QueryMonitorDUnitTest extends CacheTestCase {
    * and is not affecting other query related tests.
    * @throws Exception
    */
+  @Test
   public void testCQWithDestroysAndInvalidates() throws Exception
   {
     setup(1);
@@ -1088,6 +1106,7 @@ public class QueryMonitorDUnitTest extends CacheTestCase {
   /**
    * Tests cache operation right after query cancellation.
    */
+  @Test
   public void testCacheOpAfterQueryCancel() throws Exception {
 
     setup(4);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/cache/snapshot/ClientSnapshotDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/cache/snapshot/ClientSnapshotDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/cache/snapshot/ClientSnapshotDUnitTest.java
index 08ad752..cca9e8d 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/cache/snapshot/ClientSnapshotDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/cache/snapshot/ClientSnapshotDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.cache.snapshot;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import java.io.File;
 import java.util.concurrent.atomic.AtomicBoolean;
 
@@ -45,14 +54,16 @@ import com.gemstone.gemfire.test.dunit.LogWriterUtils;
 import com.gemstone.gemfire.test.dunit.NetworkUtils;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 
-public class ClientSnapshotDUnitTest extends CacheTestCase {
+@Category(DistributedTest.class)
+public class ClientSnapshotDUnitTest extends JUnit4CacheTestCase {
 
   private transient Region<Integer, MyObject> region;
   
-  public ClientSnapshotDUnitTest(String name) {
-    super(name);
+  public ClientSnapshotDUnitTest() {
+    super();
   }
 
+  @Test
   public void testExport() throws Exception {
     int count = 10000;
     for (int i = 0; i < count; i++) {
@@ -85,6 +96,7 @@ public class ClientSnapshotDUnitTest extends CacheTestCase {
     }
   }
   
+  @Test
   public void testImport() throws Exception {
     int count = 1000;
     for (int i = 0; i < count; i++) {
@@ -156,6 +168,7 @@ public class ClientSnapshotDUnitTest extends CacheTestCase {
     }
   }
   
+  @Test
   public void testClientCallbacks() throws Exception {
     int count = 1000;
     for (int i = 0; i < count; i++) {
@@ -209,6 +222,7 @@ public class ClientSnapshotDUnitTest extends CacheTestCase {
     region.getSnapshotService().load(f, SnapshotFormat.GEMFIRE);
   }
   
+  @Test
   public void testInvalidate() throws Exception {
     SerializableCallable invalid = new SerializableCallable() {
       @Override

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/PRDeltaPropagationDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/PRDeltaPropagationDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/PRDeltaPropagationDUnitTest.java
index 3b35954..22fd908 100755
--- a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/PRDeltaPropagationDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/PRDeltaPropagationDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
@@ -70,7 +79,8 @@ import com.gemstone.gemfire.test.dunit.WaitCriterion;
  * Tests the PR delta propagation functionality.
  * 
  */
-public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
+@Category(DistributedTest.class)
+public class PRDeltaPropagationDUnitTest extends JUnit4DistributedTestCase {
   
   private final static Compressor compressor = SnappyCompressor.getDefaultInstance();
 
@@ -122,8 +132,8 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
   private static boolean queryDestroyExecuted = false;
   private static boolean notADeltaInstanceObj = false;
 
-  public PRDeltaPropagationDUnitTest(String name) {
-    super(name);
+  public PRDeltaPropagationDUnitTest() {
+    super();
   }
 
   @Override
@@ -146,6 +156,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    *  3) From primary to secondary delta gets propagated as part RR distribution.
    * 
    */
+  @Test
   public void testDeltaPropagationForPR() throws Throwable {
     createCacheInAllPRVms();
     createDeltaPR(Boolean.FALSE);
@@ -159,6 +170,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    *  Monitor number of times constructor is called
    *  Without copy or cloning, we should have 1 instance
    */
+  @Test
   public void testConstructorCountWithoutCloning() throws Throwable {
 
     clearConstructorCounts();
@@ -180,6 +192,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    *  With cloning, we should have more than 1 instance
    *  on members receiving delta updates
    */
+  @Test
   public void testConstructorCountWithCloning() throws Throwable {
 
     clearConstructorCounts();
@@ -201,6 +214,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    *  Create partition with cloning disabled, then
    *  enable cloning and verify proper operation 
    */
+  @Test
   public void testConstructorCountWithMutator() throws Throwable {
 
     clearConstructorCounts();
@@ -276,6 +290,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    * Check delta propagation works properly with PR failover.    
    */
 
+  @Test
   public void testDeltaPropagationForPRFailover() throws Throwable {
     Object args[] = new Object[] { REGION_NAME, new Integer(1), new Integer(50),
         new Integer(8), Boolean.FALSE, null };
@@ -310,6 +325,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
     client1.invoke(() -> PRDeltaPropagationDUnitTest.checkDeltaInvoked(new Integer(deltaSent)));    
   }
 
+  @Test
   public void testDeltaPropagationForPRFailoverWithCompression() throws Throwable {
     Object args[] = new Object[] { REGION_NAME, new Integer(1), new Integer(50),
         new Integer(8), Boolean.FALSE, compressor };
@@ -353,6 +369,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    * Check full object gets resend if delta can not be applied    
    */
 
+  @Test
   public void testDeltaPropagationForPRWithExpiry() throws Throwable {
     createCacheInAllPRVms();
     createDeltaPR(Boolean.TRUE);
@@ -367,6 +384,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    *  3) From data store to client delta should get propagated.
    * 
    */
+  @Test
   public void testDeltaPropagationPRAccessorAsBridgeServer() throws Throwable {
     Object args1[] = new Object[] { REGION_NAME, new Integer(0), new Integer(0),
         new Integer(8), Boolean.FALSE, null };
@@ -394,6 +412,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    * 4) Client sends full object in response.
    * 
    */
+  @Test
   public void testDeltaPropagationPRAccessorAsBridgeServerWithDeltaException() throws Throwable {
     Object args1[] = new Object[] { REGION_NAME, new Integer(0), new Integer(0),
         new Integer(8), Boolean.FALSE, null };
@@ -438,6 +457,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    * 4) Client sends full object in response.
    * 
    */
+  @Test
   public void testDeltaPropagationClientEmptyPRAccessorAsBridgeServerWithDeltaException()
       throws Throwable {
     Object args1[] = new Object[] { REGION_NAME, new Integer(0),
@@ -484,6 +504,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    * 4) Client sends full object in response.
    * 
    */
+  @Test
   public void testDeltaPropagationReplicatedRegionPeerWithDeltaException() throws Throwable {
     Object args1[] = new Object[] {Boolean.FALSE, Boolean.TRUE};
     Object args2[] = new Object[] {Boolean.TRUE, Boolean.FALSE};
@@ -525,6 +546,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    * 2) Second client attached to datastore. Register CQ.
    * 3) Varifies that no data loss, event revcieved on second client 
    */
+  @Test
   public void testCqClientConnectAccessorAndDataStore()
       throws Throwable {
     Object args1[] = new Object[] { REGION_NAME, new Integer(1),
@@ -581,6 +603,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    * Accesor gets adjunctMessage about put
    * Verify on client1 that queryUpdate and queryDestroy are executed properly
    */
+  @Test
   public void testClientOnAccessorReceivesCqEvents()
       throws Throwable {
     Object args1[] = new Object[] { REGION_NAME, new Integer(1),
@@ -627,6 +650,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    * client puts delta objects on accessor
    * Verify on client1 that queryUpdate and queryDestroy are executed properly
    */  
+  @Test
   public void testCQClientOnRedundantBucketReceivesCQEvents()
       throws Throwable {
     // args for accessor
@@ -685,6 +709,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    * Verify that client1 receives 2 deltas for 2 updates (due to RI)
    * Verify on client1 that queryUpdate and queryDestroy are executed properly
    */  
+  @Test
   public void testCQRIClientOnRedundantBucketReceivesDeltaAndCQEvents()
       throws Throwable {
     // args for accessor
@@ -738,6 +763,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    *  4) From accessor to client delta should get propagated.
    * 
    */
+  @Test
   public void testDeltaPropagationWithAdjunctMessaging() throws Throwable {
     Object args1[] = new Object[] { REGION_NAME, new Integer(0), new Integer(0),
         new Integer(8), Boolean.FALSE, null };
@@ -762,6 +788,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    *  4) From accessor to client with data policy empty full value should get propagated.
    * 
    */
+  @Test
   public void testDeltaPropagationWithAdjunctMessagingForEmptyClient() throws Throwable {
     Object args1[] = new Object[] { REGION_NAME, new Integer(0), new Integer(0),
         new Integer(8), Boolean.FALSE, null };
@@ -793,6 +820,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
    *  5) Another delta put is performed on datastore.
    *  6) Verify that the second delta put fails and value on datastore is same as the one put by first delta update. 
    */
+  @Test
   public void testDeltaPropagationWithAdjunctMessagingAndBadDelta() throws Throwable {
     Object accessor[] = new Object[] { REGION_NAME, 0, 0, 8, Boolean.FALSE, null };
     Object dataStore[] = new Object[] { REGION_NAME, 0, 50, 8, Boolean.FALSE, null };
@@ -860,7 +888,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
   }
   
   public static void createCacheInVm() {
-    new PRDeltaPropagationDUnitTest("temp").createCache(new Properties());
+    new PRDeltaPropagationDUnitTest().createCache(new Properties());
   }
 
   public void createCache(Properties props) {
@@ -953,7 +981,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
       Boolean isEmpty) throws Exception {
 
     Properties props = new Properties();
-    new PRDeltaPropagationDUnitTest("temp").createCache(props);
+    new PRDeltaPropagationDUnitTest().createCache(props);
     AttributesFactory factory = new AttributesFactory();
     factory.setScope(Scope.DISTRIBUTED_ACK);
     factory.setConcurrencyChecksEnabled(true);
@@ -997,7 +1025,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
   
   public static void createClientCache(Integer port1,
       Boolean subscriptionEnable, Boolean isEmpty, Boolean isCq) throws Exception {
-    PRDeltaPropagationDUnitTest test = new PRDeltaPropagationDUnitTest("temp");
+    PRDeltaPropagationDUnitTest test = new PRDeltaPropagationDUnitTest();
     Properties props = new Properties();
     props.setProperty(DistributionConfig.MCAST_PORT_NAME, "0");
     props.setProperty(DistributionConfig.LOCATORS_NAME, "");
@@ -1085,7 +1113,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
   }
 
   public static void createClientCache(Integer port1, Integer port2) throws Exception {
-    PRDeltaPropagationDUnitTest test = new PRDeltaPropagationDUnitTest("temp");
+    PRDeltaPropagationDUnitTest test = new PRDeltaPropagationDUnitTest();
     Properties props = new Properties();
     props.setProperty(DistributionConfig.MCAST_PORT_NAME, "0");
     props.setProperty(DistributionConfig.LOCATORS_NAME, "");

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/RemoteCQTransactionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/RemoteCQTransactionDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/RemoteCQTransactionDUnitTest.java
index 5c3a1b3..1c8b1a3 100755
--- a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/RemoteCQTransactionDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/RemoteCQTransactionDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import java.util.Collections;
 import java.util.HashMap;
 import java.util.HashSet;
@@ -71,7 +80,8 @@ import com.gemstone.gemfire.test.dunit.WaitCriterion;
 /**
  *
  */
-public class RemoteCQTransactionDUnitTest extends CacheTestCase {
+@Category(DistributedTest.class)
+public class RemoteCQTransactionDUnitTest extends JUnit4CacheTestCase {
   final protected String CUSTOMER = "custRegion";
   final protected String ORDER = "orderRegion";
   final protected String D_REFERENCE = "distrReference";
@@ -104,8 +114,8 @@ public class RemoteCQTransactionDUnitTest extends CacheTestCase {
   /**
    * @param name
    */
-  public RemoteCQTransactionDUnitTest(String name) {
-    super(name);
+  public RemoteCQTransactionDUnitTest() {
+    super();
   }
 
   protected enum OP {
@@ -855,6 +865,7 @@ protected static class ClientListener extends CacheListenerAdapter {
   
   private static final String EMPTY_REGION = "emptyRegionName";
   
+  @Test
   public void testTXWithCQCommitInDatastoreCQ() throws Exception {
     Host host = Host.getHost(0);
     VM accessor = host.getVM(0);
@@ -897,6 +908,7 @@ protected static class ClientListener extends CacheListenerAdapter {
   }
   
   
+  @Test
   public void testTXWithCQCommitInDatastoreConnectedToAccessorCQ() throws Exception {
     Host host = Host.getHost(0);
     VM accessor = host.getVM(0);
@@ -938,6 +950,7 @@ protected static class ClientListener extends CacheListenerAdapter {
   }
   
   
+  @Test
   public void testTXWithCQCommitInDatastoreConnectedToDatastoreCQ() throws Exception {
     Host host = Host.getHost(0);
     VM accessor = host.getVM(0);
@@ -978,6 +991,7 @@ protected static class ClientListener extends CacheListenerAdapter {
     });
   }
   
+  @Test
   public void testTXWithCQCommitInAccessorConnectedToDatastoreCQ() throws Exception {
     Host host = Host.getHost(0);
     VM accessor = host.getVM(0);
@@ -1018,6 +1032,7 @@ protected static class ClientListener extends CacheListenerAdapter {
     });
   }
   
+  @Test
   public void testTXWithCQCommitInAccessorConnectedToAccessorCQ() throws Exception {
     Host host = Host.getHost(0);
     VM accessor = host.getVM(0);
@@ -1059,6 +1074,7 @@ protected static class ClientListener extends CacheListenerAdapter {
   }
   
   
+  @Test
   public void testCQCommitInDatastoreConnectedToAccessorCQ() throws Exception {
     Host host = Host.getHost(0);
     VM accessor = host.getVM(0);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java
index 6d830b8..d1c14aa 100755
--- a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.internal.cache.ha;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import java.io.File;
 import java.io.IOException;
 import java.util.ArrayList;
@@ -72,7 +81,8 @@ import junit.framework.TestSuite;
  * @since 5.7
  *
  */
-public class CQListGIIDUnitTest extends DistributedTestCase {
+@Category(DistributedTest.class)
+public class CQListGIIDUnitTest extends JUnit4DistributedTestCase {
   private final static int CREATE = 0;
 
   private final static int UPDATE = 1;
@@ -150,8 +160,8 @@ public class CQListGIIDUnitTest extends DistributedTestCase {
    * @param name
    *          name of the test
    */
-  public CQListGIIDUnitTest(String name) {
-    super(name);
+  public CQListGIIDUnitTest() {
+    super();
   }
 
   /**
@@ -204,7 +214,7 @@ public class CQListGIIDUnitTest extends DistributedTestCase {
 
   public static Integer createServerCache(String ePolicy, Integer cap)
       throws Exception {
-    new CQListGIIDUnitTest("temp").createCache(new Properties());
+    new CQListGIIDUnitTest().createCache(new Properties());
     AttributesFactory factory = new AttributesFactory();
     factory.setScope(Scope.DISTRIBUTED_ACK);
     factory.setDataPolicy(DataPolicy.REPLICATE);
@@ -335,7 +345,7 @@ public class CQListGIIDUnitTest extends DistributedTestCase {
     Properties props = new Properties();
     props.setProperty(DistributionConfig.MCAST_PORT_NAME, "0");
     props.setProperty(DistributionConfig.LOCATORS_NAME, "");
-    new CQListGIIDUnitTest("temp").createCache(props);
+    new CQListGIIDUnitTest().createCache(props);
 
     PoolFactory pf = PoolManager.createFactory();
     int endPointCount = 1;
@@ -646,6 +656,7 @@ public class CQListGIIDUnitTest extends DistributedTestCase {
    *
    * @throws Exception
    */
+  @Test
   public void testClientCQNotLostAtGIIReceiver() throws Exception {
     Integer size = Integer.valueOf(10);
     VM serverVM2 = clientVM2;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientToServerDeltaDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientToServerDeltaDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientToServerDeltaDUnitTest.java
index a5c4ff6..eebb574 100755
--- a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientToServerDeltaDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientToServerDeltaDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
@@ -62,7 +71,8 @@ import com.gemstone.gemfire.test.dunit.WaitCriterion;
  * 
  * @since 6.1
  */
-public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
+@Category(DistributedTest.class)
+public class ClientToServerDeltaDUnitTest extends JUnit4DistributedTestCase {
   /*
    * Test configuration one server one client also 2 server 2 client
    */
@@ -119,8 +129,8 @@ public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
   public static String LAST_KEY = "LAST_KEY";
   
   /** constructor */
-  public ClientToServerDeltaDUnitTest(String name) {
-    super(name);
+  public ClientToServerDeltaDUnitTest() {
+    super();
   }
 
   @Override
@@ -186,6 +196,7 @@ public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
    * resending of full object</b>):<br>
    * 1)Verifies that we donot loose attributes updates when delta fails<br>
    */
+  @Test
   public void testSendingofFullDeltaObjectsWhenFromDeltaFails() {
     initialise(false);
     // set expected value on server
@@ -209,6 +220,7 @@ public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
    * This test does the following for single key</br> 1)Verifies that we donot
    * loose attributes updates when delta fails<br>
    */
+  @Test
   public void testPutForDeltaObjects() {
     initialise(false);
     // set expected value on server
@@ -230,6 +242,7 @@ public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
    * This test does the following for single key (<b> full cycle</b>):<br>
    * 1)Verifies that client-server, peer-peer and server-client processing delta<br>
    */
+  @Test
   public void testClientToClientDeltaPropagation() throws Exception {
     initialise(false);
     // set expected value on s1,s1 and c2
@@ -457,7 +470,7 @@ public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
     Properties props = new Properties();
     props.setProperty(DistributionConfig.DELTA_PROPAGATION_PROP_NAME,
         enableDelta.toString());
-    new ClientToServerDeltaDUnitTest("temp").createCache(props);
+    new ClientToServerDeltaDUnitTest().createCache(props);
     AttributesFactory factory = new AttributesFactory();
     factory.setScope(Scope.DISTRIBUTED_ACK);
     factory.setConcurrencyChecksEnabled(true);
@@ -565,7 +578,7 @@ public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
     Properties props = new Properties();
     props.setProperty(DistributionConfig.MCAST_PORT_NAME, "0");
     props.setProperty(DistributionConfig.LOCATORS_NAME, "");
-    new ClientToServerDeltaDUnitTest("temp").createCache(props);
+    new ClientToServerDeltaDUnitTest().createCache(props);
     pool = (PoolImpl)PoolManager.createFactory().addServer(host, port.intValue())
         .setThreadLocalConnections(true).setMinConnections(2)
         .setSubscriptionEnabled(enableSubscription).setSubscriptionRedundancy(0)
@@ -681,6 +694,7 @@ public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
    * This test does the following for single key:<br>
    * 1)Verifies that cacheless client calls toDelta <br>
    */
+  @Test
   public void testEmptyClientAsFeederToServer() {
     Integer PORT1 = ((Integer)server.invoke(() -> ClientToServerDeltaDUnitTest.createServerCache( Boolean.FALSE,
             Boolean.FALSE ))).intValue();
@@ -706,6 +720,7 @@ public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
    * 1)Verifies that from delta should not called on server with empty data
    * policy just by passed delta to data store<br>
    */
+  @Test
   public void testEmptyServerAsFeederToPeer() {
     Integer PORT1 = ((Integer)server.invoke(() -> ClientToServerDeltaDUnitTest.createServerCache( Boolean.FALSE,
             Boolean.TRUE ))).intValue();
@@ -732,6 +747,7 @@ public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
    * handle deltas.
    * 
    */
+  @Test
   public void testClientsConnectedToEmptyServer() {
     Integer PORT1 = ((Integer)server.invoke(() -> ClientToServerDeltaDUnitTest.createServerCache( Boolean.FALSE,
             Boolean.TRUE ))).intValue();
@@ -758,6 +774,7 @@ public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
    * This test does the following for single key:<br>
    * 1)Verifies that To delta called on client should be equal to fromDeltaCounter on datastore <br>
    */
+  @Test
   public void testClientNonEmptyEmptyServerAsFeederToPeer() {
     Integer PORT1 = ((Integer)server.invoke(() -> ClientToServerDeltaDUnitTest.createServerCache( Boolean.FALSE,
             Boolean.TRUE ))).intValue();
@@ -789,6 +806,7 @@ public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
    * 
    * @throws Exception
    */
+  @Test
   public void testC2CDeltaPropagationWithCQ() throws Exception {
     initialise(false/* clone */, new String[] { CQs[1] }, true/* CQ */,
         true/* RI */, true/* enable delta */);
@@ -812,6 +830,7 @@ public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
    * 
    * @throws Exception
    */
+  @Test
   public void testC2CDeltaPropagationWithCQWithoutRI() throws Exception {
     initialise(false/* clone */, new String[] { CQs[1] }, true/* CQ */,
         false/* RI */, true/* enable delta */);
@@ -828,6 +847,7 @@ public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
     server2.invoke(() -> ClientToServerDeltaDUnitTest.verifyDeltaSent( Integer.valueOf(1) ));
   }
 
+  @Test
   public void testClientSendsFullValueToServerWhenDeltaOffAtServer() {
     initialise2(false/* clone */, new String[] { CQs[1] }, false/* CQ */,
         true/* RI */, false/* enable delta */);
@@ -849,6 +869,7 @@ public class ClientToServerDeltaDUnitTest extends DistributedTestCase {
         (Boolean)server.invoke(() -> DeltaTestImpl.isFromDeltaFailure()));
   }
 
+  @Test
   public void testC2SDeltaPropagationWithOldValueInvalidatedAtServer()
       throws Exception {
     String key = "DELTA_KEY";

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaPropagationWithCQDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaPropagationWithCQDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaPropagationWithCQDUnitTest.java
index 389ea55..9e1b3c4 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaPropagationWithCQDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaPropagationWithCQDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import java.util.Arrays;
 import java.util.HashSet;
 import java.util.List;
@@ -66,7 +75,8 @@ import com.gemstone.gemfire.test.dunit.WaitCriterion;
 /**
  *
  */
-public class DeltaPropagationWithCQDUnitTest extends DistributedTestCase {
+@Category(DistributedTest.class)
+public class DeltaPropagationWithCQDUnitTest extends JUnit4DistributedTestCase {
   
   private static GemFireCache cache = null;
 
@@ -96,8 +106,8 @@ public class DeltaPropagationWithCQDUnitTest extends DistributedTestCase {
   /**
    * @param name
    */
-  public DeltaPropagationWithCQDUnitTest(String name) {
-    super(name);
+  public DeltaPropagationWithCQDUnitTest() {
+    super();
   }
 
   @Override
@@ -127,6 +137,7 @@ public class DeltaPropagationWithCQDUnitTest extends DistributedTestCase {
     cqErrors = 0;
   }
 
+  @Test
   public void testCqWithRI() throws Exception {
     // 1. setup a cache server
     int port = (Integer)server1.invoke(() -> DeltaPropagationWithCQDUnitTest.createCacheServer());
@@ -160,6 +171,7 @@ public class DeltaPropagationWithCQDUnitTest extends DistributedTestCase {
         .get("SAMPLE_KEY"));
   }
 
+  @Test
   public void testFullValueRequestsWithCqWithoutRI() throws Exception {
     int numOfListeners = 5;
     int numOfKeys = 10;
@@ -247,7 +259,7 @@ public class DeltaPropagationWithCQDUnitTest extends DistributedTestCase {
   }
 
   public static Integer createCacheServer() throws Exception {
-    DeltaPropagationWithCQDUnitTest instance = new DeltaPropagationWithCQDUnitTest("temp");
+    DeltaPropagationWithCQDUnitTest instance = new DeltaPropagationWithCQDUnitTest();
     Properties props = new Properties();
     DistributedSystem ds = instance.getSystem(props);
     ds.disconnect();
@@ -272,7 +284,7 @@ public class DeltaPropagationWithCQDUnitTest extends DistributedTestCase {
     Properties props = new Properties();
     props.setProperty(DistributionConfig.MCAST_PORT_NAME, "0");
     props.setProperty(DistributionConfig.LOCATORS_NAME, "");
-    DeltaPropagationWithCQDUnitTest instance = new DeltaPropagationWithCQDUnitTest("temp");
+    DeltaPropagationWithCQDUnitTest instance = new DeltaPropagationWithCQDUnitTest();
     DistributedSystem ds = instance.getSystem(props);
     ds.disconnect();
     ds = instance.getSystem(props);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaToRegionRelationCQRegistrationDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaToRegionRelationCQRegistrationDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaToRegionRelationCQRegistrationDUnitTest.java
index bf14d2e..b3ce38a 100755
--- a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaToRegionRelationCQRegistrationDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaToRegionRelationCQRegistrationDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import java.util.Iterator;
 import java.util.Properties;
 
@@ -54,7 +63,8 @@ import com.gemstone.gemfire.test.dunit.WaitCriterion;
  * Delta propogation for a client while registering CQ
  * 
  */
-public class DeltaToRegionRelationCQRegistrationDUnitTest extends DistributedTestCase {
+@Category(DistributedTest.class)
+public class DeltaToRegionRelationCQRegistrationDUnitTest extends JUnit4DistributedTestCase {
   private static Cache cache = null;
 
   VM server = null;
@@ -110,8 +120,8 @@ public class DeltaToRegionRelationCQRegistrationDUnitTest extends DistributedTes
   private static final String cqName4="cqNameFourth";
   
   /** constructor */
-  public DeltaToRegionRelationCQRegistrationDUnitTest(String name) {
-    super(name);
+  public DeltaToRegionRelationCQRegistrationDUnitTest() {
+    super();
   }
 
   @Override
@@ -131,6 +141,7 @@ public class DeltaToRegionRelationCQRegistrationDUnitTest extends DistributedTes
    * 2)Verifies no create happens for region with data policy other then Empty; in map <br>
    * 3)Verifies multiple and different interest registration (key/list) should not create multiple entries in map <br>
    */
+  @Test
   public void testDeltaToRegionForRegisterCQ(){
     
     intialSetUp();
@@ -167,6 +178,7 @@ public class DeltaToRegionRelationCQRegistrationDUnitTest extends DistributedTes
    * 2)Verifies no create happens for region with data policy other then Empty; in map <br>
    * 3)Verifies multiple and different interest registration (key/list) should not create multiple entries in map <br>
    */
+  @Test
   public void testDeltaToRegionForRegisterCQIR(){
     
     intialSetUp();
@@ -203,6 +215,7 @@ public class DeltaToRegionRelationCQRegistrationDUnitTest extends DistributedTes
    * 1)Verifies create entry for region in map stored in CacheCleintProxy <br>
    * 2)Verifies multiple and different interest registration (key/list) should not create multiple entries in map <br>
    */
+  @Test
   public void testDeltaToRegionForRegisterCQIRThroughPool(){
     
     intialSetUpClientWithNoRegion();
@@ -241,6 +254,7 @@ public class DeltaToRegionRelationCQRegistrationDUnitTest extends DistributedTes
    * 2)Verifies create entry for region with data policy as Empty; in map stored in CacheCleintProxy <br>
    * 3)Verifies no create happens for region with data policy other then Empty; in map <br>
    */
+  @Test
   public void testDeltaToRegionForRegisterCQFailover(){
     
     intialSetUpForFailOver();
@@ -259,6 +273,7 @@ public class DeltaToRegionRelationCQRegistrationDUnitTest extends DistributedTes
    * 2)Verifies create entry for region with data policy as Empty; in map stored in CacheCleintProxy <br>
    * 3)Verifies no create happens for region with data policy other then Empty; in map <br>
    */
+  @Test
   public void testDeltaToRegionForRegisterCQIRFaliover() {
     intialSetUpForFailOver();
     // Register CQ on region with data policy as EMPTY
@@ -276,6 +291,7 @@ public class DeltaToRegionRelationCQRegistrationDUnitTest extends DistributedTes
    * 1)Verifies when primary goes down, cq registration happen <br>
    * 2)Verifies create entry for region in map stored in CacheCleintProxy <br>
    */
+  @Test
   public void testDeltaToRegionForRegisterCQIRFromPoolFaliover() {
     intialSetUpNoRegiononClientForFailOver();
     // Register CQ on region
@@ -445,7 +461,7 @@ public class DeltaToRegionRelationCQRegistrationDUnitTest extends DistributedTes
    */
   public static Integer createServerCache() throws Exception
   {
-    new DeltaToRegionRelationCQRegistrationDUnitTest("temp").createCache(new Properties());
+    new DeltaToRegionRelationCQRegistrationDUnitTest().createCache(new Properties());
     AttributesFactory factory = new AttributesFactory();
     factory.setScope(Scope.DISTRIBUTED_ACK);
     factory.setDataPolicy(DataPolicy.REPLICATE);
@@ -470,7 +486,7 @@ public class DeltaToRegionRelationCQRegistrationDUnitTest extends DistributedTes
     Properties props = new Properties();
     props.setProperty(DistributionConfig.MCAST_PORT_NAME, "0");
     props.setProperty(DistributionConfig.LOCATORS_NAME, "");
-    new DeltaToRegionRelationCQRegistrationDUnitTest("temp").createCache(props);
+    new DeltaToRegionRelationCQRegistrationDUnitTest().createCache(props);
     Pool p = PoolManager.createFactory().addServer(host, port.intValue())
         .setThreadLocalConnections(true).setMinConnections(3)
         .setSubscriptionEnabled(true).setSubscriptionRedundancy(0)
@@ -506,7 +522,7 @@ public class DeltaToRegionRelationCQRegistrationDUnitTest extends DistributedTes
     Properties props = new Properties();
     props.setProperty(DistributionConfig.MCAST_PORT_NAME, "0");
     props.setProperty(DistributionConfig.LOCATORS_NAME, "");
-    new DeltaToRegionRelationCQRegistrationDUnitTest("temp").createCache(props);
+    new DeltaToRegionRelationCQRegistrationDUnitTest().createCache(props);
     p = (PoolImpl)PoolManager.createFactory().addServer(host, port.intValue())
         .setThreadLocalConnections(true).setMinConnections(3)
         .setSubscriptionEnabled(true).setSubscriptionRedundancy(0)
@@ -523,7 +539,7 @@ public class DeltaToRegionRelationCQRegistrationDUnitTest extends DistributedTes
     Properties props = new Properties();
     props.setProperty(DistributionConfig.MCAST_PORT_NAME, "0");
     props.setProperty(DistributionConfig.LOCATORS_NAME, "");
-    new DeltaToRegionRelationCQRegistrationDUnitTest("temp").createCache(props);
+    new DeltaToRegionRelationCQRegistrationDUnitTest().createCache(props);
     PoolImpl p = (PoolImpl)PoolManager.createFactory().addServer(host1,
         port1.intValue()).addServer(host2, port2.intValue())
         .setThreadLocalConnections(true).setMinConnections(3)
@@ -559,7 +575,7 @@ public class DeltaToRegionRelationCQRegistrationDUnitTest extends DistributedTes
     Properties props = new Properties();
     props.setProperty(DistributionConfig.MCAST_PORT_NAME, "0");
     props.setProperty(DistributionConfig.LOCATORS_NAME, "");
-    new DeltaToRegionRelationCQRegistrationDUnitTest("temp").createCache(props);
+    new DeltaToRegionRelationCQRegistrationDUnitTest().createCache(props);
     p = (PoolImpl)PoolManager.createFactory().addServer(host1,
         port1.intValue()).addServer(host2, port2.intValue())
         .setThreadLocalConnections(true).setMinConnections(3)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientCrashDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientCrashDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientCrashDUnitTest.java
index 4faade9..58f2cf4 100755
--- a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientCrashDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientCrashDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import com.gemstone.gemfire.cache.CacheException;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 
@@ -26,10 +35,11 @@ import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
  * 
  * @since 5.2
  */
+@Category(DistributedTest.class)
 public class DurableClientCrashDUnitTest extends DurableClientTestCase {
 
-  public DurableClientCrashDUnitTest(String name) {
-    super(name);
+  public DurableClientCrashDUnitTest() {
+    super();
   }
 
   @Override
@@ -91,8 +101,10 @@ public class DurableClientCrashDUnitTest extends DurableClientTestCase {
   
   // AB: Following tests are not relevant for client crash case.
   
+  @Test
   public void testCqCloseExceptionDueToActiveConnection() throws Exception {}
 
+  @Test
   public void testCloseCacheProxy() throws Exception {}
 
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientNetDownDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientNetDownDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientNetDownDUnitTest.java
index a087386..277de4f 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientNetDownDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientNetDownDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 
 /**
  * Class <code>DurableClientCrashDUnitTest</code> tests durable client
@@ -24,10 +33,11 @@ package com.gemstone.gemfire.internal.cache.tier.sockets;
  * 
  * @since 5.2
  */
+@Category(DistributedTest.class)
 public class DurableClientNetDownDUnitTest extends DurableClientCrashDUnitTest {
 
-  public DurableClientNetDownDUnitTest(String name) {
-    super(name);
+  public DurableClientNetDownDUnitTest() {
+    super();
   }
   
   @Override

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java
index 28d401f..3841f27 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java
@@ -15,6 +15,15 @@
  * limitations under the License.
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
+
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
 import java.util.Iterator;
 
@@ -54,14 +63,16 @@ import com.gemstone.gemfire.test.dunit.Wait;
 import com.gemstone.gemfire.test.dunit.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.FlakyTest;
 
+@Category(DistributedTest.class)
 public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
 
-  public DurableClientSimpleDUnitTest(String name) {
-    super(name);
+  public DurableClientSimpleDUnitTest() {
+    super();
   }
   /**
    * Test that a durable client correctly receives updates.
    */
+  @Test
   public void testSimpleDurableClientUpdate() {
     // Start a server
     int serverPort = ((Integer) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServer(regionName, new Boolean(true))))
@@ -139,6 +150,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Test that a durable client VM with multiple BridgeClients correctly
    * registers on the server.
    */
+  @Test
   public void testMultipleBridgeClientsInSingleDurableVM() {
     // Start a server
     int serverPort = ((Integer) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServer(regionName, new Boolean(true))))
@@ -314,6 +326,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   /**
    * Test that the server correctly processes starting two durable clients.
    */
+  @Test
   public void testSimpleTwoDurableClients() {
     // Start a server
     int serverPort = ((Integer) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServer(regionName, new Boolean(true))))
@@ -556,6 +569,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   /**
    * Test that updates to two durable clients are processed correctly.
    */
+  @Test
   public void testTwoDurableClientsStartStopUpdate() {
     // Start a server
     int serverPort = ((Integer) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServer(regionName, new Boolean(true))))
@@ -829,6 +843,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   /**
    * Tests whether a durable client reconnects properly to two servers.
    */
+  @Test
   public void testDurableClientReconnectTwoServers() {
     // Start server 1
     Integer[] ports = ((Integer[]) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServerReturnPorts(regionName, new Boolean(true))));
@@ -1022,6 +1037,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
     this.server2VM.invoke(() -> CacheServerTestUtil.closeCache());
   }
   
+  @Test
   public void testReadyForEventsNotCalledImplicitly() {
     // Start a server
     int serverPort = ((Integer) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServer(regionName, new Boolean(true))))
@@ -1081,6 +1097,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   //This test method is disabled because it is failing
   //periodically and causing cruise control failures
   //See bug #47060
+  @Test
   public void testReadyForEventsNotCalledImplicitlyWithCacheXML() {
     try {
       setPeriodicACKObserver(durableClientVM);
@@ -1347,6 +1364,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
     vm.invoke(cacheSerializableRunnable);
   }
   
+  @Test
   public void testReadyForEventsNotCalledImplicitlyForRegisterInterestWithCacheXML() {
     final String cqName = "cqTest";
     regionName = "testReadyForEventsNotCalledImplicitlyWithCacheXML_region";
@@ -1535,6 +1553,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Events are queued up and the stats are checked
    * Durable client is then reconnected, events are dispatched and stats are rechecked
    */
+  @Test
   public void testHAQueueSizeStat() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -1611,6 +1630,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Stats should now be 0
    * Durable client is then reconnected, no events should exist and stats are rechecked
    */
+  @Test
   public void testHAQueueSizeStatExpired() throws Exception {
     int timeoutInSeconds = 20;
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
@@ -1697,6 +1717,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Stats are checked
    * Durable client then reregisters cqs and sends ready for events
    */
+  @Test
   public void testHAQueueSizeStatForGII() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -1787,6 +1808,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   /**
    * Tests the ha queued cq stat
    */
+  @Test
   public void testHAQueuedCqStat() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -1862,6 +1884,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   /**
    * @throws Exception
    */
+  @Test
   public void testHAQueuedCqStatOnSecondary() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -1961,6 +1984,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * 
    * @throws Exception
    */
+  @Test
   public void testHAQueuedCqStatForGII() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2061,6 +2085,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Durable Client sends ready or events and receives events
    * Recheck stats
    */
+  @Test
   public void testHAQueuedCqStatForGII2() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2158,6 +2183,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * 
    * @throws Exception
    */
+  @Test
   public void testHAQueuedCqStatForGIINoFailover() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2255,6 +2281,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * server 2 behaves accordingly
    * @throws Exception
    */
+  @Test
   public void testHAQueuedCqStatForFailover() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2343,6 +2370,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   /**
    * Tests the ha queued cq stat
    */
+  @Test
   public void testHAQueuedCqStatWithTimeOut() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2427,6 +2455,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Test functionality to close the cq and drain all events from the ha queue from the server
    * @throws Exception
    */
+  @Test
   public void testCloseCqAndDrainEvents() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2510,6 +2539,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * This draining should not affect events that still have register interest
    * @throws Exception
    */
+  @Test
   public void testCloseAllCqsAndDrainEvents() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2596,6 +2626,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Continues to publish afterwards to verify that stats are correct
    * @throws Exception
    */
+  @Test
   public void testCloseAllCqsAndDrainEventsNoInterestRegistered() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2706,6 +2737,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Two durable clients, one will have a cq be closed, the other should be unaffected
    * @throws Exception
    */
+  @Test
   public void testCloseCqAndDrainEvents2Client() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2824,6 +2856,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * The client should be rejected until no cqs are currently being drained
    * @throws Exception
    */
+  @Test
   public void testRejectClientWhenDrainingCq() throws Exception {
     try {
       IgnoredException.addIgnoredException(LocalizedStrings.CacheClientNotifier_COULD_NOT_CONNECT_DUE_TO_CQ_BEING_DRAINED.toLocalizedString());
@@ -2948,6 +2981,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * @throws Exception
    */
   @Category(FlakyTest.class) // GEODE-1060: random ports, async actions, time sensitive, eats exceptions (fixed 1)
+  @Test
   public void testCqCloseExceptionDueToActivatingClient() throws Exception {
     try {
       String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
@@ -3048,6 +3082,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Tests situation where a client is trying to reconnect while a cq is being drained
    * @throws Exception
    */
+  @Test
   public void testCqCloseExceptionDueToActiveConnection() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -3123,6 +3158,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * and drain all events from the ha queue from the server
    * @throws Exception
    */
+  @Test
   public void testCloseCacheProxy() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -3215,6 +3251,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Test that starting a durable client on multiple servers is processed
    * correctly.
    */
+  @Test
   public void testSimpleDurableClientMultipleServers() {
     // Start server 1
     Integer[] ports = ((Integer[]) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServerReturnPorts(regionName, new Boolean(true))));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java
index 167cc3a..29eccd2 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.management;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.client.internal.LocatorTestBase;
 import com.gemstone.gemfire.cache.query.*;
@@ -44,6 +53,7 @@ import java.util.Properties;
 /**
  * Cache Server related management test cases
  */
+@Category(DistributedTest.class)
 public class CacheServerManagementDUnitTest extends LocatorTestBase {
 
   private static final long serialVersionUID = 1L;
@@ -61,8 +71,8 @@ public class CacheServerManagementDUnitTest extends LocatorTestBase {
   protected CqQueryDUnitTest cqDUnitTest = new CqQueryDUnitTest(
       "CqDataDUnitTest");
 
-  public CacheServerManagementDUnitTest(String name) {
-    super(name);
+  public CacheServerManagementDUnitTest() {
+    super();
     this.helper = new ManagementTestBase(name);
 
   }
@@ -80,6 +90,7 @@ public class CacheServerManagementDUnitTest extends LocatorTestBase {
   /**
    * @throws Exception
    */
+  @Test
   public void testCacheServerMBean() throws Exception {
     final Host host = Host.getHost(0);
     VM server = host.getVM(0);
@@ -145,6 +156,7 @@ public class CacheServerManagementDUnitTest extends LocatorTestBase {
    * @throws Exception
    */
 
+  @Test
   public void testCacheClient() throws Exception {
 
     final Host host = Host.getHost(0);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestCQDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestCQDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestCQDUnitTest.java
index 096b3c3..d101423 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestCQDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestCQDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.management.internal.pulse;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import com.gemstone.gemfire.cache.query.cq.dunit.CqQueryDUnitTest;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.management.DistributedSystemMXBean;
@@ -32,6 +41,7 @@ import com.gemstone.gemfire.test.dunit.WaitCriterion;
  * 
  */
 
+@Category(DistributedTest.class)
 public class TestCQDUnitTest extends ManagementTestBase {
 
   private static final long serialVersionUID = 1L;
@@ -41,8 +51,8 @@ public class TestCQDUnitTest extends ManagementTestBase {
   protected CqQueryDUnitTest cqDUnitTest = new CqQueryDUnitTest(
       "CqDataDUnitTest");
 
-  public TestCQDUnitTest(String name) {
-    super(name);
+  public TestCQDUnitTest() {
+    super();
   }
 
   public static long getNumOfCQ() {
@@ -71,6 +81,7 @@ public class TestCQDUnitTest extends ManagementTestBase {
     return bean.getActiveCQCount();
   }
 
+  @Test
   public void testNumOfCQ() throws Exception {
     initManagement(false);
     LogWriterUtils.getLogWriter().info("started testNumOfCQ");

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientsDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientsDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientsDUnitTest.java
index d15e0e0..c327b05 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientsDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientsDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.management.internal.pulse;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import com.gemstone.gemfire.cache.query.cq.dunit.CqQueryDUnitTest;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.management.DistributedSystemMXBean;
@@ -34,12 +43,13 @@ import com.gemstone.gemfire.test.dunit.WaitCriterion;
  * 
  */
 
+@Category(DistributedTest.class)
 public class TestClientsDUnitTest extends ManagementTestBase {
 
   private static final long serialVersionUID = 1L;
 
-  public TestClientsDUnitTest(String name) {
-    super(name);
+  public TestClientsDUnitTest() {
+    super();
   }
 
   public static Integer getNumOfClients() {
@@ -73,6 +83,7 @@ public class TestClientsDUnitTest extends ManagementTestBase {
   protected CqQueryDUnitTest cqDUnitTest = new CqQueryDUnitTest(
       "CqDataDUnitTest");
 
+  @Test
   public void testNumOfClients() throws Exception {
     initManagement(false);
     VM server = managedNodeList.get(1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestServerDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestServerDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestServerDUnitTest.java
index a40e6fe..eb3a468 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestServerDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestServerDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.management.internal.pulse;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import com.gemstone.gemfire.cache.query.cq.dunit.CqQueryDUnitTest;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.management.DistributedSystemMXBean;
@@ -31,12 +40,13 @@ import com.gemstone.gemfire.test.dunit.WaitCriterion;
  * 
  */
 
+@Category(DistributedTest.class)
 public class TestServerDUnitTest extends ManagementTestBase {
 
   private static final long serialVersionUID = 1L;
 
-  public TestServerDUnitTest(String name) {
-    super(name);
+  public TestServerDUnitTest() {
+    super();
   }
 
   public static int getNumOfServersFromMBean() {
@@ -69,6 +79,7 @@ public class TestServerDUnitTest extends ManagementTestBase {
   protected CqQueryDUnitTest cqDUnitTest = new CqQueryDUnitTest(
       "CqDataDUnitTest");
 
+  @Test
   public void testNumOfServersDUnitTest() throws Exception {
     initManagement(false);
     VM server = managedNodeList.get(1);    

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-wan/src/test/java/com/gemstone/gemfire/cache/CacheXml70GatewayDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/cache/CacheXml70GatewayDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/cache/CacheXml70GatewayDUnitTest.java
index 6badaa2..b827ae6 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/cache/CacheXml70GatewayDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/cache/CacheXml70GatewayDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.cache;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import java.util.Properties;
 import java.util.Set;
 
@@ -43,10 +52,11 @@ import com.gemstone.gemfire.internal.cache.xmlcache.RegionAttributesCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.SerialGatewaySenderCreation;
 import com.gemstone.gemfire.test.junit.categories.FlakyTest;
 
+@Category(DistributedTest.class)
 public class CacheXml70GatewayDUnitTest extends CacheXmlTestCase {
 
-  public CacheXml70GatewayDUnitTest(String name) {
-    super(name);
+  public CacheXml70GatewayDUnitTest() {
+    super();
   }
 
   protected String getGemFireVersion() {
@@ -56,6 +66,7 @@ public class CacheXml70GatewayDUnitTest extends CacheXmlTestCase {
   /**
    * Added to test the scenario of defect #50600.
    */
+  @Test
   public void testAsyncEventQueueWithGatewayEventFilter() {
     getSystem();
     CacheCreation cache = new CacheCreation();
@@ -91,6 +102,7 @@ public class CacheXml70GatewayDUnitTest extends CacheXmlTestCase {
   }
 
   @Category(FlakyTest.class) // GEODE-978: hardcoded port range, BindException
+  @Test
   public void testGatewayReceiver() throws Exception{
     getSystem();
     CacheCreation cache = new CacheCreation();
@@ -118,6 +130,7 @@ public class CacheXml70GatewayDUnitTest extends CacheXmlTestCase {
     }
   }
   
+  @Test
   public void testParallelGatewaySender() throws CacheException{
     getSystem();
     CacheCreation cache = new CacheCreation();
@@ -155,6 +168,7 @@ public class CacheXml70GatewayDUnitTest extends CacheXmlTestCase {
     }
   }
   
+  @Test
   public void testSerialGatewaySender() throws CacheException{
     getSystem();
     CacheCreation cache = new CacheCreation();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-wan/src/test/java/com/gemstone/gemfire/cache/CacheXml80GatewayDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/cache/CacheXml80GatewayDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/cache/CacheXml80GatewayDUnitTest.java
index 0619474..f229e0f 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/cache/CacheXml80GatewayDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/cache/CacheXml80GatewayDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.cache;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import java.io.IOException;
 import java.util.Properties;
 import java.util.Set;
@@ -27,16 +36,18 @@ import com.gemstone.gemfire.cache30.*;
 import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.CacheXml;
 
+@Category(DistributedTest.class)
 public class CacheXml80GatewayDUnitTest extends CacheXmlTestCase {
 
-  public CacheXml80GatewayDUnitTest(String name) {
-    super(name);
+  public CacheXml80GatewayDUnitTest() {
+    super();
   }
 
   protected String getGemFireVersion() {
     return CacheXml.VERSION_8_0;
   }
   
+  @Test
   public void testGatewayReceiverWithManualStartTRUE() throws CacheException{
     //getSystem();
     CacheCreation cache = new CacheCreation();
@@ -68,6 +79,7 @@ public class CacheXml80GatewayDUnitTest extends CacheXmlTestCase {
     }
   }
 
+  @Test
   public void testAsyncEventQueueWithSubstitutionFilter() {
     getSystem();
     CacheCreation cache = new CacheCreation();
@@ -91,6 +103,7 @@ public class CacheXml80GatewayDUnitTest extends CacheXmlTestCase {
     assertNotNull(queueOnCache.getGatewayEventSubstitutionFilter());
   }
 
+  @Test
   public void testGatewaySenderWithSubstitutionFilter() {
     getSystem();
     CacheCreation cache = new CacheCreation();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/UpdateVersionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/UpdateVersionDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/UpdateVersionDUnitTest.java
index 0e7e8d8..c4423ef 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/UpdateVersionDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/UpdateVersionDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import java.io.File;
 import java.io.IOException;
 import java.net.InetSocketAddress;
@@ -67,7 +76,8 @@ import com.gemstone.gemfire.test.dunit.WaitCriterion;
 /**
  * @since 7.0.1
  */
-public class UpdateVersionDUnitTest extends DistributedTestCase {
+@Category(DistributedTest.class)
+public class UpdateVersionDUnitTest extends JUnit4DistributedTestCase {
 
   protected static final String regionName = "testRegion";
   protected static Cache cache;
@@ -75,8 +85,8 @@ public class UpdateVersionDUnitTest extends DistributedTestCase {
 
   
   
-  public UpdateVersionDUnitTest(String name) {
-    super(name);
+  public UpdateVersionDUnitTest() {
+    super();
   }
   
   @Override
@@ -87,6 +97,7 @@ public class UpdateVersionDUnitTest extends DistributedTestCase {
      } });
   }
   
+  @Test
   public void testUpdateVersionAfterCreateWithSerialSender() {
 
     Host host = Host.getHost(0);
@@ -225,6 +236,7 @@ public class UpdateVersionDUnitTest extends DistributedTestCase {
     assertEquals("Local and remote site have different timestamps", tag.getVersionTimeStamp(), remoteTag.getVersionTimeStamp());
   }
 
+  @Test
   public void testUpdateVersionAfterCreateWithSerialSenderOnDR() {
 
     Host host = Host.getHost(0);
@@ -350,6 +362,7 @@ public class UpdateVersionDUnitTest extends DistributedTestCase {
     assertEquals("Local and remote site have different timestamps", tag.getVersionTimeStamp(), remoteTag.getVersionTimeStamp());
   }
 
+  @Test
   public void testUpdateVersionAfterCreateWithParallelSender() {
 
     Host host = Host.getHost(0);
@@ -489,6 +502,7 @@ public class UpdateVersionDUnitTest extends DistributedTestCase {
     assertEquals("Local and remote site have different timestamps", tag.getVersionTimeStamp(), remoteTag.getVersionTimeStamp());
   }
 
+  @Test
   public void testUpdateVersionAfterCreateWithConcurrentSerialSender() {
 
     Host host = Host.getHost(0);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/CacheClientNotifierDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/CacheClientNotifierDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/CacheClientNotifierDUnitTest.java
index 0b1cd11..06c9476 100755
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/CacheClientNotifierDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/CacheClientNotifierDUnitTest.java
@@ -15,6 +15,15 @@
  * limitations under the License.
  */
 package com.gemstone.gemfire.internal.cache.wan;
+
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
 import java.io.IOException;
 import java.util.List;
@@ -59,11 +68,12 @@ import com.gemstone.gemfire.test.dunit.WaitCriterion;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.test.junit.categories.FlakyTest;
 
+@Category(DistributedTest.class)
 public class CacheClientNotifierDUnitTest extends WANTestBase {
   private static final int NUM_KEYS = 10;
   
-  public CacheClientNotifierDUnitTest(String name) {
-    super(name);
+  public CacheClientNotifierDUnitTest() {
+    super();
     // TODO Auto-generated constructor stub
   }
 
@@ -174,6 +184,7 @@ public class CacheClientNotifierDUnitTest extends WANTestBase {
    * Shutdown them and verify the CacheClientNofifier for each server is correct
    */
   // GEODE-1183: random ports, failure to start threads, eats exceptions, time sensitive
+  @Test
   public void testNormalClient2MultipleCacheServer() throws Exception {
     doMultipleCacheServer(false);
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/Simple2CacheServerDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/Simple2CacheServerDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/Simple2CacheServerDUnitTest.java
index 2b7617d..1d4e947 100755
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/Simple2CacheServerDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/Simple2CacheServerDUnitTest.java
@@ -15,6 +15,15 @@
  * limitations under the License.
  */
 package com.gemstone.gemfire.internal.cache.wan;
+
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
 import java.util.Iterator;
 import java.util.List;
@@ -45,15 +54,17 @@ import com.gemstone.gemfire.internal.cache.ha.HAContainerRegion;
 import com.gemstone.gemfire.test.junit.categories.FlakyTest;
 import com.jayway.awaitility.Awaitility;
 
+@Category(DistributedTest.class)
 public class Simple2CacheServerDUnitTest extends WANTestBase {
   private static final int NUM_KEYS = 10;
   static int afterPrimaryCount = 0;
   static int afterProxyReinitialized = 0;
   
-  public Simple2CacheServerDUnitTest(String name) {
-    super(name);
+  public Simple2CacheServerDUnitTest() {
+    super();
   }
   
+  @Test
   public void testNormalClient2MultipleCacheServer() throws Exception {
     doMultipleCacheServer(false);
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f83cc548/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
index 09ec3e1..7ef9190 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.internal.cache.wan;
 
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 import java.io.File;
 import java.io.IOException;
 import java.io.Serializable;
@@ -127,7 +136,8 @@ import com.gemstone.gemfire.test.dunit.WaitCriterion;
 import com.gemstone.gemfire.util.test.TestUtil;
 import com.jayway.awaitility.Awaitility;
 
-public class WANTestBase extends DistributedTestCase{
+@Category(DistributedTest.class)
+public class WANTestBase extends JUnit4DistributedTestCase{
 
   protected static Cache cache;
   protected static Region region;
@@ -164,8 +174,8 @@ public class WANTestBase extends DistributedTestCase{
   //this will be set for each test method run with one of the values from above list
   protected static int numDispatcherThreadsForTheRun = 1;
 
-  public WANTestBase(String name) {
-    super(name);
+  public WANTestBase() {
+    super();
   }
 
   @Override