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/06/07 20:55:09 UTC

[54/62] [abbrv] incubator-geode git commit: Merge remote-tracking branch 'origin/develop' into feature/GEODE-837

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug39079DUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug39079DUnitTest.java
index 0845cd7,90fc87c..42a93eb
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug39079DUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug39079DUnitTest.java
@@@ -19,52 -19,31 +19,46 @@@
   */
  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 com.gemstone.gemfire.cache.*;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
++import static com.gemstone.gemfire.test.dunit.Assert.*;
 +
 +import java.io.File;
 +import java.io.IOException;
- import java.nio.channels.FileChannel;
 +import java.util.List;
 +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.Cache;
 +import com.gemstone.gemfire.cache.CacheFactory;
 +import com.gemstone.gemfire.cache.DataPolicy;
 +import com.gemstone.gemfire.cache.DiskAccessException;
- import com.gemstone.gemfire.cache.EntryEvent;
 +import com.gemstone.gemfire.cache.Region;
 +import com.gemstone.gemfire.cache.RegionAttributes;
 +import com.gemstone.gemfire.cache.Scope;
  import com.gemstone.gemfire.cache.client.PoolManager;
  import com.gemstone.gemfire.cache.client.internal.PoolImpl;
  import com.gemstone.gemfire.cache.server.CacheServer;
  import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
--import com.gemstone.gemfire.cache30.CacheTestCase;
  import com.gemstone.gemfire.distributed.DistributedSystem;
