You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by hi...@apache.org on 2016/06/15 00:07:56 UTC

[40/94] [abbrv] [partial] incubator-geode git commit: GEODE-837: update tests from JUnit3 to JUnit4

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java
index 877c611..3794b37 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java
@@ -20,37 +20,62 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
+import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+import static org.junit.Assert.*;
+import static org.junit.Assume.*;
+
+import java.net.UnknownHostException;
+import java.util.Properties;
+import java.util.Set;
+
+import org.junit.Ignore;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.Operation;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.RegionFactory;
+import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.internal.DistributionAdvisor;
 import com.gemstone.gemfire.distributed.internal.DistributionManager;
 import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
 import com.gemstone.gemfire.distributed.internal.membership.NetMember;
-import com.gemstone.gemfire.internal.cache.*;
+import com.gemstone.gemfire.internal.cache.DistributedCacheOperation;
+import com.gemstone.gemfire.internal.cache.DistributedRegion;
+import com.gemstone.gemfire.internal.cache.EntryEventImpl;
+import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
+import com.gemstone.gemfire.internal.cache.InitialImageOperation;
+import com.gemstone.gemfire.internal.cache.LocalRegion;
+import com.gemstone.gemfire.internal.cache.RegionClearedException;
+import com.gemstone.gemfire.internal.cache.RegionEntry;
+import com.gemstone.gemfire.internal.cache.TombstoneService;
+import com.gemstone.gemfire.internal.cache.UpdateOperation;
+import com.gemstone.gemfire.internal.cache.VersionTagHolder;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
 import com.gemstone.gemfire.internal.cache.versions.VMVersionTag;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
 import com.gemstone.gemfire.internal.cache.vmotion.VMotionObserver;
 import com.gemstone.gemfire.internal.cache.vmotion.VMotionObserverHolder;
-import com.gemstone.gemfire.test.dunit.*;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.Wait;
+import com.gemstone.gemfire.test.dunit.WaitCriterion;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 import com.gemstone.gemfire.test.junit.categories.FlakyTest;
-import org.junit.experimental.categories.Category;
-
-import java.net.UnknownHostException;
-import java.util.Properties;
-import java.util.Set;
-
-import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 
+@Category(DistributedTest.class)
 public class DistributedAckRegionCCEDUnitTest extends DistributedAckRegionDUnitTest {
 
-  public DistributedAckRegionCCEDUnitTest(String name) {
-    super(name);
-  }
-  
+  @Override
   protected boolean supportsTransactions() {
     return true;
   }
-  
 
   @Override
   public Properties getDistributedSystemProperties() {
@@ -62,10 +87,10 @@ public class DistributedAckRegionCCEDUnitTest extends DistributedAckRegionDUnitT
     return p;
   }
 
-
   /**
    * Returns region attributes for a <code>GLOBAL</code> region
    */
+  @Override
   protected RegionAttributes getRegionAttributes() {
     AttributesFactory factory = new AttributesFactory();
     factory.setScope(Scope.DISTRIBUTED_ACK);
@@ -73,6 +98,8 @@ public class DistributedAckRegionCCEDUnitTest extends DistributedAckRegionDUnitT
     factory.setConcurrencyChecksEnabled(true);
     return factory.create();
   }
+
+  @Override
   protected RegionAttributes getRegionAttributes(String type) {
     RegionAttributes ra = getCache().getRegionAttributes(type);
     if (ra == null) {
@@ -84,44 +111,37 @@ public class DistributedAckRegionCCEDUnitTest extends DistributedAckRegionDUnitT
     return factory.create();
   }
 
+  @Ignore("replicates don't allow local destroy")
   @Override
+  @Test
   public void testLocalDestroy() throws InterruptedException {
     // replicates don't allow local destroy
   }
 
-//  public void testRepeatedClearWithConcurrentEvents() throws Exception {
-//    for (int i=0; i<50; i++) {
-//      getLogWriter().info("running test #"+i);
-//      z_versionTestClearWithConcurrentEvents(true);
-//      tearDown();
-//      setUp();
-//    }
-//  }
-
-
+  @Ignore("replicates don't allow local destroy")
   @Override
+  @Test
   public void testEntryTtlLocalDestroy() throws InterruptedException {
     // replicates don't allow local destroy
   }
 
-  
   /**
    * This test creates a server cache in vm0 and a peer cache in vm1.
    * It then tests to see if GII transferred tombstones to vm1 like it's supposed to.
    * A client cache is created in vm2 and the same sort of check is performed
    * for register-interest.
    */
-
+  @Test
   public void testGIISendsTombstones() throws Exception {
     versionTestGIISendsTombstones();
   }
 
-
   /**
    * test for bug #45564.  a create() is received by region creator and then
    * a later destroy() is received in initial image and while the version info
    * from the destroy is recorded we keep the value from the create event
    */
+  @Test
   public void testConcurrentOpWithGII() {
     if (this.getClass() != DistributedAckRegionCCEDUnitTest.class) {
       return; // not really a scope-related thing
@@ -238,7 +258,6 @@ public class DistributedAckRegionCCEDUnitTest extends DistributedAckRegionDUnitT
     }
   }  
 
-  
   protected void do_version_recovery_if_necessary(final VM vm0, final VM vm1, final VM vm2, final Object[] params) {
     // do nothing here
   }
@@ -247,24 +266,30 @@ public class DistributedAckRegionCCEDUnitTest extends DistributedAckRegionDUnitT
    * This tests the concurrency versioning system to ensure that event conflation
    * happens correctly and that the statistic is being updated properly
    */
+  @Test
   public void testConcurrentEvents() throws Exception {
     versionTestConcurrentEvents();
   }
   
   @Category(FlakyTest.class) // GEODE-720: time sensitive, async actions, thread sleeps
+  @Test
   public void testClearWithConcurrentEvents() throws Exception {
     z_versionTestClearWithConcurrentEvents(true);
   }
 
   @Category(FlakyTest.class) // GEODE-599 and GEODE-1046: async actions, thread sleeps -- // GEODE-1046: this may be hitting a product bug!
+  @Test
   public void testClearWithConcurrentEventsAsync() throws Exception {
     versionTestClearWithConcurrentEventsAsync();
   }
 
+  @Category(FlakyTest.class) // bug #45704
+  @Test
   public void testClearOnNonReplicateWithConcurrentEvents() throws Exception {
     versionTestClearOnNonReplicateWithConcurrentEvents();
   }
 
+  @Test
   public void testTombstones() {
     versionTestTombstones();
   }
@@ -274,6 +299,7 @@ public class DistributedAckRegionCCEDUnitTest extends DistributedAckRegionDUnitT
    * a tombstone has been reaped is accepted by another member that has yet to
    * reap the tombstone
    */
+  @Test
   public void testTombstoneExpirationRace() {
     VM vm0 = Host.getHost(0).getVM(0);
     VM vm1 = Host.getHost(0).getVM(1);
@@ -330,17 +356,15 @@ public class DistributedAckRegionCCEDUnitTest extends DistributedAckRegionDUnitT
       });
     disconnectAllFromDS();
   }
-  
-  
 
   /**
    * Test for bug #46087 and #46089 where the waiting thread pool is flooded with
    * threads performing distributed-GC.  This could be moved to a JUnit test class.
    */