- import com.gemstone.gemfire.distributed.internal.DistributionConfig;
  import com.gemstone.gemfire.internal.AvailablePort;
  import com.gemstone.gemfire.internal.cache.persistence.UninterruptibleFileChannel;
 -import com.gemstone.gemfire.test.dunit.*;
 -
 -import java.io.File;
 -import java.io.IOException;
 -import java.util.List;
 -import java.util.Properties;
 -
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.LOCATORS;
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.MCAST_PORT;
 +import com.gemstone.gemfire.test.dunit.Assert;
 +import com.gemstone.gemfire.test.dunit.Host;
 +import com.gemstone.gemfire.test.dunit.NetworkUtils;
 +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;
  
  /**
   * Tests that if a node doing GII experiences DiskAccessException, it should
   * also not try to recover from the disk
-- *
   */
 -public class Bug39079DUnitTest extends CacheTestCase {
 +@Category(DistributedTest.class)
 +public class Bug39079DUnitTest extends JUnit4CacheTestCase {
  
    protected static String regionName = "IGNORE_EXCEPTION_Bug39079";
  
@@@ -84,12 -64,17 +78,12 @@@
  
    private static final int maxEntries = 10000;
  
-   public Bug39079DUnitTest() {
-     super();
 -  /**
 -   * Constructor
 -   * 
 -   * @param name
 -   */
 -  public Bug39079DUnitTest(String name) {
 -    super(name);
 -    File file1 = new File(name + "1");
++  @Override
++  public final void preSetUp() throws Exception {
 +    File file1 = new File(getTestMethodName() + "1");
      file1.mkdir();
      file1.deleteOnExit();
 -    File file2 = new File(name + "2");
 +    File file2 = new File(getTestMethodName() + "2");
      file2.mkdir();
      file2.deleteOnExit();
      dirs = new File[2];
@@@ -109,18 -94,18 +103,14 @@@
  
    /**
     * This method is used to create Cache in VM0
--   * 
--   * @return CacheSerializableRunnable
     */
--
    private CacheSerializableRunnable createCacheForVM0() {
      SerializableRunnable createCache = new CacheSerializableRunnable(
          "createCache") {
        public void run2() {
          try {
  
-           (new Bug39079DUnitTest())
 -          (new Bug39079DUnitTest("vm0_diskReg"))
--              .getSystem();         
++          new Bug39079DUnitTest().getSystem();
            
            assertTrue(getCache() != null);
            AttributesFactory factory = new AttributesFactory();
@@@ -135,8 -120,8 +125,7 @@@
            getCache().createRegion(regionName, attr);
          }
          catch (Exception ex) {
--          ex.printStackTrace();
--          fail("Error Creating cache / region ");
++          fail("Error Creating cache / region ", ex);
          }
        }
      };
@@@ -145,8 -130,8 +134,6 @@@
  
    /**
     * This method is used to create Cache in VM1
--   * 
--   * @return CacheSerializableRunnable
     */
    private CacheSerializableRunnable createCacheForVM1() {
      SerializableRunnable createCache = new CacheSerializableRunnable(
@@@ -172,8 -157,8 +159,7 @@@
  
          }
          catch (Exception ex) {
--          ex.printStackTrace();
--          fail("Error Creating cache / region " + ex);
++          fail("Error Creating cache / region ", ex);
          }
        }
      };
@@@ -192,16 -177,15 +178,12 @@@
      DiskStoreImpl.SET_IGNORE_PREALLOCATE = flag;
    }
  
--  
    /**
--   * If the node expreriences disk access exception during GII, it should
++   * If the node experiences disk access exception during GII, it should
     * get destroyed & not attempt to recover from the disk
--   * 
     */
--
 +  @Test
    public void testGIIDiskAccessException() {
--
      vm0.invoke(createCacheForVM0());
      vm1.invoke(createCacheForVM1());
      //Create DiskRegion locally in controller VM also
@@@ -233,7 -217,7 +215,6 @@@
          null, (GemFireCacheImpl)getCache(), new InternalRegionArguments()
              .setDestroyLockFlag(true).setRecreateFlag(false)
              .setSnapshotInputStream(null).setImageTarget(null));
--//    assertTrue("Distributed Region is null", distRegion != null); (cannot be null)
  
      ((AbstractRegionMap)distRegion.entries)
          .setEntryFactory(Bug39079DUnitTest.TestAbstractDiskRegionEntry.getEntryFactory());
@@@ -248,29 -232,29 +229,29 @@@
        //Ok
      }
      catch (Exception e) {
--      fail(" test failed because of exception =" + e.toString());
++      fail(" test failed because of exception =", e);
      }
  
      assertTrue(rgn == null || rgn.isDestroyed());
--
    }
  
    static class TestAbstractDiskRegionEntry extends VMThinDiskRegionEntryHeapObjectKey {
++
      protected TestAbstractDiskRegionEntry(RegionEntryContext r, Object key,
          Object value) {
        super(r, key, value);
      }
  
      private static RegionEntryFactory factory = new RegionEntryFactory() {
++
++      @Override
        public final RegionEntry createEntry(RegionEntryContext r, Object key,
            Object value) {
--
          throw new DiskAccessException(new IOException("Test Exception"));
--        //return new Bug39079DUnitTest.TestAbstractDiskRegionEntry(r, key, value);
        }
  
++      @Override
        public final Class getEntryClass() {
--
          return Bug39079DUnitTest.TestAbstractDiskRegionEntry.class;
        }
  
@@@ -278,7 -262,7 +259,8 @@@
        public RegionEntryFactory makeVersioned() {
          return this;
        }
--      
++
++      @Override
        public RegionEntryFactory makeOnHeap() {
          return this;
        }
@@@ -300,12 -284,11 +282,9 @@@
    /**
     * If IOException occurs while updating an entry in an already initialized
     * DiskRegion ,then the bridge servers should be stopped , if any running 
--   * 
--   * @throws Exception
     */
 -  public void testBridgeServerStoppingInSynchPersistOnlyForIOExceptionCase()
 -      throws Exception {    
 +  @Test
-   public void testBridgeServerStoppingInSynchPersistOnlyForIOExceptionCase()
-       throws Exception {    
++  public void testBridgeServerStoppingInSynchPersistOnlyForIOExceptionCase() throws Exception {
     // create server cache 
     Integer port = (Integer)vm0.invoke(() -> Bug39079DUnitTest.createServerCache());
     //create cache client
@@@ -320,9 -303,9 +299,8 @@@
     vm1.invoke(() -> Bug39079DUnitTest.closeCacheAndDisconnect());
    }
    
--  public static Integer createServerCache() throws Exception
--  {
 -    new Bug39079DUnitTest("temp").createCache(new Properties());
++  public static Integer createServerCache() throws Exception {
 +    new Bug39079DUnitTest().createCache(new Properties());
      DiskRegionProperties props = new DiskRegionProperties();
      props.setRegionName(REGION_NAME);
      props.setOverflow(true);
@@@ -339,16 -322,16 +317,14 @@@
      return new Integer(bs1.getPort());
    }
  
--  public static void closeCacheAndDisconnect()
--  {
++  public static void closeCacheAndDisconnect() {
      if (gemfirecache != null && !gemfirecache.isClosed()) {
        gemfirecache.close();
        gemfirecache.getDistributedSystem().disconnect();
      }
    }
    
--  private void createCache(Properties props) throws Exception
--  {
++  private void createCache(Properties props) throws Exception {
      DistributedSystem ds = getSystem(props);
      assertNotNull(ds);
      ds.disconnect();
@@@ -358,12 -341,12 +334,10 @@@
    }
    
    private static void validateRuningBridgeServerList(){
--    /*Region region = gemfirecache.getRegion(Region.SEPARATOR + REGION_NAME);
--    assertNotNull(region);*/
--    try {        
++    try {
        region.create("key1", new byte[16]);
        region.create("key2", new byte[16]);
--//    Get the oplog handle & hence the underlying file & close it
++      // Get the oplog handle & hence the underlying file & close it
        UninterruptibleFileChannel oplogFileChannel = ((LocalRegion)region).getDiskRegion()
            .testHook_getChild().getFileChannel();
        try {
@@@ -389,13 -372,13 +363,12 @@@
      }
    }
    
--  public static void createClientCache(String host, Integer port1)
--      throws Exception {
 -    new Bug39079DUnitTest("temp");
++  public static void createClientCache(String host, Integer port1) throws Exception {
 +    new Bug39079DUnitTest();
      Properties props = new Properties();
-     props.setProperty(DistributionConfig.MCAST_PORT_NAME, "0");
-     props.setProperty(DistributionConfig.LOCATORS_NAME, "");
+     props.setProperty(MCAST_PORT, "0");
+     props.setProperty(LOCATORS, "");
 -    new Bug39079DUnitTest("temp").createCache(props);
 +    new Bug39079DUnitTest().createCache(props);
      PoolImpl p = (PoolImpl)PoolManager.createFactory().addServer(host,
          port1.intValue())
          .setSubscriptionEnabled(true).setSubscriptionRedundancy(0)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41091DUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41091DUnitTest.java
index c5db436,bb2faf0..dfe502e
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41091DUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41091DUnitTest.java
@@@ -16,56 -16,42 +16,44 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
- import org.junit.experimental.categories.Category;
- import org.junit.Test;
- 
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +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.InetAddress;
 +import java.net.UnknownHostException;
 +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.Cache;
  import com.gemstone.gemfire.cache.PartitionAttributesFactory;
  import com.gemstone.gemfire.cache.Region;
--import com.gemstone.gemfire.cache30.CacheTestCase;
  import com.gemstone.gemfire.distributed.Locator;
- import com.gemstone.gemfire.distributed.internal.DistributionConfig;
  import com.gemstone.gemfire.distributed.internal.DistributionManager;
  import com.gemstone.gemfire.distributed.internal.DistributionMessage;
  import com.gemstone.gemfire.distributed.internal.DistributionMessageObserver;
  import com.gemstone.gemfire.internal.AvailablePort;
  import com.gemstone.gemfire.internal.cache.InitialImageOperation.RequestImageMessage;
 -import com.gemstone.gemfire.test.dunit.*;
 -
 -import java.io.File;
 -import java.io.IOException;
 -import java.net.InetAddress;
 -import java.net.UnknownHostException;
 -import java.util.Properties;
 -
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +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.NetworkUtils;
 +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;
  
  /**
-- * 
   * This class tests that bucket regions can handle
   * a failure of the GII target during GII.
-- *
   */
 -public class Bug41091DUnitTest extends CacheTestCase {
 +@Category(DistributedTest.class)
 +public class Bug41091DUnitTest extends JUnit4CacheTestCase {
  
--  /**
--   * @param name
--   */
-   public Bug41091DUnitTest() {
-     super();
 -  public Bug41091DUnitTest(String name) {
 -    super(name);
--  }
--  
    @Override
    public final void postTearDownCacheTestCase() throws Exception {
      disconnectAllFromDS();
@@@ -97,9 -82,9 +85,9 @@@
                RequestImageMessage rim = (RequestImageMessage) message;
                Region region = getCache().getRegion(rim.regionPath);
                if(region instanceof BucketRegion) {
--//We can no longer do any puts until the bucket is completely created,
--//so this will hang
--//                getCache().getRegion("region").put(113, "b");
++                //We can no longer do any puts until the bucket is completely created,
++                //so this will hang
++                // getCache().getRegion("region").put(113, "b");
                  getCache().close();
                }
              }
@@@ -150,7 -135,7 +138,6 @@@
              }
            };
        vm3.invoke(stopLocator);
--      
      }
    }
    

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41957DUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41957DUnitTest.java
index 8a9e7c3,fc7b443..05966b3
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41957DUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41957DUnitTest.java
@@@ -16,35 -16,18 +16,35 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
 -import com.gemstone.gemfire.cache.*;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static com.gemstone.gemfire.test.dunit.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.EvictionAttributes;
 +import com.gemstone.gemfire.cache.InterestPolicy;
 +import com.gemstone.gemfire.cache.InterestResultPolicy;
 +import com.gemstone.gemfire.cache.PartitionAttributesFactory;
 +import com.gemstone.gemfire.cache.Region;
 +import com.gemstone.gemfire.cache.Scope;
 +import com.gemstone.gemfire.cache.SubscriptionAttributes;
  import com.gemstone.gemfire.cache.client.PoolFactory;
  import com.gemstone.gemfire.cache.client.PoolManager;
  import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
  import com.gemstone.gemfire.cache30.ClientServerTestCase;
- import com.gemstone.gemfire.distributed.internal.DistributionConfig;
  import com.gemstone.gemfire.internal.AvailablePort;
 -import com.gemstone.gemfire.test.dunit.*;
 -
 -import java.util.Properties;
 -
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.LOCATORS;
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.MCAST_PORT;
 +import com.gemstone.gemfire.test.dunit.Assert;
 +import com.gemstone.gemfire.test.dunit.DistributedTestUtils;
 +import com.gemstone.gemfire.test.dunit.Host;
 +import com.gemstone.gemfire.test.dunit.NetworkUtils;
 +import com.gemstone.gemfire.test.dunit.VM;
 +import com.gemstone.gemfire.test.junit.categories.DistributedTest;
  
  /**
   * Test for bug 41957.
@@@ -52,10 -35,13 +52,10 @@@
   * do a register interest with key&values and see if we end up with more entries
   * in the client than the eviction limit.
   *
-  * @since 6.5
+  * @since GemFire 6.5
   */
 - public class Bug41957DUnitTest extends ClientServerTestCase {
 -
 -  public Bug41957DUnitTest(String name) {
 -    super(name);
 -  }
 +@Category(DistributedTest.class)
 +public class Bug41957DUnitTest extends ClientServerTestCase {
  
    @Override
    public final void postTearDownCacheTestCase() throws Exception {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug45934DUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug45934DUnitTest.java
index 8188cad,eb4faf6..6702a64
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug45934DUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug45934DUnitTest.java
@@@ -16,38 -16,23 +16,33 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
- import org.junit.experimental.categories.Category;
- import org.junit.Test;
- 
 -import com.gemstone.gemfire.cache.*;
 -import com.gemstone.gemfire.cache30.CacheTestCase;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +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.HashMap;
 +import java.util.Map;
 +
++import org.junit.Test;
++import org.junit.experimental.categories.Category;
++
 +import com.gemstone.gemfire.cache.Cache;
 +import com.gemstone.gemfire.cache.CacheFactory;
 +import com.gemstone.gemfire.cache.DataPolicy;
 +import com.gemstone.gemfire.cache.Region;
 +import com.gemstone.gemfire.cache.RegionFactory;
 +import com.gemstone.gemfire.cache.RegionShortcut;
 +import com.gemstone.gemfire.cache.Scope;
- import com.gemstone.gemfire.cache30.CacheTestCase;
  import com.gemstone.gemfire.internal.util.DelayedAction;
  import com.gemstone.gemfire.test.dunit.Host;
  import com.gemstone.gemfire.test.dunit.SerializableCallable;
  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 java.util.HashMap;
 -import java.util.Map;
 -
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +@Category(DistributedTest.class)
 +public class Bug45934DUnitTest extends JUnit4CacheTestCase {
-   public Bug45934DUnitTest() {
-     super();
-   }
-   
+ 
 -public class Bug45934DUnitTest extends CacheTestCase {
 -  public Bug45934DUnitTest(String name) {
 -    super(name);
 -  }
 -  
 +  @Test
    public void testNormal() throws Exception {
      int count = 1000;
      Host host = Host.getHost(0);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/CacheAdvisorDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/CacheAdvisorDUnitTest.java
index 96c4c39,777ef66..19064c2
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/CacheAdvisorDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/CacheAdvisorDUnitTest.java
@@@ -275,17 -261,15 +275,17 @@@ public class CacheAdvisorDUnitTest exte
    }
    
    /** coverage for bug 34255
-    * @since 5.0
+    * @since GemFire 5.0
     */
 - public void testRegionClose() throws Exception {
 +  @Test
 +  public void testRegionClose() throws Exception {
      basicTestClose(Operation.REGION_CLOSE);
    }
  
    /** coverage for bug 34255
-    * @since 5.0
+    * @since GemFire 5.0
     */
 +  @Test
    public void testRegionLocalDestroy() throws Exception {
      basicTestClose(Operation.REGION_LOCAL_DESTROY);
    }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/CacheLifecycleListenerJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/CacheLifecycleListenerJUnitTest.java
index 15d75a7,4656b91..6f70a27
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/CacheLifecycleListenerJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/CacheLifecycleListenerJUnitTest.java
@@@ -16,18 -16,18 +16,18 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
 -import com.gemstone.gemfire.cache.CacheFactory;
 -import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 -import org.junit.Test;
 -import org.junit.experimental.categories.Category;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
  
  import java.util.ArrayList;
  import java.util.List;
  import java.util.Properties;
  
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.LOCATORS;
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.MCAST_PORT;
 -import static org.junit.Assert.*;
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
 +
 +import com.gemstone.gemfire.cache.CacheFactory;
- import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 +import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
  
  /**
   * Tests notifications of CacheLifecycleListener from GemFireCacheImpl.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClearDAckDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClearDAckDUnitTest.java
index e13d913,bb0e02d..94aa4fd
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClearDAckDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClearDAckDUnitTest.java
@@@ -100,10 -87,10 +100,10 @@@ public class ClearDAckDUnitTest extend
  
      public static DistributedMember createCacheVM0() {
          try{
-             //            props.setProperty("mcast-port", "1234");
+           //            props.setProperty(DistributionConfig.SystemConfigurationProperties.MCAST_PORT, "1234");
              //            ds = DistributedSystem.connect(props);
              LogWriterUtils.getLogWriter().info("I am vm0");
 -            ds = (new ClearDAckDUnitTest("temp")).getSystem(props);
 +            ds = (new ClearDAckDUnitTest()).getSystem(props);
              cache = CacheFactory.create(ds);
              
              AttributesFactory factory  = new AttributesFactory();
@@@ -125,10 -112,10 +125,10 @@@
      } //end of create cache for VM0
      public static DistributedMember createCacheVM1(){
          try{
-             //   props.setProperty("mcast-port", "1234");
+           //   props.setProperty(DistributionConfig.SystemConfigurationProperties.MCAST_PORT, "1234");
              //   ds = DistributedSystem.connect(props);
              LogWriterUtils.getLogWriter().info("I am vm1");
 -            ds = (new ClearDAckDUnitTest("temp")).getSystem(props);
 +            ds = (new ClearDAckDUnitTest()).getSystem(props);
              //DistributedSystem.setThreadsSocketPolicy(false);
              CacheObserverImpl observer = new CacheObserverImpl();
              origObserver = CacheObserverHolder.setInstance(observer);
@@@ -154,10 -141,10 +154,10 @@@
      
      public static void createCacheVM2AndLocalClear(){
        try{
-           //   props.setProperty("mcast-port", "1234");
+         //   props.setProperty(DistributionConfig.SystemConfigurationProperties.MCAST_PORT, "1234");
            //   ds = DistributedSystem.connect(props);
            LogWriterUtils.getLogWriter().info("I am vm2");
 -          ds = (new ClearDAckDUnitTest("temp")).getSystem(props);
 +          ds = (new ClearDAckDUnitTest()).getSystem(props);
            //DistributedSystem.setThreadsSocketPolicy(false);
            CacheObserverImpl observer = new CacheObserverImpl();
            origObserver = CacheObserverHolder.setInstance(observer);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerGetAllDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerGetAllDUnitTest.java
index ea06da2,bc1c8af..84445b8
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerGetAllDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerGetAllDUnitTest.java
@@@ -16,26 -16,7 +16,27 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
 -import com.gemstone.gemfire.cache.*;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static com.gemstone.gemfire.test.dunit.Assert.*;
 +
 +import java.util.ArrayList;
 +import java.util.Arrays;
 +import java.util.Collection;
 +import java.util.Iterator;
 +import java.util.Map;
 +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.Cache;
 +import com.gemstone.gemfire.cache.CacheException;
 +import com.gemstone.gemfire.cache.DataPolicy;
 +import com.gemstone.gemfire.cache.LoaderHelper;
 +import com.gemstone.gemfire.cache.PartitionAttributesFactory;
 +import com.gemstone.gemfire.cache.Region;
 +import com.gemstone.gemfire.cache.Scope;
  import com.gemstone.gemfire.cache.client.PoolFactory;
  import com.gemstone.gemfire.cache.client.PoolManager;
  import com.gemstone.gemfire.cache.server.CacheServer;
@@@ -57,10 -34,13 +57,10 @@@ import com.gemstone.gemfire.test.junit.
  /**
   * Class <code>ClientServerGetAllDUnitTest</code> test client/server getAll.
   *
-  * @since 5.7
+  * @since GemFire 5.7
   */
 - public class ClientServerGetAllDUnitTest extends ClientServerTestCase {
 -
 -  public ClientServerGetAllDUnitTest(String name) {
 -    super(name);
 -  }
 +@Category(DistributedTest.class)
 +public class ClientServerGetAllDUnitTest extends ClientServerTestCase {
  
    @Override
    public final void postTearDownCacheTestCase() throws Exception {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
index 3c053f3,d46172b..35b1162
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
@@@ -16,60 -16,38 +16,52 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
- import org.junit.experimental.categories.Category;
- import org.junit.Test;
- 
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +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.LinkedList;
 +import java.util.List;
 +import java.util.Map;
 +
++import org.junit.Test;
++import org.junit.experimental.categories.Category;
++
  import com.gemstone.gemfire.LogWriter;
 -import com.gemstone.gemfire.cache.*;
 +import com.gemstone.gemfire.cache.Cache;
 +import com.gemstone.gemfire.cache.EntryEvent;
 +import com.gemstone.gemfire.cache.InterestResultPolicy;
 +import com.gemstone.gemfire.cache.Operation;
 +import com.gemstone.gemfire.cache.PartitionAttributesFactory;
 +import com.gemstone.gemfire.cache.Region;
 +import com.gemstone.gemfire.cache.RegionFactory;
 +import com.gemstone.gemfire.cache.RegionShortcut;
  import com.gemstone.gemfire.cache.client.ClientCache;
  import com.gemstone.gemfire.cache.client.ClientCacheFactory;
  import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
  import com.gemstone.gemfire.cache.server.CacheServer;
  import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
--import com.gemstone.gemfire.cache30.CacheTestCase;
- import com.gemstone.gemfire.distributed.internal.DistributionConfig;
  import com.gemstone.gemfire.internal.AvailablePortHelper;
  import com.gemstone.gemfire.internal.cache.tier.InterestType;
 -import com.gemstone.gemfire.test.dunit.*;
 -
 -import java.io.IOException;
 -import java.util.LinkedList;
 -import java.util.List;
 -import java.util.Map;
 -
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +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.SerializableCallable;
 +import com.gemstone.gemfire.test.dunit.SerializableCallableIF;
 +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;
  
  /**
   * This tests the fix for bug #43407 under a variety of configurations and
   * also tests that tombstones are treated in a similar manner.  The ticket
   * complains that a client that does a get(K) does not end up with the entry
   * in its cache if K is invalid on the server.
-- *
   */
 -public class ClientServerInvalidAndDestroyedEntryDUnitTest extends CacheTestCase {
 +@Category(DistributedTest.class)
 +public class ClientServerInvalidAndDestroyedEntryDUnitTest extends JUnit4CacheTestCase {
    
-   public ClientServerInvalidAndDestroyedEntryDUnitTest() {
-     super();
 -  public ClientServerInvalidAndDestroyedEntryDUnitTest(String name) {
 -    super(name);
--  }
--
    @Override
    public final void postSetUp() throws Exception {
      disconnectAllFromDS();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
index db85e64,22efdea..1c9b401
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
@@@ -16,71 -16,12 +16,36 @@@
   */
  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 static com.gemstone.gemfire.test.dunit.LogWriterUtils.*;
 +
 +import java.util.ArrayList;
 +import java.util.HashMap;
 +import java.util.HashSet;
 +import java.util.Iterator;
 +import java.util.List;
 +import java.util.Map;
 +import java.util.Properties;
 +import java.util.Set;
 +import java.util.concurrent.CountDownLatch;
 +import java.util.concurrent.TimeUnit;
 +
 +import javax.naming.Context;
 +import javax.transaction.UserTransaction;
+ import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
  
- import com.gemstone.gemfire.cache.AttributesFactory;
- import com.gemstone.gemfire.cache.Cache;
- import com.gemstone.gemfire.cache.CacheFactory;
- import com.gemstone.gemfire.cache.CacheListener;
- import com.gemstone.gemfire.cache.CacheLoader;
- import com.gemstone.gemfire.cache.CacheLoaderException;
- import com.gemstone.gemfire.cache.CacheTransactionManager;
- import com.gemstone.gemfire.cache.CacheWriterException;
- import com.gemstone.gemfire.cache.CommitConflictException;
- import com.gemstone.gemfire.cache.DataPolicy;
- import com.gemstone.gemfire.cache.EntryEvent;
- import com.gemstone.gemfire.cache.InterestPolicy;
- import com.gemstone.gemfire.cache.LoaderHelper;
- import com.gemstone.gemfire.cache.Region;
+ import com.gemstone.gemfire.cache.*;
  import com.gemstone.gemfire.cache.Region.Entry;
- import com.gemstone.gemfire.cache.RegionFactory;
- import com.gemstone.gemfire.cache.RegionShortcut;
- import com.gemstone.gemfire.cache.Scope;
- import com.gemstone.gemfire.cache.SubscriptionAttributes;
- import com.gemstone.gemfire.cache.TransactionDataNodeHasDepartedException;
- import com.gemstone.gemfire.cache.TransactionDataNotColocatedException;
- import com.gemstone.gemfire.cache.TransactionEvent;
- import com.gemstone.gemfire.cache.TransactionException;
- import com.gemstone.gemfire.cache.TransactionId;
- import com.gemstone.gemfire.cache.TransactionInDoubtException;
- import com.gemstone.gemfire.cache.TransactionWriter;
- import com.gemstone.gemfire.cache.TransactionWriterException;
- import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
- import com.gemstone.gemfire.cache.client.ClientCache;
- import com.gemstone.gemfire.cache.client.ClientCacheFactory;
- import com.gemstone.gemfire.cache.client.ClientRegionFactory;
- import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
- import com.gemstone.gemfire.cache.client.PoolFactory;
- import com.gemstone.gemfire.cache.client.PoolManager;
- import com.gemstone.gemfire.cache.execute.Execution;
- import com.gemstone.gemfire.cache.execute.FunctionAdapter;
- import com.gemstone.gemfire.cache.execute.FunctionContext;
- import com.gemstone.gemfire.cache.execute.FunctionException;
- import com.gemstone.gemfire.cache.execute.FunctionService;
- import com.gemstone.gemfire.cache.execute.RegionFunctionContext;
+ import com.gemstone.gemfire.cache.client.*;
+ import com.gemstone.gemfire.cache.execute.*;
  import com.gemstone.gemfire.cache.server.CacheServer;
  import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
  import com.gemstone.gemfire.cache.util.CacheWriterAdapter;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapLocalJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapLocalJUnitTest.java
index 2471ffd,315caff..3b7c6df
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapLocalJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapLocalJUnitTest.java
@@@ -16,8 -16,8 +16,9 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
 -import com.gemstone.gemfire.cache.*;
 -import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
 +
  import org.junit.After;
  import org.junit.Before;
  import org.junit.Test;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapOpsDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapOpsDUnitTest.java
index cbc6784,919556d..7f03ad1
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapOpsDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapOpsDUnitTest.java
@@@ -14,30 -14,14 +14,31 @@@
   * See the License for the specific language governing permissions and
   * limitations under the License.
   */
 -/**
 - * 
 - */
  package com.gemstone.gemfire.internal.cache;
  
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static com.gemstone.gemfire.test.dunit.Assert.*;
 +
 +import java.io.DataInput;
 +import java.io.DataOutput;
 +import java.io.IOException;
 +import java.io.Serializable;
 +import java.util.HashSet;
 +import java.util.Set;
 +import java.util.concurrent.atomic.AtomicInteger;
 +
 +import org.junit.Ignore;
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
 +
  import com.gemstone.gemfire.Delta;
  import com.gemstone.gemfire.InvalidDeltaException;
 -import com.gemstone.gemfire.cache.*;
 +import com.gemstone.gemfire.cache.CacheListener;
 +import com.gemstone.gemfire.cache.EntryEvent;
 +import com.gemstone.gemfire.cache.Operation;
 +import com.gemstone.gemfire.cache.Region;
 +import com.gemstone.gemfire.cache.RegionEvent;
 +import com.gemstone.gemfire.cache.RegionShortcut;
  import com.gemstone.gemfire.cache.client.ClientCache;
  import com.gemstone.gemfire.cache.client.ClientCacheFactory;
  import com.gemstone.gemfire.cache.client.ClientRegionFactory;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConnectDisconnectDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConnectDisconnectDUnitTest.java
index 2cd4559,d585d26..c0be121
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConnectDisconnectDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConnectDisconnectDUnitTest.java
@@@ -16,29 -16,29 +16,31 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
 -import com.gemstone.gemfire.cache30.CacheTestCase;
 -import com.gemstone.gemfire.test.dunit.*;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+ 
  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.test.dunit.AsyncInvocation;
 +import com.gemstone.gemfire.test.dunit.DistributedTestUtils;
 +import com.gemstone.gemfire.test.dunit.Host;
 +import com.gemstone.gemfire.test.dunit.IgnoredException;
 +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.cache.internal.JUnit4CacheTestCase;
 +import com.gemstone.gemfire.test.junit.categories.DistributedTest;
  
  /** A test of 46438 - missing response to an update attributes message */
 -public class ConnectDisconnectDUnitTest extends CacheTestCase {
 +@Category(DistributedTest.class)
 +public class ConnectDisconnectDUnitTest extends JUnit4CacheTestCase {
    
 -  static {
 -//    System.setProperty("DistributionManager.VERBOSE", "true");
 -  }
 -
 -
    private IgnoredException ex;
  
 -  public ConnectDisconnectDUnitTest(String name) {
 -    super(name);
 -  }
 -  
 -  
 -  // see bugs #50785 and #46438 
 +  // see bugs #50785 and #46438
 +  @Test
    public void testManyConnectsAndDisconnects() throws Throwable {
  //    invokeInEveryVM(new SerializableRunnable() {
  //
@@@ -63,7 -63,7 +65,7 @@@
    
    static int LOCATOR_PORT;
    static String LOCATORS_STRING;
--  
++
    static int[] locatorPorts;
    
    public void setLocatorPorts(int[] ports) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationDUnitTest.java
index fd6bd5d,cf42b9b..8815318
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationDUnitTest.java
@@@ -19,14 -19,6 +19,15 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
 +
 +import java.io.File;
 +import java.util.Properties;
 +
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
 +
  import com.gemstone.gemfire.DeltaTestImpl;
  import com.gemstone.gemfire.InvalidDeltaException;
  import com.gemstone.gemfire.LogWriter;
@@@ -64,21 -42,18 +65,21 @@@ import com.gemstone.gemfire.internal.ca
  import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
  import com.gemstone.gemfire.internal.cache.tier.sockets.ConflationDUnitTest;
  import com.gemstone.gemfire.internal.tcp.ConnectionTable;
 -import com.gemstone.gemfire.test.dunit.*;
 -
 -import java.io.File;
 -import java.util.Properties;
 -
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import com.gemstone.gemfire.test.dunit.Host;
 +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.dunit.internal.JUnit4DistributedTestCase;
 +import com.gemstone.gemfire.test.junit.categories.DistributedTest;
  
  /**
-  * @since 6.1
+  * @since GemFire 6.1
   */
 -public class DeltaPropagationDUnitTest extends DistributedTestCase {
 -  private final static Compressor compressor = SnappyCompressor.getDefaultInstance();
 +@Category(DistributedTest.class)
 +public class DeltaPropagationDUnitTest extends JUnit4DistributedTestCase {
 +
-   private final static Compressor compressor = SnappyCompressor.getDefaultInstance();
++  private static final Compressor compressor = SnappyCompressor.getDefaultInstance();
    
    protected static Cache cache = null;
  
@@@ -96,7 -71,7 +97,7 @@@
  
    private int PORT2;
  
--  private static final String regionName = "DeltaPropagationDUnitTest";
++  private static final String regionName = DeltaPropagationDUnitTest.class.getSimpleName();
  
    private static LogWriter logger = null;
  
@@@ -1344,10 -1311,10 +1345,10 @@@
      CacheServerTestUtil.disableShufflingOfEndpoints();
  
      Properties props = new Properties();
-     props.setProperty(DistributionConfig.MCAST_PORT_NAME, "0");
-     props.setProperty(DistributionConfig.LOCATORS_NAME, "");
-     props.setProperty(DistributionConfig.CLIENT_CONFLATION_PROP_NAME, conflate);
+     props.setProperty(MCAST_PORT, "0");
+     props.setProperty(LOCATORS, "");
+     props.setProperty(CONFLATE_EVENTS, conflate);
 -    new DeltaPropagationDUnitTest("temp").createCache(props);
 +    new DeltaPropagationDUnitTest().createCache(props);
      AttributesFactory factory = new AttributesFactory();
      pool = ClientServerTestCase.configureConnectionPool(factory, "localhost", ports,
          true, Integer.parseInt(rLevel), 2, null, 1000, 250, false, -2);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationStatsDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationStatsDUnitTest.java
index 2c5c5ca,390d1c2..20deab0
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationStatsDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationStatsDUnitTest.java
@@@ -19,24 -19,9 +19,25 @@@
   */
  package com.gemstone.gemfire.internal.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.DeltaTestImpl;
  import com.gemstone.gemfire.InvalidDeltaException;
 -import com.gemstone.gemfire.cache.*;
 +import com.gemstone.gemfire.cache.AttributesFactory;
 +import com.gemstone.gemfire.cache.Cache;
 +import com.gemstone.gemfire.cache.CacheFactory;
 +import com.gemstone.gemfire.cache.DataPolicy;
 +import com.gemstone.gemfire.cache.EntryEvent;
 +import com.gemstone.gemfire.cache.Region;
 +import com.gemstone.gemfire.cache.RegionAttributes;
 +import com.gemstone.gemfire.cache.Scope;
  import com.gemstone.gemfire.cache.client.Pool;
  import com.gemstone.gemfire.cache.client.PoolManager;
  import com.gemstone.gemfire.cache.server.CacheServer;
@@@ -535,9 -511,9 +535,9 @@@ public class DeltaPropagationStatsDUnit
    public static void createClientCache(String host, Integer port)
        throws Exception {
      Properties props = new Properties();
-     props.setProperty(DistributionConfig.MCAST_PORT_NAME, "0");
-     props.setProperty(DistributionConfig.LOCATORS_NAME, "");
+     props.setProperty(MCAST_PORT, "0");
+     props.setProperty(LOCATORS, "");
 -    cache = new DeltaPropagationStatsDUnitTest("temp").createCache(props);
 +    cache = new DeltaPropagationStatsDUnitTest().createCache(props);
      pool = PoolManager.createFactory().addServer(host, port)
          .setThreadLocalConnections(true).setMinConnections(1)
          .setSubscriptionEnabled(true).setSubscriptionRedundancy(0)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskOfflineCompactionJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskOfflineCompactionJUnitTest.java
index 8a266df,5819060..56f533a
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskOfflineCompactionJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskOfflineCompactionJUnitTest.java
@@@ -16,24 -16,7 +16,25 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
 -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.After;
 +import org.junit.Before;
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
 +
 +import com.gemstone.gemfire.cache.AttributesFactory;
 +import com.gemstone.gemfire.cache.Cache;
 +import com.gemstone.gemfire.cache.CacheFactory;
 +import com.gemstone.gemfire.cache.DataPolicy;
 +import com.gemstone.gemfire.cache.DiskStore;
 +import com.gemstone.gemfire.cache.DiskStoreFactory;
 +import com.gemstone.gemfire.cache.Region;
  import com.gemstone.gemfire.distributed.DistributedSystem;
  import com.gemstone.gemfire.internal.HeapDataOutputStream;
  import com.gemstone.gemfire.internal.InternalDataSerializer;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskOldAPIsJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskOldAPIsJUnitTest.java
index c0e4e88,ccf6c87..1b78dae
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskOldAPIsJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskOldAPIsJUnitTest.java
@@@ -16,28 -16,21 +16,38 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
 +import static org.junit.Assert.*;
 +
 +import java.io.File;
 +import java.util.Properties;
 +import java.util.Set;
 +
+ import com.gemstone.gemfire.cache.*;
+ import com.gemstone.gemfire.distributed.DistributedSystem;
+ import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
  import org.junit.After;
  import org.junit.Before;
  import org.junit.Test;
  import org.junit.experimental.categories.Category;
  
 +import com.gemstone.gemfire.cache.AttributesFactory;
 +import com.gemstone.gemfire.cache.Cache;
 +import com.gemstone.gemfire.cache.CacheFactory;
 +import com.gemstone.gemfire.cache.DataPolicy;
 +import com.gemstone.gemfire.cache.DiskWriteAttributesFactory;
 +import com.gemstone.gemfire.cache.EvictionAction;
 +import com.gemstone.gemfire.cache.EvictionAttributes;
 +import com.gemstone.gemfire.cache.Region;
 +import com.gemstone.gemfire.distributed.DistributedSystem;
 +import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 +
+ import java.io.File;
+ import java.util.Properties;
+ import java.util.Set;
+ 
+ import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+ import static org.junit.Assert.*;
+ 
  /**
   * Tests the old disk apis to make sure they do the correct thing.
   * Once we drop these old deprecated disk apis then this unit test can be removed.
@@@ -48,19 -44,19 +58,17 @@@ public class DiskOldAPIsJUnitTest 
    protected static Cache cache = null;
  
    protected static DistributedSystem ds = null;
--  protected static Properties props = new Properties();
- 
-   static {
-     props.setProperty("mcast-port", "0");
-     props.setProperty("locators", "");
-     props.setProperty("log-level", "config"); // to keep diskPerf logs smaller
-     props.setProperty("statistic-sampling-enabled", "true");
-     props.setProperty("enable-time-statistics", "true");
-     props.setProperty("statistic-archive-file", "stats.gfs");
-   }
  
 -  static {
 +  @Before
 +  public void setUp() throws Exception {
++    Properties props = new Properties();
+     props.setProperty(MCAST_PORT, "0");
+     props.setProperty(LOCATORS, "");
+     props.setProperty(LOG_LEVEL, "config"); // to keep diskPerf logs smaller
+     props.setProperty(STATISTIC_SAMPLING_ENABLED, "true");
+     props.setProperty(ENABLE_TIME_STATISTICS, "true");
+     props.setProperty(STATISTIC_ARCHIVE_FILE, "stats.gfs");
 -  }
+ 
 -  @Before
 -  public void setUp() throws Exception {
      cache = new CacheFactory(props).create();
      ds = cache.getDistributedSystem();
      DiskStoreImpl.SET_IGNORE_PREALLOCATE = true;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegCacheXmlJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegCacheXmlJUnitTest.java
index 132cd69,840cb67..3849be3
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegCacheXmlJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegCacheXmlJUnitTest.java
@@@ -16,28 -16,23 +16,28 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
 -import com.gemstone.gemfire.SystemFailure;
 -import com.gemstone.gemfire.cache.*;
 -import com.gemstone.gemfire.distributed.DistributedSystem;
 -import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 -import com.gemstone.gemfire.util.test.TestUtil;
 -import org.junit.After;
 -import org.junit.Test;
 -import org.junit.experimental.categories.Category;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
  
  import java.io.File;
  import java.util.Arrays;
  import java.util.Iterator;
  import java.util.Properties;
  
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 -import static org.junit.Assert.assertTrue;
 -import static org.junit.Assert.fail;
 +import org.junit.After;
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
 +
 +import com.gemstone.gemfire.SystemFailure;
 +import com.gemstone.gemfire.cache.Cache;
 +import com.gemstone.gemfire.cache.CacheFactory;
 +import com.gemstone.gemfire.cache.CacheTransactionManager;
 +import com.gemstone.gemfire.cache.DiskStore;
 +import com.gemstone.gemfire.cache.Region;
 +import com.gemstone.gemfire.cache.RegionAttributes;
 +import com.gemstone.gemfire.distributed.DistributedSystem;
- import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 +import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 +import com.gemstone.gemfire.util.test.TestUtil;
  
  /**
   * This test is for testing Disk attributes set via xml.
@@@ -45,18 -40,19 +45,18 @@@
   * A cache and region are created using an xml. The regions are then verified to make sure
   * that all the attributes have been correctly set
   * 
-  * @since 5.1
+  * @since GemFire 5.1
   */
  @Category(IntegrationTest.class)
 -public class DiskRegCacheXmlJUnitTest
 -{
 -  Cache cache = null;
 +public class DiskRegCacheXmlJUnitTest {
  
 -  DistributedSystem ds = null;
 +  private Cache cache = null;
  
 -  protected static File[] dirs = null;
 +  private DistributedSystem ds = null;
  
 -  public void mkDirAndConnectDs()
 -  {
 +  private static File[] dirs = null;
 +
 +  private void mkDirAndConnectDs() {
      File file1 = new File("d1");
      file1.mkdir();
      file1.deleteOnExit();
@@@ -72,13 -68,19 +72,13 @@@
      dirs[2] = file3;
      // Connect to the GemFire distributed system
      Properties props = new Properties();
-     props.setProperty(DistributionConfig.NAME_NAME, "test");
+     props.setProperty(NAME, "test");
      String path = TestUtil.getResourcePath(getClass(), "DiskRegCacheXmlJUnitTest.xml");
-     props.setProperty("mcast-port", "0");
-     props.setProperty("cache-xml-file", path);
+     props.setProperty(MCAST_PORT, "0");
+     props.setProperty(CACHE_XML_FILE, path);
      ds = DistributedSystem.connect(props);
 -    try {
 -      // Create the cache which causes the cache-xml-file to be parsed
 -      cache = CacheFactory.create(ds);
 -    }
 -    catch (Exception ex) {
 -      ds.getLogWriter().error("Exception occured",ex);
 -      fail("failed to create cache due to "+ex);
 -    }
 +    // Create the cache which causes the cache-xml-file to be parsed
 +    cache = CacheFactory.create(ds);
    }
  
    @Test

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegCachexmlGeneratorJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegCachexmlGeneratorJUnitTest.java
index 47004a6,76eaab8..591046f
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegCachexmlGeneratorJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegCachexmlGeneratorJUnitTest.java
@@@ -16,244 -16,230 +16,204 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
 -import com.gemstone.gemfire.cache.CacheFactory;
 -import com.gemstone.gemfire.cache.Region;
 -import com.gemstone.gemfire.cache.Scope;
 -import com.gemstone.gemfire.distributed.DistributedSystem;
 -import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator;
 -import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 -import org.junit.After;
 -import org.junit.Before;
 -import org.junit.Test;
 -import org.junit.experimental.categories.Category;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+ 
  import java.io.File;
  import java.io.FileWriter;
 +import java.io.IOException;
  import java.io.PrintWriter;
  import java.util.Properties;
  
- import org.junit.After;
- import org.junit.Before;
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 -import static org.junit.Assert.fail;
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
 +
- import static org.junit.Assert.*;
- 
- import com.gemstone.gemfire.cache.*;
++import com.gemstone.gemfire.cache.CacheFactory;
++import com.gemstone.gemfire.cache.Region;
++import com.gemstone.gemfire.cache.Scope;
 +import com.gemstone.gemfire.distributed.DistributedSystem;
- import com.gemstone.gemfire.distributed.internal.DistributionConfig;
- import com.gemstone.gemfire.internal.AvailablePort;
- import com.gemstone.gemfire.internal.cache.xmlcache.*;
++import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator;
 +import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
  
  /**
   * This test is for testing Disk attributes set programmatically
   * The generated cacheXml is used to create a cache and teh region
   * properties retested.
 - * 
   */
  @Category(IntegrationTest.class)
 -public class DiskRegCachexmlGeneratorJUnitTest extends DiskRegionTestingBase
 -{
 -  PrintWriter pw;
 -
 -  DiskRegionProperties diskProps = new DiskRegionProperties();
 +public class DiskRegCachexmlGeneratorJUnitTest extends DiskRegionTestingBase {
  
-   private PrintWriter pw;
- 
-   private DiskRegionProperties diskProps = new DiskRegionProperties();
-   private DiskRegionProperties diskProps1 = new DiskRegionProperties();
-   private DiskRegionProperties diskProps2 = new DiskRegionProperties();
-   private DiskRegionProperties diskProps3 = new DiskRegionProperties();
-   private DiskRegionProperties diskProps4 = new DiskRegionProperties();
-   private DiskRegionProperties diskProps5 = new DiskRegionProperties();
-   private DiskRegionProperties diskProps6 = new DiskRegionProperties();
-   private DiskRegionProperties diskProps7 = new DiskRegionProperties();
-   private DiskRegionProperties diskProps8 = new DiskRegionProperties();
-   private DiskRegionProperties diskProps9 = new DiskRegionProperties();
-   private DiskRegionProperties diskProps10 = new DiskRegionProperties();
-   private DiskRegionProperties diskProps11 = new DiskRegionProperties();
-   private DiskRegionProperties diskProps12 = new DiskRegionProperties();
- 
-   private Region region1;
-   private Region region2;
-   private Region region3;
-   private Region region4;
-   private Region region5;
-   private Region region6;
-   private Region region7;
-   private Region region8;
-   private Region region9;
-   private Region region10;
-   private Region region11;
-   private Region region12;
 -  DiskRegionProperties[] diskRegionProperties = new DiskRegionProperties[12];
++  private DiskRegionProperties[] diskRegionProperties = new DiskRegionProperties[12];
+ 
 -  Region[] regions = new Region[12];
++  private Region[] regions = new Region[12];
  
 -  @Before
 -  public void setUp() throws Exception
 -  {
 -    super.setUp();
 +  @Override
 +  protected final void postSetUp() throws Exception {
      diskDirSize = new int[4];
      diskDirSize[0] = Integer.MAX_VALUE;
      diskDirSize[1] = Integer.MAX_VALUE;
      diskDirSize[2] = 1073741824;
      diskDirSize[3] = 2073741824;
-     diskProps1.setDiskDirsAndSizes(dirs, diskDirSize);
-     diskProps2.setDiskDirs(dirs);
-     diskProps3.setDiskDirs(dirs);
-     diskProps4.setDiskDirs(dirs);
-     diskProps5.setDiskDirs(dirs);
-     diskProps6.setDiskDirs(dirs);
-     diskProps7.setDiskDirs(dirs);
-     diskProps8.setDiskDirs(dirs);
-     diskProps9.setDiskDirs(dirs);
-     diskProps10.setDiskDirs(dirs);
-     diskProps11.setDiskDirs(dirs);
-     diskProps12.setDiskDirs(dirs);
+ 
+     for (int i = 0; i < diskRegionProperties.length; i++) {
+       diskRegionProperties[i] = new DiskRegionProperties();
+       if(i == 0)
+       {
+         diskRegionProperties[i].setDiskDirsAndSizes(dirs, diskDirSize);
+       }
+       else{
+         diskRegionProperties[i].setDiskDirs(dirs);
+       }
+     }
    }
  
-   private void createCacheXML() throws IOException {
-     // create the region1 which is SyncPersistOnly and set DiskWriteAttibutes
-     diskProps1.setRolling(true);
-     diskProps1.setMaxOplogSize(1073741824L);
-     diskProps1.setRegionName("region1");
-     region1 = DiskRegionHelperFactory.getSyncPersistOnlyRegion(cache,
-         diskProps1, Scope.LOCAL);
- 
-     // create the region2 which is SyncPersistOnly and set DiskWriteAttibutes
- 
-     diskProps2.setRolling(false);
-     diskProps2.setRegionName("region2");
-     region2 = DiskRegionHelperFactory.getSyncPersistOnlyRegion(cache,
-         diskProps2, Scope.LOCAL);
- 
-     // create the region3 which AsyncPersistOnly, No buffer and Rolling oplog
-     diskProps3.setRolling(true);
-     diskProps3.setMaxOplogSize(1073741824L);
-     diskProps3.setRegionName("region3");
-     region3 = DiskRegionHelperFactory.getAsyncPersistOnlyRegion(cache,
-         diskProps3);
- 
-     // create the region4 which is AsynchPersistonly, No buffer and fixed oplog
-     diskProps4.setRolling(false);
-     diskProps4.setRegionName("region4");
-     region4 = DiskRegionHelperFactory.getAsyncPersistOnlyRegion(cache,
-         diskProps4);
- 
-     // create the region5 which is SynchOverflowOnly, Rolling oplog
-     diskProps5.setRolling(true);
-     diskProps5.setMaxOplogSize(1073741824L);
-     diskProps5.setRegionName("region5");
-     region5 = DiskRegionHelperFactory.getSyncOverFlowOnlyRegion(cache,
-         diskProps5);
- 
-     // create the region6 which is SyncOverflowOnly, Fixed oplog
-     diskProps6.setRolling(false);
-     diskProps6.setRegionName("region6");
-     region6 = DiskRegionHelperFactory.getSyncOverFlowOnlyRegion(cache,
-         diskProps6);
 -  @After
 -  public void tearDown() throws Exception
 -  {
 -    super.tearDown();
--
-     // create the region7 which is AsyncOverflow, with Buffer and rolling oplog
-     diskProps7.setRolling(true);
-     diskProps7.setMaxOplogSize(1073741824L);
-     diskProps7.setBytesThreshold(10000l);
-     diskProps7.setTimeInterval(15l);
-     diskProps7.setRegionName("region7");
-     region7 = DiskRegionHelperFactory.getAsyncOverFlowOnlyRegion(cache,
-         diskProps7);
 -  }
--
-     // create the region8 which is AsyncOverflow ,Time base buffer-zero byte
 -  public void createCacheXML()
 -  {
++  public void createCacheXML() throws IOException {
+     // create the regions[0] which is SyncPersistOnly and set DiskWriteAttibutes
+     diskRegionProperties[0].setRolling(true);
+     diskRegionProperties[0].setMaxOplogSize(1073741824L);
+     diskRegionProperties[0].setRegionName("regions1");
+     regions[0] = DiskRegionHelperFactory.getSyncPersistOnlyRegion(cache,
 -        diskRegionProperties[0], Scope.LOCAL);
++      diskRegionProperties[0], Scope.LOCAL);
+ 
+     // create the regions[1] which is SyncPersistOnly and set DiskWriteAttibutes
+ 
+     diskRegionProperties[1].setRolling(false);
+     diskRegionProperties[1].setRegionName("regions2");
+     regions[1] = DiskRegionHelperFactory.getSyncPersistOnlyRegion(cache,
 -        diskRegionProperties[1], Scope.LOCAL);
++      diskRegionProperties[1], Scope.LOCAL);
+ 
+     // create the regions[2] which AsyncPersistOnly, No buffer and Rolling oplog
+     diskRegionProperties[2].setRolling(true);
+     diskRegionProperties[2].setMaxOplogSize(1073741824L);
+     diskRegionProperties[2].setRegionName("regions3");
+     regions[2] = DiskRegionHelperFactory.getAsyncPersistOnlyRegion(cache,
 -        diskRegionProperties[2]);
++      diskRegionProperties[2]);
+ 
+     // create the regions[3] which is AsynchPersistonly, No buffer and fixed oplog
+     diskRegionProperties[3].setRolling(false);
+     diskRegionProperties[3].setRegionName("regions4");
+     regions[3] = DiskRegionHelperFactory.getAsyncPersistOnlyRegion(cache,
 -        diskRegionProperties[3]);
++      diskRegionProperties[3]);
+ 
+     // create the regions[4] which is SynchOverflowOnly, Rolling oplog
+     diskRegionProperties[4].setRolling(true);
+     diskRegionProperties[4].setMaxOplogSize(1073741824L);
+     diskRegionProperties[4].setRegionName("regions5");
+     regions[4] = DiskRegionHelperFactory.getSyncOverFlowOnlyRegion(cache,
 -        diskRegionProperties[4]);
++      diskRegionProperties[4]);
+ 
+     // create the regions[5] which is SyncOverflowOnly, Fixed oplog
+     diskRegionProperties[5].setRolling(false);
+     diskRegionProperties[5].setRegionName("regions6");
+     regions[5] = DiskRegionHelperFactory.getSyncOverFlowOnlyRegion(cache,
 -        diskRegionProperties[5]);
++      diskRegionProperties[5]);
+ 
+     // create the regions[6] which is AsyncOverflow, with Buffer and rolling oplog
+     diskRegionProperties[6].setRolling(true);
+     diskRegionProperties[6].setMaxOplogSize(1073741824L);
+     diskRegionProperties[6].setBytesThreshold(10000l);
+     diskRegionProperties[6].setTimeInterval(15l);
+     diskRegionProperties[6].setRegionName("regions7");
+     regions[6] = DiskRegionHelperFactory.getAsyncOverFlowOnlyRegion(cache,
 -        diskRegionProperties[6]);
++      diskRegionProperties[6]);
+ 
+     // create the regions[7] which is AsyncOverflow ,Time base buffer-zero byte
      // buffer
      // and Fixed oplog
-     diskProps8.setRolling(false);
-     diskProps8.setTimeInterval(15l);
-     diskProps8.setBytesThreshold(0l);
-     diskProps8.setRegionName("region8");
-     region8 = DiskRegionHelperFactory.getAsyncOverFlowOnlyRegion(cache,
-         diskProps8);
- 
-     // create the region9 which is SyncPersistOverflow, Rolling oplog
-     diskProps9.setRolling(true);
-     diskProps9.setMaxOplogSize(1073741824L);
-     diskProps9.setRegionName("region9");
-     region9 = DiskRegionHelperFactory.getSyncOverFlowAndPersistRegion(cache,
-         diskProps9);
- 
-     // create the region10 which is Sync PersistOverflow, fixed oplog
-     diskProps10.setRolling(false);
-     diskProps10.setRegionName("region10");
-     region10 = DiskRegionHelperFactory.getSyncOverFlowAndPersistRegion(cache,
-         diskProps10);
-     // create the region11 which is Async Overflow Persist ,with buffer and
+     diskRegionProperties[7].setRolling(false);
+     diskRegionProperties[7].setTimeInterval(15l);
+     diskRegionProperties[7].setBytesThreshold(0l);
+     diskRegionProperties[7].setRegionName("regions8");
+     regions[7] = DiskRegionHelperFactory.getAsyncOverFlowOnlyRegion(cache,
 -        diskRegionProperties[7]);
++      diskRegionProperties[7]);
+ 
+     // create the regions[8] which is SyncPersistOverflow, Rolling oplog
+     diskRegionProperties[8].setRolling(true);
+     diskRegionProperties[8].setMaxOplogSize(1073741824L);
+     diskRegionProperties[8].setRegionName("regions9");
+     regions[8] = DiskRegionHelperFactory.getSyncOverFlowAndPersistRegion(cache,
 -        diskRegionProperties[8]);
++      diskRegionProperties[8]);
+ 
+     // create the regions[9] which is Sync PersistOverflow, fixed oplog
+     diskRegionProperties[9].setRolling(false);
+     diskRegionProperties[9].setRegionName("regions10");
+     regions[9] = DiskRegionHelperFactory.getSyncOverFlowAndPersistRegion(cache,
 -        diskRegionProperties[9]);
++      diskRegionProperties[9]);
+     // create the regions[10] which is Async Overflow Persist ,with buffer and
      // rollong
      // oplog
-     diskProps11.setRolling(true);
-     diskProps11.setMaxOplogSize(1073741824L);
-     diskProps11.setBytesThreshold(10000l);
-     diskProps11.setTimeInterval(15l);
-     diskProps11.setRegionName("region11");
-     region11 = DiskRegionHelperFactory.getAsyncOverFlowAndPersistRegion(cache,
-         diskProps11);
- 
-     // create the region12 which is Async Persist Overflow with time based
+     diskRegionProperties[10].setRolling(true);
+     diskRegionProperties[10].setMaxOplogSize(1073741824L);
+     diskRegionProperties[10].setBytesThreshold(10000l);
+     diskRegionProperties[10].setTimeInterval(15l);
+     diskRegionProperties[10].setRegionName("regions11");
+     regions[10] = DiskRegionHelperFactory.getAsyncOverFlowAndPersistRegion(cache,
 -        diskRegionProperties[10]);
++      diskRegionProperties[10]);
+ 
+     // create the regions[11] which is Async Persist Overflow with time based
      // buffer
      // and Fixed oplog
-     diskProps12.setRolling(false);
-     diskProps12.setBytesThreshold(0l);
-     diskProps12.setTimeInterval(15l);
-     diskProps12.setRegionName("region12");
-     region12 = DiskRegionHelperFactory.getAsyncOverFlowAndPersistRegion(cache,
-         diskProps12);
+     diskRegionProperties[11].setRolling(false);
+     diskRegionProperties[11].setBytesThreshold(0l);
+     diskRegionProperties[11].setTimeInterval(15l);
+     diskRegionProperties[11].setRegionName("regions12");
+     regions[11] = DiskRegionHelperFactory.getAsyncOverFlowAndPersistRegion(cache,
 -        diskRegionProperties[11]);
 -
++      diskRegionProperties[11]);
  
      //cacheXmlGenerator: generates cacheXml file
-     FileWriter fw = new FileWriter(new File("DiskRegCachexmlGeneratorJUnitTest.xml"));
 -    try {
 -      FileWriter fw = new FileWriter(new File("DiskRegCachexmlGeneratorJUnitTest.xml"));
 -      PrintWriter pw = new PrintWriter(fw);
 -      CacheXmlGenerator.generate(cache, pw);
 -    }
 -    catch (Exception ex) {
 -      logWriter.error("Exception occured",ex);
 -      fail("FAILED While cache xml generation");
 -    }
 -
++    FileWriter fw = new FileWriter(new File(getClass().getSimpleName() + ".xml"));
 +    PrintWriter pw = new PrintWriter(fw);
 +    CacheXmlGenerator.generate(cache, pw);
    }
--  
++
    @Test
 -  public void testVerifyCacheXml() throws Exception
 -  {
 +  public void testVerifyCacheXml() throws Exception {
      createCacheXML();
      ds.disconnect();
      // Connect to the GemFire distributed system
      Properties props = new Properties();
-     props.setProperty(DistributionConfig.NAME_NAME, "DiskRegCachexmlGeneratorJUnitTest");
-     props.setProperty("mcast-port", "0");
-     String path = "DiskRegCachexmlGeneratorJUnitTest.xml";
-     props.setProperty("cache-xml-file", path);
 -    props.setProperty(NAME, "DiskRegCachexmlGeneratorJUnitTest");
++    props.setProperty(NAME, getClass().getSimpleName());
+     props.setProperty(MCAST_PORT, "0");
 -    String path = "DiskRegCachexmlGeneratorJUnitTest.xml";
++    String path = getClass().getSimpleName() + ".xml";
+     props.setProperty(CACHE_XML_FILE, path);
      ds = DistributedSystem.connect(props);
      // Create the cache which causes the cache-xml-file to be parsed
      cache = CacheFactory.create(ds);
  
-     // Get the region1 
-     region1 = cache.getRegion("region1");
-     verify((LocalRegion)region1, diskProps1);
- 
-     // Get the region2
-     Region region2 = cache.getRegion("region2");
-     verify((LocalRegion)region2, diskProps2);
- 
-     // Get the region3 
-     Region region3 = cache.getRegion("region3");
-     verify((LocalRegion)region3, diskProps3);
- 
-     // Get the region4 
-     Region region4 = cache.getRegion("region4");
-     verify((LocalRegion)region4, diskProps4);
-     
-     // Get the region5 
-     Region region5 = cache.getRegion("region5");
-     verify((LocalRegion)region5, diskProps5);
- 
-     // Get the region6 
-     Region region6 = cache.getRegion("region6");
-     verify((LocalRegion)region6, diskProps6);
-     
-     // Get the region7 
-     Region region7 = cache.getRegion("region7");
-     verify((LocalRegion)region7, diskProps7);
- 
-     // Get the region8 
-     Region region8 = cache.getRegion("region8");
-     verify((LocalRegion)region8, diskProps8);
- 
-     // Get the region9 
-     Region region9 = cache.getRegion("region9");
-     verify((LocalRegion)region9, diskProps9);
- 
-     // Get the region10 
-     Region region10 = cache.getRegion("region10");
-     verify((LocalRegion)region10, diskProps10);
- 
-     // Get the region11
-     Region region11 = cache.getRegion("region11");
-     verify((LocalRegion)region11, diskProps11);
- 
-     // Get the region12 
-     Region region12 = cache.getRegion("region12");
-     verify((LocalRegion)region12, diskProps12);
 -    // Get the regions[0] 
++    // Get the regions[0]
+     verify((LocalRegion) cache.getRegion("regions1"), diskRegionProperties[0]);
+ 
+     // Get the regions[1]
+     verify((LocalRegion) cache.getRegion("regions2"), diskRegionProperties[1]);
+ 
 -    // Get the regions[2] 
++    // Get the regions[2]
+     verify((LocalRegion) cache.getRegion("regions3"), diskRegionProperties[2]);
+ 
 -    // Get the regions[3] 
++    // Get the regions[3]
+     verify((LocalRegion) cache.getRegion("regions4"), diskRegionProperties[3]);
 -    
 -    // Get the regions[4] 
++
++    // Get the regions[4]
+     verify((LocalRegion) cache.getRegion("regions5"), diskRegionProperties[4]);
+ 
 -    // Get the regions[5] 
++    // Get the regions[5]
+     verify((LocalRegion) cache.getRegion("regions6"), diskRegionProperties[5]);
 -    
 -    // Get the regions[6] 
++
++    // Get the regions[6]
+     verify((LocalRegion) cache.getRegion("regions7"), diskRegionProperties[6]);
+ 
 -    // Get the regions[7] 
++    // Get the regions[7]
+     verify((LocalRegion) cache.getRegion("regions8"), diskRegionProperties[7]);
+ 
 -    // Get the regions[8] 
++    // Get the regions[8]
+     verify((LocalRegion) cache.getRegion("regions9"), diskRegionProperties[8]);
+ 
 -    // Get the regions[9] 
++    // Get the regions[9]
+     verify((LocalRegion) cache.getRegion("regions10"), diskRegionProperties[9]);
+ 
+     // Get the regions[10]
+     verify((LocalRegion) cache.getRegion("regions11"), diskRegionProperties[10]);
+ 
 -    // Get the regions[11] 
++    // Get the regions[11]
+     verify((LocalRegion) cache.getRegion("regions12"), diskRegionProperties[11]);
    }
  
--}// end of DiskRegCachexmlGeneratorJUnitTest
 -
++}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegRecoveryJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegRecoveryJUnitTest.java
index 391aed0,4e3beaa..792f07e
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegRecoveryJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegRecoveryJUnitTest.java
@@@ -40,12 -42,30 +40,12 @@@ import com.gemstone.gemfire.test.junit.
  /**
   * Disk region recovery tests
   * 
-  * @since 5.1
+  * @since GemFire 5.1
   */
  @Category(IntegrationTest.class)
 -public class DiskRegRecoveryJUnitTest extends DiskRegionTestingBase
 -{
 -  DiskRegionProperties diskProps = new DiskRegionProperties();
 -  
 -  private static int EMPTY_RVV_SIZE = 6;
 -
 -//  private static final boolean debug = false;
 -
 -  @Before
 -  public void setUp() throws Exception
 -  {
 -    super.setUp();
 -    diskProps.setDiskDirs(dirs);
 -  }
 -
 -  @After
 -  public void tearDown() throws Exception
 -  {
 -    super.tearDown();
 -  }
 +public class DiskRegRecoveryJUnitTest extends DiskRegionTestingBase {
  
 +  private static int EMPTY_RVV_SIZE = 6;
    private static int ENTRY_SIZE = 1024;
  
    private static boolean oplogsIDsNotifiedToRoll;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionClearJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionClearJUnitTest.java
index f9a17c5,b38de12..8d1fe4f
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionClearJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionClearJUnitTest.java
@@@ -16,11 -16,12 +16,12 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
 -import com.gemstone.gemfire.SystemFailure;
 -import com.gemstone.gemfire.cache.*;
 -import com.gemstone.gemfire.distributed.DistributedSystem;
 -import com.gemstone.gemfire.test.dunit.ThreadUtils;
 -import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 -import junit.framework.Assert;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
 +
 +import java.util.Iterator;
 +import java.util.Properties;
 +
  import org.junit.After;
  import org.junit.Before;
  import org.junit.Test;
@@@ -45,24 -41,23 +46,19 @@@ import com.gemstone.gemfire.test.junit.
   * 
   * Data on disk should reflect data in memory. A put while clear is going on should
   * wait for clear and if it is successfully recorded in memory than it should
-- * be recored on disk. Else if not successfully recorded in memory than should not be
++ * be recorded on disk. Else if not successfully recorded in memory than should not be
   * recorded on disk
 - * 
 + *
 + * TODO: use DiskRegionTestingBase and DiskRegionHelperFactory
   */
  @Category(IntegrationTest.class)
  public class DiskRegionClearJUnitTest {
  
 -  static Region testRegion = null;
 -  static Object returnObject = null;
 -  static boolean done = false;
 -  static volatile int counter = 0;
 -  static volatile boolean cleared = false;
 -  static volatile long entries = 0;
 -  static Cache cache = null;  
 -  static DistributedSystem distributedSystem = null;
 -  
 -  private static String regionName = "TestRegion";
 +  private static Region testRegion = null;
-   private static Object returnObject = null;
-   private static boolean done = false;
 +  private static volatile int counter = 0;
 +  private static volatile boolean cleared = false;
-   private static volatile long entries = 0;
 +  private static Cache cache = null;
 +  private static DistributedSystem distributedSystem = null;
-   
-   private static String regionName = "TestRegion";
  
    @Before
    public void setUp() throws Exception {
@@@ -117,8 -113,8 +113,7 @@@
        }
      }
    }
--  
--  
++
    /**
     * Make sure the disk region stats are set to zero when the region is cleared.
     */
@@@ -182,59 -179,66 +177,58 @@@
    }
  
    @Test
 -  public void testRecreateRegionAndCacheNegative() {
 -    try {
 -      LocalRegion.ISSUE_CALLBACKS_TO_CACHE_OBSERVER = false;
 -      for(long i=0;i<100; i++) {
 -        testRegion.put(new Long(i), new Long(i));
 -      }
 -      testRegion.clear();
 -      assertEquals(0, testRegion.size());
 -      cache.close();
 -      distributedSystem.disconnect();
 -      Properties properties = new Properties();
 -      properties.setProperty(MCAST_PORT, "0");
 -      properties.setProperty(LOCATORS, "");
 -      distributedSystem = DistributedSystem.connect(properties);
 -      cache = CacheFactory.create(distributedSystem);
 -      AttributesFactory factory = new AttributesFactory();
 -      factory.setScope(Scope.DISTRIBUTED_ACK);
 -      factory.setDataPolicy(DataPolicy.PERSISTENT_REPLICATE);
 -      RegionAttributes regionAttributes = factory.create();
 -      testRegion = cache.createRegion("TestRegion1", regionAttributes);
 -      
 +  public void testRecreateRegionAndCacheNegative() throws Exception {
 +    LocalRegion.ISSUE_CALLBACKS_TO_CACHE_OBSERVER = false;
 +    for(long i=0;i<100; i++) {
 +      testRegion.put(new Long(i), new Long(i));
      }
 -    catch (Exception e) {
 -      fail("test failed due to "+e);
 -     }
 +    testRegion.clear();
 +    assertEquals(0, testRegion.size());
 +    cache.close();
 +    distributedSystem.disconnect();
 +    Properties properties = new Properties();
-     properties.setProperty("mcast-port", "0");
-     properties.setProperty("locators", "");
++    properties.setProperty(MCAST_PORT, "0");
++    properties.setProperty(LOCATORS, "");
 +    distributedSystem = DistributedSystem.connect(properties);
 +    cache = CacheFactory.create(distributedSystem);
 +    AttributesFactory factory = new AttributesFactory();
 +    factory.setScope(Scope.DISTRIBUTED_ACK);
 +    factory.setDataPolicy(DataPolicy.PERSISTENT_REPLICATE);
 +    RegionAttributes regionAttributes = factory.create();
 +    testRegion = cache.createRegion("TestRegion1", regionAttributes);
 +      
      System.out.println("keySet after recovery = " + testRegion.keySet());
      assertEquals(0, testRegion.size());
    }
    
    @Test
    public void testRecreateRegionAndCachePositive() {
--    int size = 0;
 -      LocalRegion.ISSUE_CALLBACKS_TO_CACHE_OBSERVER = false;
 -      for(long i=0;i<1000; i++) {
 -        testRegion.put(new Long(i), new Long(i));
 -      }
 -      testRegion.clear();
 -      for(long i=0;i<1000; i++) {
 -        testRegion.put(new Long(i), new Long(i));
 -      }
 -      assertEquals(1000, testRegion.size());
 -      cache.close();
 -      distributedSystem.disconnect();
 -      Properties properties = new Properties();
 +    LocalRegion.ISSUE_CALLBACKS_TO_CACHE_OBSERVER = false;
 +    for(long i=0;i<1000; i++) {
 +      testRegion.put(new Long(i), new Long(i));
 +    }
 +    testRegion.clear();
 +    for(long i=0;i<1000; i++) {
 +      testRegion.put(new Long(i), new Long(i));
 +    }
 +    assertEquals(1000, testRegion.size());
 +    cache.close();
 +    distributedSystem.disconnect();
 +    Properties properties = new Properties();
-     properties.setProperty("mcast-port", "0");
-     properties.setProperty("locators", "");
+     properties.setProperty(MCAST_PORT, "0");
+     properties.setProperty(LOCATORS, "");
 -      distributedSystem = DistributedSystem.connect(properties);
 -      cache = CacheFactory.create(distributedSystem);
 -      AttributesFactory factory = new AttributesFactory();
 -      factory.setScope(Scope.DISTRIBUTED_ACK);
 -      factory.setDataPolicy(DataPolicy.PERSISTENT_REPLICATE);
 -      RegionAttributes regionAttributes = factory.create();
 -      testRegion = cache.createRegion("TestRegion1", regionAttributes);
 +    distributedSystem = DistributedSystem.connect(properties);
 +    cache = CacheFactory.create(distributedSystem);
 +    AttributesFactory factory = new AttributesFactory();
 +    factory.setScope(Scope.DISTRIBUTED_ACK);
 +    factory.setDataPolicy(DataPolicy.PERSISTENT_REPLICATE);
 +    RegionAttributes regionAttributes = factory.create();
 +    testRegion = cache.createRegion("TestRegion1", regionAttributes);
      assertEquals(1000, testRegion.size());
    }
 -  
 -  protected static class Thread1 implements Runnable {
  
 -    
 -    
 +  private static class Thread1 implements Runnable {
- 
++    @Override
      public void run() {
        for(long i=0 ; i< 100 ; i++) {     
        testRegion.put(new Long(i), new Long(i));
@@@ -243,19 -247,20 +237,21 @@@
      }
    }
  
 -  protected static class Thread2 implements Runnable {
 -
 +  private static class Thread2 implements Runnable {
- 
++    @Override
      public void run() {
        testRegion.clear();
      }
    }
  
 -  protected static class CacheObserverListener extends CacheObserverAdapter {
 -    
 -    
 +  private static class CacheObserverListener extends CacheObserverAdapter {
-     
++
++    @Override
      public void afterRegionClear(RegionEvent event) {
        cleared = true;
      }
  
++    @Override
      public void beforeDiskClear() {
        for(int i=0; i<3; i++) {
        Thread thread = new Thread(new Thread1());

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionIllegalArguementsJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionIllegalArguementsJUnitTest.java
index dbc90c9,fd64ceb..baba67f
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionIllegalArguementsJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionIllegalArguementsJUnitTest.java
@@@ -16,46 -16,53 +16,45 @@@
   */
  package com.gemstone.gemfire.internal.cache;
  
+ import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
 +
 +import java.io.File;
 +import java.util.Properties;
  
 -import com.gemstone.gemfire.cache.Cache;
 -import com.gemstone.gemfire.cache.CacheFactory;
 -import com.gemstone.gemfire.cache.DiskStoreFactory;
 -import com.gemstone.gemfire.distributed.DistributedSystem;
 -import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
  import org.junit.After;
  import org.junit.Before;
  import org.junit.Test;
  import org.junit.experimental.categories.Category;
  
 -import java.io.File;
 -import java.util.Properties;
 -
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.LOCATORS;
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.MCAST_PORT;
 -import static org.junit.Assert.assertEquals;
 -import static org.junit.Assert.fail;
 +import com.gemstone.gemfire.cache.Cache;
 +import com.gemstone.gemfire.cache.CacheFactory;
 +import com.gemstone.gemfire.cache.DiskStoreFactory;
 +import com.gemstone.gemfire.distributed.DistributedSystem;
 +import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
  
  /**
-- * This test tests Illegal arguements being passed to create disk regions. The
++ * This test tests Illegal arguments being passed to create disk regions. The
   * creation of the DWA object should throw a relevant exception if the
-- * arguements specified are incorrect.
 - * 
 - *  
++ * arguments specified are incorrect.
   */
  @Category(IntegrationTest.class)
 -public class DiskRegionIllegalArguementsJUnitTest
 -{
 +public class DiskRegionIllegalArguementsJUnitTest {
  
    protected static Cache cache = null;
  
    protected static DistributedSystem ds = null;
--  protected static Properties props = new Properties();
- 
-   static {
-     props.setProperty("mcast-port", "0");
-     props.setProperty("locators", "");
-     props.setProperty("log-level", "config"); // to keep diskPerf logs smaller
-     props.setProperty("statistic-sampling-enabled", "true");
-     props.setProperty("enable-time-statistics", "true");
-     props.setProperty("statistic-archive-file", "stats.gfs");
-   }
  
 -  static {
 +  @Before
 +  public void setUp() throws Exception {
++    Properties props = new Properties();
+     props.setProperty(MCAST_PORT, "0");
+     props.setProperty(LOCATORS, "");
+     props.setProperty(LOG_LEVEL, "config"); // to keep diskPerf logs smaller
+     props.setProperty(STATISTIC_SAMPLING_ENABLED, "true");
+     props.setProperty(ENABLE_TIME_STATISTICS, "true");
+     props.setProperty(STATISTIC_ARCHIVE_FILE, "stats.gfs");
 -  }
+ 
 -  @Before
 -  public void setUp() throws Exception {
      cache = new CacheFactory(props).create();
      ds = cache.getDistributedSystem();
    }
@@@ -68,7 -75,7 +67,6 @@@
    /**
     * test Illegal max oplog size
     */
--
    @Test
    public void testMaxOplogSize()
    {