+  @Test
   public void testAggressiveTombstoneReaping() {
-    if (this.getClass() != DistributedAckRegionCCEDUnitTest.class) {
-      return; // not really a scope-related thing
-    }
+    assumeTrue(getClass() == DistributedAckRegionCCEDUnitTest.class);
+
     final String name = this.getUniqueName() + "-CC";
 
 
@@ -380,40 +404,33 @@ public class DistributedAckRegionCCEDUnitTest extends DistributedAckRegionDUnitT
     }
   }
 
-  
-  
-  
-  
-  
   /**
    * This tests the concurrency versioning system to ensure that event conflation
    * happens correctly and that the statistic is being updated properly
    */
+  @Test
   public void testConcurrentEventsOnEmptyRegion() {
     versionTestConcurrentEventsOnEmptyRegion();
   }
-  
-  
-  
-  
+
   /**
    * This tests the concurrency versioning system to ensure that event conflation
    * happens correctly and that the statistic is being updated properly
    */
+  @Test
   public void testConcurrentEventsOnNonReplicatedRegion() {
     versionTestConcurrentEventsOnNonReplicatedRegion();
   }
-  
-  
+
+  @Test
   public void testGetAllWithVersions() {
     versionTestGetAllWithVersions();
   }
 
-  
+  @Test
   public void testEntryVersionRollover() throws Exception {
-    if (this.getClass() != DistributedAckRegionCCEDUnitTest.class) {
-      return;
-    }
+    assumeTrue(getClass() == DistributedAckRegionCCEDUnitTest.class);
+
     final String name = this.getUniqueName() + "-CC";
     final int numEntries = 1;
     SerializableRunnable createRegion = new SerializableRunnable("Create Region") {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEOffHeapDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEOffHeapDUnitTest.java
index e766a49..739da00 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEOffHeapDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEOffHeapDUnitTest.java
@@ -16,14 +16,18 @@
  */
 package com.gemstone.gemfire.cache30;
 
+import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+
+import java.util.Properties;
+
+import org.junit.experimental.categories.Category;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
 import com.gemstone.gemfire.test.dunit.Invoke;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
-
-import java.util.Properties;
-import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
 /**
  * Tests Distributed Ack Region with ConcurrencyChecksEnabled and OffHeap memory.
@@ -31,12 +35,9 @@ import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties
  * @since Geode 1.0
  */
 @SuppressWarnings({ "deprecation", "serial" })
+@Category(DistributedTest.class)
 public class DistributedAckRegionCCEOffHeapDUnitTest extends DistributedAckRegionCCEDUnitTest {
 
-  public DistributedAckRegionCCEOffHeapDUnitTest(String name) {
-    super(name);
-  }
-  
   @Override
   public final void preTearDownAssertions() throws Exception {
     SerializableRunnable checkOrphans = new SerializableRunnable() {
@@ -59,8 +60,8 @@ public class DistributedAckRegionCCEOffHeapDUnitTest extends DistributedAckRegio
     return props;
   }
   
-  @SuppressWarnings({ "rawtypes", "unchecked" })
   @Override
+  @SuppressWarnings({ "rawtypes", "unchecked" })
   protected RegionAttributes getRegionAttributes() {
     RegionAttributes attrs = super.getRegionAttributes();
     AttributesFactory factory = new AttributesFactory(attrs);
@@ -68,8 +69,8 @@ public class DistributedAckRegionCCEOffHeapDUnitTest extends DistributedAckRegio
     return factory.create();
   }
   
-  @SuppressWarnings({ "rawtypes", "unchecked" })
   @Override
+  @SuppressWarnings({ "rawtypes", "unchecked" })
   protected RegionAttributes getRegionAttributes(String type) {
     RegionAttributes ra = super.getRegionAttributes(type);
     AttributesFactory factory = new AttributesFactory(ra);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCompressionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCompressionDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCompressionDUnitTest.java
index b4517a9..f50a30e 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCompressionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCompressionDUnitTest.java
@@ -16,25 +16,23 @@
  */
 package com.gemstone.gemfire.cache30;
 
+import org.junit.experimental.categories.Category;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.compression.Compressor;
 import com.gemstone.gemfire.compression.SnappyCompressor;
-import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
 /**
  * Tests Distributed Ack Region with compression.
  * 
  * @since GemFire 8.0
  */
+@Category(DistributedTest.class)
 @SuppressWarnings({ "deprecation", "serial" })
-public class DistributedAckRegionCompressionDUnitTest extends
-    DistributedAckRegionDUnitTest {
+public class DistributedAckRegionCompressionDUnitTest extends DistributedAckRegionDUnitTest {
   
-  public DistributedAckRegionCompressionDUnitTest(String name) {
-    super(name);
-  }
-
   @SuppressWarnings({ "rawtypes", "unchecked" })
   @Override
   protected RegionAttributes getRegionAttributes() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionDUnitTest.java
index 1587179..48a97c9 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionDUnitTest.java
@@ -17,24 +17,35 @@
 package com.gemstone.gemfire.cache30;
 
 import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
-
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.test.dunit.*;
+import static org.junit.Assert.*;
 
 import java.util.Properties;
 
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.test.dunit.Assert;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.LogWriterUtils;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
 /**
  * This class tests the functionality of a cache {@link Region region}
  * that has a scope of {@link Scope#DISTRIBUTED_ACK distributed ACK}.
  *
  * @since GemFire 3.0
  */
+@Category(DistributedTest.class)
 public class DistributedAckRegionDUnitTest extends MultiVMRegionTestCase {
 
-  public DistributedAckRegionDUnitTest(String name) {
-    super(name);
-  }
-
   /**
    * Returns region attributes for a <code>GLOBAL</code> region
    */
@@ -54,14 +65,13 @@ public class DistributedAckRegionDUnitTest extends MultiVMRegionTestCase {
     return p;
   }
 
-  //////////////////////  Test Methods  //////////////////////
-
   /**
    * Tests the compatibility of creating certain kinds of subregions
    * of a local region.
    *
    * @see Region#createSubregion
    */
+  @Test
   public void testIncompatibleSubregions()
     throws CacheException, InterruptedException {
 
@@ -122,7 +132,4 @@ public class DistributedAckRegionDUnitTest extends MultiVMRegionTestCase {
         }
       });
   } 
-  
-
-  
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionOffHeapDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionOffHeapDUnitTest.java
index 89b32d5..388a6e3 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionOffHeapDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionOffHeapDUnitTest.java
@@ -16,28 +16,28 @@
  */
 package com.gemstone.gemfire.cache30;
 
+import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+
+import java.util.Properties;
+
+import org.junit.experimental.categories.Category;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
 import com.gemstone.gemfire.test.dunit.Invoke;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
-
-import java.util.Properties;
-
-import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
 /**
  * Tests Distributed Ack Region with OffHeap memory.
  * 
  * @since Geode 1.0
  */
+@Category(DistributedTest.class)
 @SuppressWarnings({ "deprecation", "serial" })
 public class DistributedAckRegionOffHeapDUnitTest extends DistributedAckRegionDUnitTest {
 
-  public DistributedAckRegionOffHeapDUnitTest(String name) {
-    super(name);
-  }
-  
   @Override
   public final void preTearDownAssertions() throws Exception {
     SerializableRunnable checkOrphans = new SerializableRunnable() {
@@ -60,8 +60,8 @@ public class DistributedAckRegionOffHeapDUnitTest extends DistributedAckRegionDU
     return props;
   }
   
-  @SuppressWarnings({ "rawtypes", "unchecked" })
   @Override
+  @SuppressWarnings({ "rawtypes", "unchecked" })
   protected RegionAttributes getRegionAttributes() {
     RegionAttributes attrs = super.getRegionAttributes();
     AttributesFactory factory = new AttributesFactory(attrs);
@@ -69,8 +69,8 @@ public class DistributedAckRegionOffHeapDUnitTest extends DistributedAckRegionDU
     return factory.create();
   }
   
-  @SuppressWarnings({ "rawtypes", "unchecked" })
   @Override
+  @SuppressWarnings({ "rawtypes", "unchecked" })
   protected RegionAttributes getRegionAttributes(String type) {
     RegionAttributes ra = super.getRegionAttributes(type);
     AttributesFactory factory = new AttributesFactory(ra);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedMulticastRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedMulticastRegionDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedMulticastRegionDUnitTest.java
index a2bee79..5776158 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedMulticastRegionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedMulticastRegionDUnitTest.java
@@ -16,7 +16,22 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
+import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+import static org.junit.Assert.*;
+
+import java.io.File;
+import java.io.IOException;
+import java.util.Properties;
+
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.Locator;
 import com.gemstone.gemfire.distributed.internal.InternalLocator;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
@@ -25,15 +40,16 @@ import com.gemstone.gemfire.pdx.PdxReader;
 import com.gemstone.gemfire.pdx.PdxSerializable;
 import com.gemstone.gemfire.pdx.PdxSerializationException;
 import com.gemstone.gemfire.pdx.PdxWriter;
-import com.gemstone.gemfire.test.dunit.*;
-
-import java.io.File;
-import java.io.IOException;
-import java.util.Properties;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.Invoke;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
-import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
-
-public class DistributedMulticastRegionDUnitTest extends CacheTestCase {
+@Category(DistributedTest.class)
+public class DistributedMulticastRegionDUnitTest extends JUnit4CacheTestCase {
 
   static int locatorVM = 3;
   static String mcastport = "42786";
@@ -41,10 +57,6 @@ public class DistributedMulticastRegionDUnitTest extends CacheTestCase {
   
   private int locatorPort;
 
-  public DistributedMulticastRegionDUnitTest(String name) {
-    super(name);
-  }
-  
   @Override
   public final void preSetUp() throws Exception {
     clean();
@@ -65,6 +77,7 @@ public class DistributedMulticastRegionDUnitTest extends CacheTestCase {
     Invoke.invokeInEveryVM(cleanVM);    
   }
   
+  @Test
   public void testMulticastEnabled() {
     final String name = "mcastRegion";
     SerializableRunnable create =
@@ -120,7 +133,7 @@ public class DistributedMulticastRegionDUnitTest extends CacheTestCase {
       closeLocator();      
   }
   
-  public class TestObjectThrowsException implements PdxSerializable {
+  private static class TestObjectThrowsException implements PdxSerializable {
     String name = "TestObjectThrowsException";
 
     @Override
@@ -130,12 +143,11 @@ public class DistributedMulticastRegionDUnitTest extends CacheTestCase {
 
     @Override
     public void fromData(PdxReader reader) {
-      throw new RuntimeException("Unable to desrialize message ");
-      //name = reader.readString("name");
+      throw new RuntimeException("Unable to deserialize message ");
     }
-    
   }
   
+  @Test
   public void testMulticastWithRegionOpsException() {
     Host host = Host.getHost(0);
     final VM vm0 = host.getVM(0);
@@ -260,30 +272,30 @@ public class DistributedMulticastRegionDUnitTest extends CacheTestCase {
   }
   
   private int startLocator() {
-  final int [] ports = AvailablePortHelper.getRandomAvailableTCPPorts(3);
-  final int locatorPort = ports[0];
-  
-  VM locator1Vm = Host.getHost(0).getVM(locatorVM);;
-    locator1Vm.invoke(new SerializableCallable() {
-      @Override
-      public Object call() {
-        final File locatorLogFile = new File(getTestMethodName() + "-locator-" + locatorPort + ".log");
-        final Properties locatorProps = new Properties();
-        locatorProps.setProperty(NAME, "LocatorWithMcast");
-        locatorProps.setProperty(MCAST_PORT, mcastport);
-        locatorProps.setProperty(MCAST_TTL, mcastttl);
-        locatorProps.setProperty(LOG_LEVEL, "info");
-        //locatorProps.setProperty(DistributionConfig.ENABLE_CLUSTER_CONFIGURATION_NAME, "true");
-        try {
-          final InternalLocator locator = (InternalLocator) Locator.startLocatorAndDS(locatorPort, null, null,
-              locatorProps);
-          System.out.println("test Locator started " + locatorPort);
-           } catch (IOException ioex) {
-          fail("Unable to create a locator with a shared configuration");
+    final int [] ports = AvailablePortHelper.getRandomAvailableTCPPorts(3);
+    final int locatorPort = ports[0];
+
+    VM locator1Vm = Host.getHost(0).getVM(locatorVM);
+      locator1Vm.invoke(new SerializableCallable() {
+        @Override
+        public Object call() {
+          final File locatorLogFile = new File(getTestMethodName() + "-locator-" + locatorPort + ".log");
+          final Properties locatorProps = new Properties();
+          locatorProps.setProperty(NAME, "LocatorWithMcast");
+          locatorProps.setProperty(MCAST_PORT, mcastport);
+          locatorProps.setProperty(MCAST_TTL, mcastttl);
+          locatorProps.setProperty(LOG_LEVEL, "info");
+          //locatorProps.setProperty(DistributionConfig.ENABLE_CLUSTER_CONFIGURATION_NAME, "true");
+          try {
+            final InternalLocator locator = (InternalLocator) Locator.startLocatorAndDS(locatorPort, null, null,
+                locatorProps);
+            System.out.println("test Locator started " + locatorPort);
+             } catch (IOException ioex) {
+            fail("Unable to create a locator with a shared configuration");
+          }
+
+          return null;
         }
-  
-        return null;
-      }
     });
     return locatorPort;
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEDUnitTest.java
index 35660a6..8720fcc 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEDUnitTest.java
@@ -16,27 +16,43 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.test.dunit.*;
-import com.gemstone.gemfire.test.junit.categories.FlakyTest;
-import org.junit.experimental.categories.Category;
+import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+import static org.junit.Assert.*;
 
 import java.util.Map;
 import java.util.Properties;
 
-import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
 
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheListener;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.EntryNotFoundException;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.RegionFactory;
+import com.gemstone.gemfire.cache.RegionShortcut;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.internal.cache.LocalRegion;
+import com.gemstone.gemfire.test.dunit.Assert;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.LogWriterUtils;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.Wait;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+import com.gemstone.gemfire.test.junit.categories.FlakyTest;
+
+@Category(DistributedTest.class)
 public class DistributedNoAckRegionCCEDUnitTest extends DistributedNoAckRegionDUnitTest {
   
   static volatile boolean ListenerBlocking;
 
-  public DistributedNoAckRegionCCEDUnitTest(String name) {
-    super(name);
-  }
-
   @Override
   public Properties getDistributedSystemProperties() {
     Properties p = super.getDistributedSystemProperties();
@@ -48,7 +64,6 @@ public class DistributedNoAckRegionCCEDUnitTest extends DistributedNoAckRegionDU
     return p;
   }
 
-
   /**
    * Returns region attributes for a <code>GLOBAL</code> region
    */
@@ -84,15 +99,18 @@ public class DistributedNoAckRegionCCEDUnitTest extends DistributedNoAckRegionDU
 
 
   @Override
+  @Test
   public void testLocalDestroy() throws InterruptedException {
     // replicates don't allow local destroy
   }
 
   @Override
+  @Test
   public void testEntryTtlLocalDestroy() throws InterruptedException {
     // replicates don't allow local destroy
   }
 
+  @Test
   public void testClearWithManyEventsInFlight() throws Exception {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0);
@@ -224,6 +242,7 @@ public class DistributedNoAckRegionCCEDUnitTest extends DistributedNoAckRegionDU
    * for register-interest.
    */
 
+  @Test
   public void testGIISendsTombstones() throws Exception {
     versionTestGIISendsTombstones();
   }
@@ -237,24 +256,29 @@ public class DistributedNoAckRegionCCEDUnitTest extends DistributedNoAckRegionDU
    * This tests the concurrency versioning system to ensure that event conflation
    * happens correctly and that the statistic is being updated properly
    */
+  @Test
   public void testConcurrentEvents() throws Exception {
     versionTestConcurrentEvents();
   }
   
   
+  @Test
   public void testClearWithConcurrentEvents() throws Exception {
     // need to figure out how to flush clear() ops for verification steps
   }
 
+  @Test
   public void testClearWithConcurrentEventsAsync() throws Exception {
     // need to figure out how to flush clear() ops for verification steps
   }
 
+  @Test
   public void testClearOnNonReplicateWithConcurrentEvents() throws Exception {
     // need to figure out how to flush clear() ops for verification steps
   }
   
   
+  @Test
   public void testTombstones() throws Exception {
 //    for (int i=0; i<1000; i++) {
 //      System.out.println("starting run #"+i);
@@ -272,6 +296,7 @@ public class DistributedNoAckRegionCCEDUnitTest extends DistributedNoAckRegionDU
   
   
   
+  @Test
   public void testOneHopKnownIssues() {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0);
@@ -349,6 +374,7 @@ public class DistributedNoAckRegionCCEDUnitTest extends DistributedNoAckRegionDU
    * happens correctly and that the statistic is being updated properly
    */
   @Category(FlakyTest.class) // GEODE-976: time sensitive, thread sleeps, relies on stat values
+  @Test
   public void testConcurrentEventsOnEmptyRegion() {
     versionTestConcurrentEventsOnEmptyRegion();
   }
@@ -357,11 +383,13 @@ public class DistributedNoAckRegionCCEDUnitTest extends DistributedNoAckRegionDU
    * This tests the concurrency versioning system to ensure that event conflation
    * happens correctly and that the statistic is being updated properly
    */
+  @Test
   public void testConcurrentEventsOnNonReplicatedRegion() {
     versionTestConcurrentEventsOnNonReplicatedRegion();
   }
   
   
+  @Test
   public void testGetAllWithVersions() {
     versionTestGetAllWithVersions();
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEOffHeapDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEOffHeapDUnitTest.java
index 9980e56..c871632 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEOffHeapDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEOffHeapDUnitTest.java
@@ -16,28 +16,28 @@
  */
 package com.gemstone.gemfire.cache30;
 
+import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+
+import java.util.Properties;
+
+import org.junit.experimental.categories.Category;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
 import com.gemstone.gemfire.test.dunit.Invoke;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
-
-import java.util.Properties;
-
-import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
 /**
  * Tests Distributed Ack Region with ConcurrencyChecksEnabled and OffHeap memory.
  * 
  * @since Geode 1.0
  */
+@Category(DistributedTest.class)
 @SuppressWarnings({ "deprecation", "serial" })
 public class DistributedNoAckRegionCCEOffHeapDUnitTest extends DistributedNoAckRegionCCEDUnitTest {
 
-  public DistributedNoAckRegionCCEOffHeapDUnitTest(String name) {
-    super(name);
-  }
-  
   @Override
   public final void preTearDownAssertions() throws Exception {
     SerializableRunnable checkOrphans = new SerializableRunnable() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionDUnitTest.java
index 454d0ce..aecce60 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionDUnitTest.java
@@ -16,9 +16,15 @@
  */
 package com.gemstone.gemfire.cache30;
 
+import static org.junit.Assert.*;
+
 import java.util.Arrays;
 import java.util.Set;
 
+import org.junit.Ignore;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.CacheException;
 import com.gemstone.gemfire.cache.DataPolicy;
@@ -37,6 +43,7 @@ import com.gemstone.gemfire.test.dunit.ThreadUtils;
 import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.test.dunit.Wait;
 import com.gemstone.gemfire.test.dunit.WaitCriterion;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
 /**
  * This class tests the functionality of a cache {@link Region region}
@@ -45,12 +52,9 @@ import com.gemstone.gemfire.test.dunit.WaitCriterion;
  *
  * @since GemFire 3.0
  */
+@Category(DistributedTest.class)
 public class DistributedNoAckRegionDUnitTest extends MultiVMRegionTestCase {
 
-  public DistributedNoAckRegionDUnitTest(String name) {
-    super(name);
-  }
-
   /**
    * Returns region attributes for a <code>GLOBAL</code> region
    */
@@ -62,12 +66,12 @@ public class DistributedNoAckRegionDUnitTest extends MultiVMRegionTestCase {
     return factory.create();
   }
 
-  //////////////////////  Test Methods  //////////////////////
-
-  /** Tests creating a distributed subregion of a local scope region,
+  /**
+   * Tests creating a distributed subregion of a local scope region,
    * which should fail.
    */
-  public void testDistSubregionOfLocalRegion() throws CacheException {
+  @Test
+  public void testDistSubregionOfLocalRegion() throws Exception {
     // creating a distributed subregion of a LOCAL region is illegal.
     AttributesFactory factory = new AttributesFactory();
     factory.setScope(Scope.LOCAL);
@@ -87,8 +91,8 @@ public class DistributedNoAckRegionDUnitTest extends MultiVMRegionTestCase {
    *
    * @see Region#createSubregion
    */
-  public void testIncompatibleSubregions()
-    throws CacheException, InterruptedException {
+  @Test
+  public void testIncompatibleSubregions() throws Exception {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0);
     VM vm1 = host.getVM(1);
@@ -121,17 +125,16 @@ public class DistributedNoAckRegionDUnitTest extends MultiVMRegionTestCase {
             try {
               createRootRegion( "INCOMPATIBLE_ROOT", factory.create());
               fail("Should have thrown an IllegalStateException");
-//              createRegion(name, factory.create());
             } catch (IllegalStateException ex) {
               // pass...
             }
-//            assertNull(getRootRegion());
 
           } catch (CacheException ex) {
             Assert.fail("While creating GLOBAL Region", ex);
           }
         }
       });
+
     vm1.invoke(new SerializableRunnable("Create ACK Region") {
         public void run() {
           try {
@@ -142,11 +145,9 @@ public class DistributedNoAckRegionDUnitTest extends MultiVMRegionTestCase {
             try {
               createRootRegion( "INCOMPATIBLE_ROOT", factory.create());
               fail("Should have thrown an IllegalStateException");
-//              createRegion(name, factory.create());
             } catch (IllegalStateException ex) {
               // pass...
             }
-//            assertNull(getRootRegion());
 
           } catch (CacheException ex) {
             Assert.fail("While creating ACK Region", ex);
@@ -156,6 +157,7 @@ public class DistributedNoAckRegionDUnitTest extends MultiVMRegionTestCase {
   }
 
   private static final int CHUNK_SIZE = 500 * 1024; // == InitialImageOperation.CHUNK_SIZE_IN_BYTES
+
   // use sizes so it completes in < 15 sec, but hangs if bug exists
   private static final int NUM_ENTRIES_VM = 15000;
   private static final int VALUE_SIZE_VM = CHUNK_SIZE * 150 / NUM_ENTRIES_VM;
@@ -170,7 +172,9 @@ public class DistributedNoAckRegionDUnitTest extends MultiVMRegionTestCase {
    * and GII is now non-blocking (bug 30705 was caused blocking gii).
    * This test can take a long time to run on disk regions.
    */
-  public void disabled_testBug30705() throws InterruptedException {    
+  @Ignore("TODO")
+  @Test
+  public void testBug30705() throws Exception {
     final String name = this.getUniqueName();
     final int numEntries = NUM_ENTRIES_VM;
     final int valueSize = VALUE_SIZE_VM;
@@ -213,7 +217,6 @@ public class DistributedNoAckRegionDUnitTest extends MultiVMRegionTestCase {
         }
     };
 
-
     vm0.invoke(create);
 
     vm0.invoke(new CacheSerializableRunnable("Put data") {
@@ -263,12 +266,6 @@ public class DistributedNoAckRegionDUnitTest extends MultiVMRegionTestCase {
             }
           };
           Wait.waitForCriterion(ev, 30 * 1000, 200, true);
-//          pause(100);
-//           try {
-//             getRootRegion().getSubregion(name).destroyRegion();
-//           } catch (OperationAbortedException ignore) {
-//           }
-//           closeCache();
         }
        });
     } // finally
@@ -297,13 +294,13 @@ public class DistributedNoAckRegionDUnitTest extends MultiVMRegionTestCase {
 
   /**
    * The number of milliseconds to try repeating validation code in the
-   * event that AssertionFailedError is thrown.  For DISTRIBUTED_NO_ACK 
+   * event that AssertionError is thrown.  For DISTRIBUTED_NO_ACK
    * scopes, a repeat timeout is used to account for the fact that a
    * previous operation may have not yet completed.
    */
   @Override
   protected long getRepeatTimeoutMs() {
-    return 5000;
+    return 120*1000;
   }
   
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionOffHeapDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionOffHeapDUnitTest.java
index 73f5201..b74956c 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionOffHeapDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionOffHeapDUnitTest.java
@@ -16,25 +16,30 @@
  */
 package com.gemstone.gemfire.cache30;
 
+import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+
+import java.util.Properties;
+
+import org.junit.experimental.categories.Category;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
 import com.gemstone.gemfire.test.dunit.Invoke;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
-import java.util.Properties;
-
-import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 /**
  * Tests Distributed NoAck Region with OffHeap memory.
  * 
  * @since Geode 1.0
  */
 @SuppressWarnings({ "deprecation", "serial" })
+@Category(DistributedTest.class)
 public class DistributedNoAckRegionOffHeapDUnitTest extends DistributedNoAckRegionDUnitTest {
 
-  public DistributedNoAckRegionOffHeapDUnitTest(String name) {
-    super(name);
+  public DistributedNoAckRegionOffHeapDUnitTest() {
+    super();
   }
   
   @Override

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/DynamicRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DynamicRegionDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DynamicRegionDUnitTest.java
index 472546f..046df3d 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DynamicRegionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DynamicRegionDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.cache30;
 
+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.Properties;
 
@@ -40,12 +49,13 @@ import com.gemstone.gemfire.test.dunit.VM;
  *
  * @since GemFire 4.3
  */
-public class DynamicRegionDUnitTest extends CacheTestCase {
+@Category(DistributedTest.class)
+public class DynamicRegionDUnitTest extends JUnit4CacheTestCase {
 
   // Specify oplog size in MB
   private static final int OPLOG_SIZE = 1;
-  public DynamicRegionDUnitTest(String name) {
-    super(name);
+  public DynamicRegionDUnitTest() {
+    super();
   }
 
   // this test has special config of its distributed system so
@@ -215,6 +225,7 @@ public class DynamicRegionDUnitTest extends CacheTestCase {
   /**
    * Make sure dynamic regions work on peers
    */
+  @Test
   public void testPeerRegion() {
     assertEquals(true, DynamicRegionFactory.get().isOpen());
     createParentRegion("parent", true);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalLockingDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalLockingDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalLockingDUnitTest.java
index 0830b7e..09b1613 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalLockingDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalLockingDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.cache30;
 
+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.concurrent.locks.Lock;
 
 import com.gemstone.gemfire.cache.AttributesFactory;
@@ -35,12 +44,13 @@ import com.gemstone.gemfire.test.dunit.VM;
 /**
  * This class tests distributed locking of global region entries.
  */
-public class GlobalLockingDUnitTest extends CacheTestCase {
+@Category(DistributedTest.class)
+public class GlobalLockingDUnitTest extends JUnit4CacheTestCase {
 
   public static Region region_testBug32356;
   
-  public GlobalLockingDUnitTest(String name) {
-    super(name);
+  public GlobalLockingDUnitTest() {
+    super();
   }
 
   /**
@@ -71,6 +81,7 @@ public class GlobalLockingDUnitTest extends CacheTestCase {
   /** 
    * Tests for 32356 R2 tryLock w/ 0 timeout broken in Distributed Lock Service
    */
+  @Test
   public void testBug32356() throws Exception {
     LogWriterUtils.getLogWriter().fine("[testBug32356]");
     Host host = Host.getHost(0);
@@ -107,6 +118,7 @@ public class GlobalLockingDUnitTest extends CacheTestCase {
     }
   }
 
+  @Test
   public void testNonGlobalRegion() throws CacheException {
     String name = this.getUniqueName();
     AttributesFactory factory = new AttributesFactory(getGlobalAttrs());
@@ -136,6 +148,7 @@ public class GlobalLockingDUnitTest extends CacheTestCase {
     }
   }
 
+  @Test
   public void testSingleVMLockUnlock() throws CacheException {
     String name = this.getUniqueName() + "-GLOBAL";
     Region region = getOrCreateRootRegion().createSubregion(name, getGlobalAttrs());
@@ -145,6 +158,7 @@ public class GlobalLockingDUnitTest extends CacheTestCase {
     lock.unlock();
   }
   
+  @Test
   public void testIsLockGrantorAttribute() throws Exception {
     String name = this.getUniqueName() + "-testIsLockGrantorAttribute";
     AttributesFactory factory = new AttributesFactory(getGlobalAttrs());
@@ -161,6 +175,7 @@ public class GlobalLockingDUnitTest extends CacheTestCase {
   /**
    * Get the lock in one VM, try to create in other
    */
+  @Test
   public void testCreateLockTimeout() {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0);
@@ -193,6 +208,7 @@ public class GlobalLockingDUnitTest extends CacheTestCase {
   /**
    * get the lock in one VM, try to put() in other
    */
+  @Test
   public void testPutLockTimeout() {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0);
@@ -224,6 +240,7 @@ public class GlobalLockingDUnitTest extends CacheTestCase {
   /**
    * get lock in one VM, try to invoke loader in other
    */
+  @Test
   public void testLoadLockTimeout() {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0);
@@ -265,6 +282,7 @@ public class GlobalLockingDUnitTest extends CacheTestCase {
   /**
    * get lock in one VM, try to invalidate in other
    */
+  @Test
   public void testInvalidateLockTimeout() {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0);
@@ -296,6 +314,7 @@ public class GlobalLockingDUnitTest extends CacheTestCase {
   /**
    * get lock in one VM, try to destroy in other
    */
+  @Test
   public void testDestroyLockTimeout() {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0);
@@ -329,6 +348,7 @@ public class GlobalLockingDUnitTest extends CacheTestCase {
   /**
    * get the lock, region.get(), region.put(), release lock
    */
+  @Test
   public void testLockGetPut() throws CacheException {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0);
@@ -379,6 +399,7 @@ public class GlobalLockingDUnitTest extends CacheTestCase {
   /**
    * Test Region.getRegionDistributedLock(), calling lock() and then unlock()
    */
+  @Test
   public void testRegionDistributedLockSimple() throws CacheException
   {
     final String name = this.getUniqueName();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEDUnitTest.java
index deefac4..9a8f0e0 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEDUnitTest.java
@@ -20,7 +20,21 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
+import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+import static org.junit.Assert.*;
+
+import java.util.Properties;
+
+import org.junit.Ignore;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.RegionFactory;
+import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.RegionClearedException;
 import com.gemstone.gemfire.internal.cache.RegionEntry;
@@ -30,27 +44,16 @@ import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
-import org.junit.Ignore;
-
-import java.util.Properties;
-
-import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
 /**
  * This test is only for GLOBAL REPLICATE Regions. Tests are
  * similar to {@link DistributedAckRegionCCEDUnitTest}.
- *
- * 
  */
+@Category(DistributedTest.class)
 public class GlobalRegionCCEDUnitTest extends GlobalRegionDUnitTest {
 
-  /**
-   * @param name
-   */
-  public GlobalRegionCCEDUnitTest(String name) {
-    super(name);
-  }
-
+  @Override
   protected boolean supportsTransactions() {
     return true;
   }
@@ -69,6 +72,7 @@ public class GlobalRegionCCEDUnitTest extends GlobalRegionDUnitTest {
   /**
    * Returns region attributes for a <code>GLOBAL</code> region
    */
+  @Override
   protected RegionAttributes getRegionAttributes() {
     AttributesFactory factory = new AttributesFactory();
     factory.setScope(Scope.GLOBAL);
@@ -77,6 +81,7 @@ public class GlobalRegionCCEDUnitTest extends GlobalRegionDUnitTest {
     return factory.create();
   }
 
+  @Override
   protected RegionAttributes getRegionAttributes(String type) {
     RegionAttributes ra = getCache().getRegionAttributes(type);
     if (ra == null) {
@@ -89,12 +94,16 @@ public class GlobalRegionCCEDUnitTest extends GlobalRegionDUnitTest {
     return factory.create();
   }
 
+  @Ignore("replicates don't allow local destroy")
   @Override
+  @Test
   public void testLocalDestroy() throws InterruptedException {
     // replicates don't allow local destroy
   }
 
+  @Ignore("replicates don't allow local destroy")
   @Override
+  @Test
   public void testEntryTtlLocalDestroy() throws InterruptedException {
     // replicates don't allow local destroy
   }
@@ -105,10 +114,12 @@ public class GlobalRegionCCEDUnitTest extends GlobalRegionDUnitTest {
    * client cache is created in vm2 and the same sort of check is performed for
    * register-interest.
    */
+  @Test
   public void testGIISendsTombstones() throws Exception {
     versionTestGIISendsTombstones();
   }
 
+  // TODO: delete this unused method
   protected void do_version_recovery_if_necessary(final VM vm0, final VM vm1,
       final VM vm2, final Object[] params) {
     // do nothing here
@@ -119,24 +130,33 @@ public class GlobalRegionCCEDUnitTest extends GlobalRegionDUnitTest {
    * conflation happens correctly and that the statistic is being updated
    * properly
    */
+  @Test
   public void testConcurrentEvents() throws Exception {
     versionTestConcurrentEvents();
   }
 
   // these tests for clear() take too long with global regions and cause false dunit hangs
   // on older machines
-//  public void testClearWithConcurrentEvents() throws Exception {
-//    z_versionTestClearWithConcurrentEvents(true);
-//  }
-//
-//  public void testClearWithConcurrentEventsAsync() throws Exception {
-//    versionTestClearWithConcurrentEventsAsync();
-//  }
-//
-//  public void testClearOnNonReplicateWithConcurrentEvents() throws Exception {
-//    versionTestClearOnNonReplicateWithConcurrentEvents();
-//  }
 
+  @Ignore("TODO: takes too long with global regions and cause false dunit hangs")
+  @Test
+  public void testClearWithConcurrentEvents() throws Exception {
+    z_versionTestClearWithConcurrentEvents(true);
+  }
+
+  @Ignore("TODO: takes too long with global regions and cause false dunit hangs")
+  @Test
+  public void testClearWithConcurrentEventsAsync() throws Exception {
+    versionTestClearWithConcurrentEventsAsync();
+  }
+
+  @Ignore("TODO: takes too long with global regions and cause false dunit hangs")
+  @Test
+  public void testClearOnNonReplicateWithConcurrentEvents() throws Exception {
+    versionTestClearOnNonReplicateWithConcurrentEvents();
+  }
+
+  @Test
   public void testTombstones() {
     versionTestTombstones();
   }
@@ -146,6 +166,7 @@ public class GlobalRegionCCEDUnitTest extends GlobalRegionDUnitTest {
    * tombstone has been reaped is accepted by another member that has yet to
    * reap the tombstone
    */
+  @Test
   public void testTombstoneExpirationRace() {
     VM vm0 = Host.getHost(0).getVM(0);
     VM vm1 = Host.getHost(0).getVM(1);
@@ -216,7 +237,8 @@ public class GlobalRegionCCEDUnitTest extends GlobalRegionDUnitTest {
    * properly
    */
   @Ignore("Disabling due to bug #52347")
-  public void DISABLED_testConcurrentEventsOnEmptyRegion() {
+  @Test
+  public void testConcurrentEventsOnEmptyRegion() {
     versionTestConcurrentEventsOnEmptyRegion();
   }
 
@@ -225,15 +247,17 @@ public class GlobalRegionCCEDUnitTest extends GlobalRegionDUnitTest {
    * conflation happens correctly and that the statistic is being updated
    * properly
    */
+  @Ignore("TODO: reenable this test")
+  @Test
   public void testConcurrentEventsOnNonReplicatedRegion() {
     // Shobhit: Just commenting out for now as it is being fixed by Bruce.
     // TODO: uncomment the test asa the bug is fixed.
     //versionTestConcurrentEventsOnNonReplicatedRegion();
   }
 
+  @Test
   public void testGetAllWithVersions() {
     versionTestGetAllWithVersions();
   }
 
-
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEOffHeapDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEOffHeapDUnitTest.java
index 0c7b17d..dddc2e5 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEOffHeapDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEOffHeapDUnitTest.java
@@ -16,6 +16,17 @@
  */
 package com.gemstone.gemfire.cache30;
 
+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 com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
@@ -31,13 +42,10 @@ import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties
  * 
  * @since Geode 1.0
  */
+@Category(DistributedTest.class)
 @SuppressWarnings({ "deprecation", "serial" })
 public class GlobalRegionCCEOffHeapDUnitTest extends GlobalRegionCCEDUnitTest {
 
-  public GlobalRegionCCEOffHeapDUnitTest(String name) {
-    super(name);
-  }
-  
   @Override
   public final void preTearDownAssertions() throws Exception {
     SerializableRunnable checkOrphans = new SerializableRunnable() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionDUnitTest.java
index 8c40d6f..b105354 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionDUnitTest.java
@@ -16,10 +16,15 @@
  */
 package com.gemstone.gemfire.cache30;
 
+import static org.junit.Assert.*;
+
 import java.util.Random;
 import java.util.concurrent.TimeUnit;
 import java.util.concurrent.locks.Lock;
 
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+
 import com.gemstone.gemfire.SystemFailure;
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.Cache;
@@ -38,6 +43,7 @@ import com.gemstone.gemfire.test.dunit.LogWriterUtils;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.ThreadUtils;
 import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
 /**
  * This class tests the functionality of a cache {@link Region region}
@@ -45,12 +51,9 @@ import com.gemstone.gemfire.test.dunit.VM;
  *
  * @since GemFire 3.0
  */
+@Category(DistributedTest.class)
 public class GlobalRegionDUnitTest extends MultiVMRegionTestCase {
 
-  public GlobalRegionDUnitTest(String name) {
-    super(name);
-  }
-
   /**
    * Returns region attributes for a <code>GLOBAL</code> region
    */
@@ -70,6 +73,7 @@ public class GlobalRegionDUnitTest extends MultiVMRegionTestCase {
    *
    * @see Region#createSubregion
    */
+  @Test
   public void testIncompatibleSubregions()
     throws CacheException, InterruptedException {
 
@@ -145,6 +149,7 @@ public class GlobalRegionDUnitTest extends MultiVMRegionTestCase {
    * Tests that a value in a remote cache will be fetched by
    * <code>netSearch</code> and that no loaders are invoked.
    */
+  @Test
   public void testRemoteFetch() throws CacheException {
     assertTrue(getRegionAttributes().getScope().isDistributed());
 
@@ -198,6 +203,7 @@ public class GlobalRegionDUnitTest extends MultiVMRegionTestCase {
    * Tests that a bunch of threads in a bunch of VMs all atomically
    * incrementing the value of an entry get the right value.
    */
+  @Test
   public void testSynchronousIncrements()
     throws InterruptedException {
 
@@ -338,6 +344,7 @@ public class GlobalRegionDUnitTest extends MultiVMRegionTestCase {
    * Tests that {@link Region#put} and {@link Region#get} timeout when
    * another VM holds the distributed lock on the entry in question.
    */
+  @Test
   public void testPutGetTimeout() {
     assertEquals(Scope.GLOBAL, getRegionAttributes().getScope());
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionOffHeapDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionOffHeapDUnitTest.java
index 6f06758..d894565 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionOffHeapDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionOffHeapDUnitTest.java
@@ -16,28 +16,30 @@
  */
 package com.gemstone.gemfire.cache30;
 
+import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+
+import java.util.Properties;
+
+import org.junit.Ignore;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
 import com.gemstone.gemfire.test.dunit.Invoke;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
-
-import java.util.Properties;
-
-import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
 /**
  * Tests Global Region with OffHeap memory.
  * 
  * @since Geode 1.0
  */
-@SuppressWarnings({ "deprecation", "serial" })
+@Category(DistributedTest.class)
+@SuppressWarnings({ "deprecation", "serial", "rawtypes", "unchecked" })
 public class GlobalRegionOffHeapDUnitTest extends GlobalRegionDUnitTest {
 
-  public GlobalRegionOffHeapDUnitTest(String name) {
-    super(name);
-  }
-  
   @Override
   public final void preTearDownAssertions() throws Exception {
     SerializableRunnable checkOrphans = new SerializableRunnable() {
@@ -52,14 +54,14 @@ public class GlobalRegionOffHeapDUnitTest extends GlobalRegionDUnitTest {
     Invoke.invokeInEveryVM(checkOrphans);
     checkOrphans.run();
   }
-  
+
+  @Ignore("TODO: DISABLED due to bug 47951")
   @Override
-  public void DISABLED_testNBRegionInvalidationDuringGetInitialImage() throws Throwable {
+  @Test
+  public void testNBRegionInvalidationDuringGetInitialImage() throws Exception {
     //DISABLED - bug 47951
   }
 
-
-
   @Override
   public Properties getDistributedSystemProperties() {
     Properties props = super.getDistributedSystemProperties();
@@ -67,7 +69,6 @@ public class GlobalRegionOffHeapDUnitTest extends GlobalRegionDUnitTest {
     return props;
   }
   
-  @SuppressWarnings({ "rawtypes", "unchecked" })
   @Override
   protected RegionAttributes getRegionAttributes() {
     RegionAttributes attrs = super.getRegionAttributes();
@@ -76,7 +77,6 @@ public class GlobalRegionOffHeapDUnitTest extends GlobalRegionDUnitTest {
     return factory.create();
   }
   
-  @SuppressWarnings({ "rawtypes", "unchecked" })
   @Override
   protected RegionAttributes getRegionAttributes(String type) {
     RegionAttributes ra = super.getRegionAttributes(type);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/LRUEvictionControllerDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/LRUEvictionControllerDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/LRUEvictionControllerDUnitTest.java
index e0358d7..fa2abb2 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/LRUEvictionControllerDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/LRUEvictionControllerDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.cache30;
 
+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.Properties;
 
@@ -56,15 +65,16 @@ import com.gemstone.gemfire.test.dunit.VM;
  *
  * @since GemFire 3.2
  */
-public class LRUEvictionControllerDUnitTest extends CacheTestCase {
+@Category(DistributedTest.class)
+public class LRUEvictionControllerDUnitTest extends JUnit4CacheTestCase {
 
   private static boolean usingMain = false;
 
   /**
    * Creates a new <code>LRUEvictionControllerDUnitTest</code>
    */
-  public LRUEvictionControllerDUnitTest(String name) {
-    super(name);
+  public LRUEvictionControllerDUnitTest() {
+    super();
   }
 
   /**
@@ -81,6 +91,7 @@ public class LRUEvictionControllerDUnitTest extends CacheTestCase {
    * Carefully verifies that region operations effect the {@link
    * LRUStatistics} as expected.
    */
+  @Test
   public void testRegionOperations() throws CacheException {
 
     int threshold = 10;
@@ -128,6 +139,7 @@ public class LRUEvictionControllerDUnitTest extends CacheTestCase {
    * LRUStatistics} as expected in the presense of a {@link
    * CacheLoader}.
    */
+  @Test
   public void testCacheLoader() throws CacheException {
 
     int threshold = 10;
@@ -183,6 +195,7 @@ public class LRUEvictionControllerDUnitTest extends CacheTestCase {
   /**
    * Tests an <code>LRUCapacityController</code> of size 1.
    */
+  @Test
   public void testSizeOne() throws CacheException {
     int threshold = 1;
 
@@ -247,6 +260,7 @@ public class LRUEvictionControllerDUnitTest extends CacheTestCase {
    * Tests that a single set of eviction attributes can be used multiple times
    * (and does the right thing).
    */
+  @Test
   public void testMultipleUsesOfEvictionAttributes()
     throws CacheException, CloneNotSupportedException {
 
@@ -282,6 +296,7 @@ public class LRUEvictionControllerDUnitTest extends CacheTestCase {
    * Tests that a Region with an LRU capacity controller can be
    * accessed from inside a cache listener.
    */
+  @Test
   public void testBug31592() throws Exception {
     final String name = this.getUniqueName();
     final Object key = "KEY";
@@ -330,6 +345,7 @@ public class LRUEvictionControllerDUnitTest extends CacheTestCase {
    * Tests that a capacity controller with LOCAL_DESTROY eviction action
    * cannot be installed into a region
    */
+  @Test
   public void testCCMirrored() throws Exception {
     final String name = this.getUniqueName();
     AttributesFactory factory = new AttributesFactory();
@@ -351,6 +367,7 @@ public class LRUEvictionControllerDUnitTest extends CacheTestCase {
    * Asserts that the LRU rules are observed
    * @throws Exception
    */
+  @Test
   public void testReplicationAndTransactions() throws Exception {
     final String r1 = this.getUniqueName() + "-1";
     final String r2 = this.getUniqueName() + "-2";
@@ -481,7 +498,7 @@ public class LRUEvictionControllerDUnitTest extends CacheTestCase {
   
   public static void main(String[] args) throws Exception {
     usingMain = true;
-    (new LRUEvictionControllerDUnitTest("test")).testSizeOne();
+    (new LRUEvictionControllerDUnitTest()).testSizeOne();
   }
 
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/LocalRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/LocalRegionDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/LocalRegionDUnitTest.java
index 4f4a440..225cd7c 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/LocalRegionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/LocalRegionDUnitTest.java
@@ -16,6 +16,11 @@
  */
 package com.gemstone.gemfire.cache30;
 
+import static org.junit.Assert.*;
+
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.CacheException;
 import com.gemstone.gemfire.cache.CacheLoaderException;
@@ -27,21 +32,19 @@ import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache.TimeoutException;
 import com.gemstone.gemfire.test.dunit.Assert;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
 /**
  * Tests the functionality of a {@link Scope#LOCAL locally scoped}
  * cache {@link Region} including its callbacks.  Note that even
- * though this test is a {@link com.gemstone.gemfire.test.dunit.DistributedTestCase}, it does
+ * though this test is a dunit test, it does
  * not perform any distribution.
  *
  * @since GemFire 3.0
  */
+@Category(DistributedTest.class)
 public class LocalRegionDUnitTest extends CacheListenerTestCase {
 
-  public LocalRegionDUnitTest(String name) {
-    super(name);
-  }
-
   /**
    * Returns the attributes of a region to be tested.
    */
@@ -60,6 +63,7 @@ public class LocalRegionDUnitTest extends CacheListenerTestCase {
    *
    * @see Region#createSubregion
    */
+  @Test
   public void testIncompatibleSubregions() throws CacheException {
     Region region = createRegion(this.getUniqueName());
     assertEquals(Scope.LOCAL, region.getAttributes().getScope());
@@ -110,6 +114,7 @@ public class LocalRegionDUnitTest extends CacheListenerTestCase {
    * invokes {@link LoaderHelper#netSearch}, a {@link
    * CacheLoaderException} is thrown.
    */
+  @Test
   public void testLocalLoaderNetSearch() throws CacheException {
     assertEquals(Scope.LOCAL, getRegionAttributes().getScope());
 
@@ -155,6 +160,7 @@ public class LocalRegionDUnitTest extends CacheListenerTestCase {
    * Tests that a local writer receives a modified version of the
    * callback argument on a create.
    */
+  @Test
   public void testLocalCreateModifiedCallbackArgument()
     throws CacheException {
 
@@ -202,6 +208,7 @@ public class LocalRegionDUnitTest extends CacheListenerTestCase {
    * Tests that a local writer receives a modified version of the
    * callback argument on an update.
    */
+  @Test
   public void testLocalUpdateModifiedCallbackArgument()
     throws CacheException {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b914df23/geode-core/src/test/java/com/gemstone/gemfire/cache30/MemLRUEvictionControllerDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/MemLRUEvictionControllerDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/MemLRUEvictionControllerDUnitTest.java
index 2e8716c..a74967b 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/MemLRUEvictionControllerDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/MemLRUEvictionControllerDUnitTest.java
@@ -16,6 +16,15 @@
  */
 package com.gemstone.gemfire.cache30;
 
+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.Random;
 
@@ -42,7 +51,8 @@ import com.gemstone.gemfire.internal.size.WellKnownClassSizer;
  * 
  * @since GemFire 3.2
  */
-public class MemLRUEvictionControllerDUnitTest extends CacheTestCase
+@Category(DistributedTest.class)
+public class MemLRUEvictionControllerDUnitTest extends JUnit4CacheTestCase
 {
 
   private static boolean usingMain = false;
@@ -50,8 +60,8 @@ public class MemLRUEvictionControllerDUnitTest extends CacheTestCase
   /**
    * Creates a new <code>MemLRUEvictionControllerDUnitTest</code>
    */
-  public MemLRUEvictionControllerDUnitTest(String name) {
-    super(name);
+  public MemLRUEvictionControllerDUnitTest() {
+    super();
   }
 
   /**
@@ -76,6 +86,7 @@ public class MemLRUEvictionControllerDUnitTest extends CacheTestCase
    * Carefully verifies that region operations effect the {@link LRUStatistics}
    * as expected.
    */
+  @Test
   public void testRegionOperations() throws CacheException
   {
 
@@ -149,6 +160,7 @@ public class MemLRUEvictionControllerDUnitTest extends CacheTestCase
    * see the class instance.
    * @throws CacheException
    */
+  @Test
   public void testSizeClassesOnce() throws CacheException
   {
     int threshold = 4;
@@ -191,6 +203,7 @@ public class MemLRUEvictionControllerDUnitTest extends CacheTestCase
   /**
    * Prints out the number of bytes that a region entry occupies in the VM.
    */
+  @Test
   public void testEntryOverHead() throws Exception
   {
     final String name = this.getUniqueName();
@@ -235,6 +248,7 @@ public class MemLRUEvictionControllerDUnitTest extends CacheTestCase
    * 
    * @throws Exception
    */
+  @Test
   public void testCustomObjectSizer() throws Exception
   {
     final String name = this.getUniqueName();
@@ -261,7 +275,7 @@ public class MemLRUEvictionControllerDUnitTest extends CacheTestCase
   public static void main(String[] args) throws Exception
   {
     usingMain = true;
-    (new MemLRUEvictionControllerDUnitTest("test")).testRegionOperations();
+    (new MemLRUEvictionControllerDUnitTest()).testRegionOperations();
   }
   
   private static class TestObject {