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:00 UTC

[45/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/management/CacheManagementDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/management/CacheManagementDUnitTest.java
index b9cf205,9d314dd..8cbbf03
--- a/geode-core/src/test/java/com/gemstone/gemfire/management/CacheManagementDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/management/CacheManagementDUnitTest.java
@@@ -16,32 -16,7 +16,33 @@@
   */
  package com.gemstone.gemfire.management;
  
 -import com.gemstone.gemfire.cache.*;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static com.jayway.awaitility.Awaitility.*;
 +import static org.hamcrest.Matchers.*;
 +import static org.junit.Assert.*;
 +
 +import java.util.ArrayList;
 +import java.util.HashMap;
 +import java.util.HashSet;
 +import java.util.List;
 +import java.util.Map;
 +import java.util.Properties;
 +import java.util.Set;
 +import java.util.concurrent.TimeUnit;
 +import javax.management.InstanceNotFoundException;
 +import javax.management.JMException;
 +import javax.management.Notification;
 +import javax.management.NotificationListener;
 +import javax.management.ObjectName;
 +
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
 +
 +import com.gemstone.gemfire.cache.Cache;
 +import com.gemstone.gemfire.cache.FixedPartitionAttributes;
 +import com.gemstone.gemfire.cache.Region;
 +import com.gemstone.gemfire.cache.RegionFactory;
 +import com.gemstone.gemfire.cache.RegionShortcut;
  import com.gemstone.gemfire.distributed.DistributedMember;
  import com.gemstone.gemfire.distributed.internal.DistributionConfig;
  import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
@@@ -65,14 -44,13 +66,10 @@@ import com.gemstone.gemfire.test.junit.
   * Goal of the Test : MemberMBean gets created once cache is created. Data like
   * config data and stats are of proper value To check proper federation of
   * MemberMBean including remote ops and remote data access
-- * 
-- * 
   */
 +@Category(DistributedTest.class)
  public class CacheManagementDUnitTest extends ManagementTestBase {
  
--  private static final long serialVersionUID = 1L;
--
    private final String VERIFY_CONFIG_METHOD = "verifyConfigData";
  
    private final String VERIFY_REMOTE_CONFIG_METHOD = "verifyConfigDataRemote";
@@@ -85,7 -63,7 +82,6 @@@
  
    static List<FixedPartitionAttributes> fpaList = new ArrayList<FixedPartitionAttributes>();
  
--
    static final List<Notification> notifList = new ArrayList<Notification>();
    
    // This must be bigger than the dunit ack-wait-threshold for the revoke
@@@ -93,13 -71,12 +89,7 @@@
    // 60 seconds.
    private static final int MAX_WAIT = 70 * 1000;
  
--
--
-   public CacheManagementDUnitTest() {
-     super();
 -  public CacheManagementDUnitTest(String name) {
 -    super(name);
--  }
--
 +  @Test
    public void testGemFireConfigData() throws Exception {
       initManagement(false);
     
@@@ -114,17 -91,16 +104,13 @@@
      args[0] = configMap;
      getManagingNode().invoke(
          CacheManagementDUnitTest.class, VERIFY_REMOTE_CONFIG_METHOD, args);
-- 
    }
  
    /**
     * Tests each and every operations that is defined on the MemberMXBean
--   * 
--   * @throws Exception
     */
 +  @Test
    public void testMemberMBeanOperations() throws Exception {
--    
      initManagement(false);
      
      for (VM vm : managedNodeList) {
@@@ -133,22 -109,22 +119,17 @@@
        
        createLocalRegion(vm,"testRegion");
  
--
--
        String log = (String) vm.invoke(() -> CacheManagementDUnitTest.fetchLog());
        assertNotNull(log);
        LogWriterUtils.getLogWriter().info(
            "<ExpectedString> Log Of Member is " + log.toString()
                + "</ExpectedString> ");
  
--     
--
        vm.invoke(() -> CacheManagementDUnitTest.fetchJVMMetrics());
  
        vm.invoke(() -> CacheManagementDUnitTest.fetchOSMetrics());
  
        vm.invoke(() -> CacheManagementDUnitTest.shutDownMember());
--
      }
      
      VM managingNode = getManagingNode();
@@@ -156,14 -132,13 +137,12 @@@
      args[0] = 1;// Only locator member wont be shutdown
      managingNode.invoke(CacheManagementDUnitTest.class,
          "assertExpectedMembers", args);
--    
    }
  
    /**
     * Invoke remote operations on MemberMBean
--   * @throws Exception
     */
 +  @Test
    public void testMemberMBeanOpsRemote() throws Exception {
      initManagement(false);
      getManagingNode().invoke(() -> CacheManagementDUnitTest.invokeRemoteOps());
@@@ -172,10 -147,9 +151,8 @@@
    /**
     * Creates and starts a manager.
     * Multiple Managers
--   * 
--   * @throws Exception
     */
 +  @Test
    public void testManager() throws Exception {
      List<VM> managedNodeList = getManagedNodeList();
      VM node1 = managedNodeList.get(0);
@@@ -199,16 -173,15 +176,13 @@@
      startManagingNode(managingNode);
      checkManagerView(managingNode, member);
      stopManagingNode(managingNode);
--
    }
    
    /**
     * Creates and starts a manager.
     * Multiple Managers
--   * 
--   * @throws Exception
     */
 +  @Test
    public void testManagerShutdown() throws Exception {
      List<VM> managedNodeList = getManagedNodeList();
      VM node1 = managedNodeList.get(0);
@@@ -251,10 -223,9 +225,9 @@@
      
      closeCache(node3);
      validateServiceResource(node3);
--
    }
    
 +  @Test
    public void testGetMBean() throws Exception{
      List<VM> managedNodeList = getManagedNodeList();
      VM node1 = managedNodeList.get(0);
@@@ -271,10 -242,9 +244,9 @@@
      startManagingNode(managingNode);
  
      checkGetMBean(managingNode);
--
    }
    
 +  @Test
    public void testQueryMBeans() throws Exception{
      List<VM> managedNodeList = getManagedNodeList();
      VM node1 = managedNodeList.get(0);
@@@ -291,7 -261,7 +263,6 @@@
      startManagingNode(managingNode);
  
      checkQueryMBeans(managingNode);
--
    }
  
    protected void checkQueryMBeans(final VM vm) {
@@@ -316,13 -286,13 +287,10 @@@
            assertTrue(names.contains(memberMBeanName));
  
          }
--        
--        
++
          Set<ObjectName> names = managementService.queryMBeanNames(cache
              .getDistributedSystem().getDistributedMember());
          assertTrue(!superSet.contains(names));
--         
--
        }
      };
      vm.invoke(validateServiceResource);
@@@ -360,7 -330,7 +328,6 @@@
        }
      };
      vm.invoke(validateServiceResource);
--
    }
  
    protected void validateServiceResource(final VM vm) {
@@@ -374,19 -344,19 +341,13 @@@
          
          SystemManagementService service = (SystemManagementService)managementService;
          assertNull(service.getLocalManager());
--        
--        
--
        }
      };
      vm.invoke(validateServiceResource);
--
    }
    
    /**
     * Creates a Distributed Region
--   * 
--   * @param vm
     */
    protected AsyncInvocation checkManagerView(final VM vm,
        final DistributedMember oneManager) {
@@@ -417,10 -387,10 +378,7 @@@
    
    /**
     * Add any Manager clean up asserts here
--   * 
--   * @param vm
     */
--
    protected void checkNonManagerView(final VM vm) {
      SerializableRunnable checkNonManagerView = new SerializableRunnable(
          "Check Non Manager View") {
@@@ -450,10 -420,10 +408,8 @@@
        }
      };
      vm.invoke(checkNonManagerView);
--
    }
    
--
    public static Map<DistributedMember, DistributionConfig> verifyConfigData() {
      GemFireCacheImpl cache = GemFireCacheImpl.getInstance();
      ManagementService service = getManagementService();
@@@ -481,10 -451,10 +437,8 @@@
        MemberMXBean bean = MBeanUtil.getMemberMbeanProxy(member);
        GemFireProperties data = bean.listGemFireProperties();
        DistributionConfig config = configMap.get(member);
 -      assertEquals(config, data);
 -
 +      assertConfigEquals(config, data);
- 
      }
--
    }
  
    /**
@@@ -495,7 -465,7 +449,7 @@@
        GemFireProperties data) {
  
      assertEquals(data.getMemberName(), config.getName());
--    // **TODO **/
++    // **TODO **
      String memberGroups = null;
  
      assertEquals(data.getMcastPort(), config.getMcastPort());
@@@ -505,7 -475,7 +459,7 @@@
      assertEquals(data.getTcpPort(), config.getTcpPort());
      assertEquals(removeVMDir(data.getCacheXMLFile()), removeVMDir(config.getCacheXmlFile()
          .getAbsolutePath()));
--    // **TODO **/
++    // **TODO **
      String configFile = null;
      String configFile1 = null;
      assertEquals(data.getMcastTTL(), config.getMcastTtl());
@@@ -519,7 -489,7 +473,7 @@@
          .getStatisticSamplingEnabled());
      assertEquals(removeVMDir(data.getStatisticArchiveFile()), removeVMDir(config
          .getStatisticArchiveFile().getAbsolutePath()));
--    // ** TODO **//
++    // ** TODO **
      String includeFile = null;
      assertEquals(data.getAckWaitThreshold(), config.getAckWaitThreshold());
      assertEquals(data.getAckSevereAlertThreshold(), config
@@@ -603,7 -573,7 +557,6 @@@
      assertEquals(data.getStatisticSampleRate(), config.getStatisticSampleRate());
    }
  
--  
    private static String removeVMDir(String string) {
      return string.replaceAll("vm.", "");
    }
@@@ -661,7 -631,7 +614,6 @@@
      LogWriterUtils.getLogWriter().info(
          "<ExpectedString> JVMMetrics is " + metrics.toString()
              + "</ExpectedString> ");
--
    }
  
    public static void fetchOSMetrics() {
@@@ -672,14 -642,14 +624,12 @@@
      LogWriterUtils.getLogWriter().info(
          "<ExpectedString> OSMetrics is " + metrics.toString()
              + "</ExpectedString> ");
--
    }
  
    public static void shutDownMember() {
      MemberMXBean bean = getManagementService()
          .getMemberMXBean();
      bean.shutDownMember();
--
    }
  
    public static void assertExpectedMembers(int expectedMemberCount) {
@@@ -697,10 -667,10 +647,8 @@@
        }
  
      }, MAX_WAIT, 500, true);
--
    }
  
--
    public static void invokeRemoteOps() throws Exception {
      GemFireCacheImpl cache = GemFireCacheImpl.getInstance();
      Set<DistributedMember> otherMemberSet = cache.getDistributionManager()
@@@ -720,22 -690,21 +668,11 @@@
        LogWriterUtils.getLogWriter().info(
            "<ExpectedString> Boolean Data Check " +bean.isManager()
                + "</ExpectedString> ");
--      
      }
    }
  
--  public void verifyStatistics() {
--
--  }
--
--  public void invokeOperations() {
--
--  }
--  
--  
 +  @Test
    public void testNotification() throws Exception {
--
      List<VM> managedNodeList = getManagedNodeList();
      VM node1 = managedNodeList.get(0);
      VM node2 = managedNodeList.get(1);
@@@ -755,12 -724,11 +692,10 @@@
  
      // Step : 3 : Verify Notification count, notification region sizes
      countNotificationsAndCheckRegionSize(node1, node2, node3, managingNode);
--
    }
  
 +  @Test
    public void testNotificationManagingNodeFirst() throws Exception {
--
      List<VM> managedNodeList = getManagedNodeList();
      VM node1 = managedNodeList.get(0);
      VM node2 = managedNodeList.get(1);
@@@ -780,12 -748,11 +715,10 @@@
  
      // Step : 3 : Verify Notification count, notification region sizes
      countNotificationsAndCheckRegionSize(node1, node2, node3, managingNode);
--
    }
    
 +  @Test
    public void testRedundancyZone() throws Exception {
--
      List<VM> managedNodeList = getManagedNodeList();
      VM node1 = managedNodeList.get(0);
      VM node2 = managedNodeList.get(1);
@@@ -798,17 -765,17 +731,11 @@@
      node1.invoke(new SerializableRunnable("Assert Redundancy Zone") {
  
        public void run() {
--
          ManagementService service = ManagementService.getExistingManagementService(getCache());
          MemberMXBean bean = service.getMemberMXBean();
          assertEquals("ARMY_ZONE", bean.getRedundancyZone());
--
--        
--
        }
      });
--
--
    }
  
    protected void attchListenerToDSMBean(final VM vm) {
@@@ -832,7 -799,7 +759,7 @@@
          try {
            mbeanServer.addNotificationListener(MBeanJMXAdapter.getDistributedSystemName(), nt, null, null);
          } catch (InstanceNotFoundException e) {
--          fail("Failed With Exception "  + e);
++          throw new AssertionError("Failed With Exception ", e);
          }
  
        }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/management/ClientHealthStatsDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/management/ClientHealthStatsDUnitTest.java
index 6661a0a,1d7a5a0..9c805f2
--- a/geode-core/src/test/java/com/gemstone/gemfire/management/ClientHealthStatsDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/management/ClientHealthStatsDUnitTest.java
@@@ -16,20 -16,7 +16,21 @@@
   */
  package com.gemstone.gemfire.management;
  
 -import com.gemstone.gemfire.cache.*;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static com.gemstone.gemfire.test.dunit.Assert.*;
 +
 +import java.util.Collection;
 +import java.util.Iterator;
 +import java.util.Properties;
 +
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
 +
 +import com.gemstone.gemfire.cache.Cache;
 +import com.gemstone.gemfire.cache.EntryEvent;
 +import com.gemstone.gemfire.cache.Region;
 +import com.gemstone.gemfire.cache.RegionFactory;
 +import com.gemstone.gemfire.cache.RegionShortcut;
  import com.gemstone.gemfire.cache.client.ClientCacheFactory;
  import com.gemstone.gemfire.cache.client.ClientRegionFactory;
  import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
@@@ -242,13 -240,17 +242,13 @@@ public class ClientHealthStatsDUnitTes
      cache.close(true);
    }
  
 -  public static void createClientCache(Host host, Integer port, int clientNum, boolean subscriptionEnabled, boolean durable) throws Exception {
 -
 +  private static void createClientCache(Host host, Integer port, int clientNum, boolean subscriptionEnabled, boolean durable) throws Exception {
      Properties props = new Properties();
-     props.setProperty(DistributionConfig.DURABLE_CLIENT_ID_NAME, "durable-"+clientNum);
-     props.setProperty(DistributionConfig.DURABLE_CLIENT_TIMEOUT_NAME, "300000");
-     props.setProperty("log-level", "info");
-     props.setProperty("statistic-archive-file", getTestMethodName()+"_client_" + clientNum + ".gfs");
-     props.setProperty("statistic-sampling-enabled", "true");
+     props.setProperty(DURABLE_CLIENT_ID, "durable-"+clientNum);
+     props.setProperty(DURABLE_CLIENT_TIMEOUT, "300000");
 -
 -//    props.setProperty("log-file", getTestMethodName()+"_client_" + clientNum + ".log");
+     props.setProperty(LOG_LEVEL, "info");
 -    props.setProperty(STATISTIC_ARCHIVE_FILE, getTestMethodName() + "_client_" + clientNum
 -        + ".gfs");
++    props.setProperty(STATISTIC_ARCHIVE_FILE, getTestMethodName() + "_client_" + clientNum + ".gfs");
+     props.setProperty(STATISTIC_SAMPLING_ENABLED, "true");
  
      ClientCacheFactory ccf = new ClientCacheFactory(props);
      if(subscriptionEnabled){

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/management/LocatorManagementDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/management/LocatorManagementDUnitTest.java
index 903a3d7,6230119..ac608a6
--- a/geode-core/src/test/java/com/gemstone/gemfire/management/LocatorManagementDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/management/LocatorManagementDUnitTest.java
@@@ -16,66 -16,50 +16,45 @@@
   */
  package com.gemstone.gemfire.management;
  
- import org.junit.experimental.categories.Category;
- import org.junit.Test;
- 
 -import com.gemstone.gemfire.distributed.DistributedMember;
 -import com.gemstone.gemfire.distributed.Locator;
 -import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 -import com.gemstone.gemfire.distributed.internal.InternalLocator;
 -import com.gemstone.gemfire.internal.AvailablePortHelper;
 -import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 -import com.gemstone.gemfire.management.internal.ManagementConstants;
 -import com.gemstone.gemfire.test.dunit.*;
++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 static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
++import org.junit.Test;
++import org.junit.experimental.categories.Category;
+ 
 +import com.gemstone.gemfire.distributed.DistributedMember;
 +import com.gemstone.gemfire.distributed.Locator;
 +import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 +import com.gemstone.gemfire.distributed.internal.InternalLocator;
- import com.gemstone.gemfire.i18n.LogWriterI18n;
- import com.gemstone.gemfire.internal.AvailablePort;
 +import com.gemstone.gemfire.internal.AvailablePortHelper;
 +import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 +import com.gemstone.gemfire.management.internal.ManagementConstants;
 +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.VM;
 +import com.gemstone.gemfire.test.dunit.Wait;
 +import com.gemstone.gemfire.test.dunit.WaitCriterion;
- 
++import com.gemstone.gemfire.test.junit.categories.DistributedTest;
  
  /**
   * Test cases
   * 
   * DistributedSystem Cache Locator no no yes yes no yes yes yes yes
-- * 
-- * 
-- * 
   */
--
 +@Category(DistributedTest.class)
  public class LocatorManagementDUnitTest extends ManagementTestBase {
  
--  /** Default file name for locator log: <code>"locator.log"</code> */
--  public static final String DEFAULT_LOG_FILE = "locator.log";
--
    private static final int MAX_WAIT = 8 * ManagementConstants.REFRESH_TIME;
  
--  private static Properties props = new Properties();
--
    private VM locator;
--  
--
-   public LocatorManagementDUnitTest() {
-     super();
 -  public LocatorManagementDUnitTest(String name) {
 -    super(name);
--  }
--
--  private static final long serialVersionUID = 1L;
  
    @Override
    protected final void postSetUpManagementTestBase() throws Exception {
@@@ -90,10 -74,9 +69,8 @@@
    /**
     * When plan is to start Distributed System later so that the system can use
     * this locator
--   * 
--   * @throws Exception
     */
 +  @Test
    public void testPeerLocation() throws Exception {
      int locPort = AvailablePortHelper.getRandomAvailableTCPPort();
      startLocator(locator, true, locPort);
@@@ -141,10 -123,9 +118,8 @@@
  
    /**
     * Tests a locator which is co-located with already existing cache
--   * 
--   * @throws Exception
     */
 +  @Test
    public void testColocatedLocator() throws Exception {
      initManagement(false);
      int locPort = AvailablePortHelper.getRandomAvailableTCPPort();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/management/ManagementTestBase.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/management/ManagementTestBase.java
index 59847b9,08167ab..2915f06
--- a/geode-core/src/test/java/com/gemstone/gemfire/management/ManagementTestBase.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/management/ManagementTestBase.java
@@@ -16,25 -16,12 +16,25 @@@
   */
  package com.gemstone.gemfire.management;
  
+ import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
 +
 +import java.util.ArrayList;
 +import java.util.Iterator;
 +import java.util.List;
 +import java.util.Properties;
 +import java.util.Set;
 +import javax.management.MBeanServer;
 +import javax.management.ObjectName;
  
  import com.gemstone.gemfire.LogWriter;
 -import com.gemstone.gemfire.cache.*;
 +import com.gemstone.gemfire.cache.Cache;
 +import com.gemstone.gemfire.cache.CacheFactory;
 +import com.gemstone.gemfire.cache.Region;
 +import com.gemstone.gemfire.cache.RegionFactory;
 +import com.gemstone.gemfire.cache.RegionShortcut;
  import com.gemstone.gemfire.distributed.DistributedMember;
  import com.gemstone.gemfire.distributed.DistributedSystem;
- import com.gemstone.gemfire.distributed.internal.DistributionConfig;
  import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
  import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
  import com.gemstone.gemfire.internal.statistics.SampleCollector;
@@@ -218,8 -203,8 +218,8 @@@ public abstract class ManagementTestBas
  
    public Cache createCache(Properties props) {
      System.setProperty("dunitLogPerTest", "true");
-     props.setProperty(DistributionConfig.LOG_FILE_NAME, getTestMethodName() + "-.log");
+     props.setProperty(LOG_FILE, getTestMethodName() + "-.log");
 -    ds = (new ManagementTestBase("temp")).getSystem(props);
 +    ds = getSystem(props);
      cache = CacheFactory.create(ds);
      managementService = ManagementService.getManagementService(cache);
      logWriter = ds.getLogWriter();
@@@ -235,15 -220,15 +235,15 @@@
    public Cache createCache(boolean management) {
      System.setProperty("dunitLogPerTest", "true");
      if (management) {
-       props.setProperty(DistributionConfig.JMX_MANAGER_NAME, "true");
-       props.setProperty(DistributionConfig.JMX_MANAGER_START_NAME, "false");
-       props.setProperty(DistributionConfig.JMX_MANAGER_PORT_NAME, "0");
-       props.setProperty(DistributionConfig.JMX_MANAGER_HTTP_PORT_NAME, "0");
+       props.setProperty(JMX_MANAGER, "true");
+       props.setProperty(JMX_MANAGER_START, "false");
+       props.setProperty(JMX_MANAGER_PORT, "0");
+       props.setProperty(JMX_MANAGER_HTTP_PORT, "0");
      }
-     props.setProperty(DistributionConfig.ENABLE_TIME_STATISTICS_NAME, "true");
-     props.setProperty(DistributionConfig.STATISTIC_SAMPLING_ENABLED_NAME, "true");
-     props.setProperty(DistributionConfig.LOG_FILE_NAME, getTestMethodName() + "-.log");
+     props.setProperty(ENABLE_TIME_STATISTICS, "true");
+     props.setProperty(STATISTIC_SAMPLING_ENABLED, "true");
+     props.setProperty(LOG_FILE, getTestMethodName() + "-.log");
 -    ds = (new ManagementTestBase("temp")).getSystem(props);
 +    ds = getSystem(props);
      cache = CacheFactory.create(ds);
      managementService = ManagementService.getManagementService(cache);
      logWriter = ds.getLogWriter();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/management/OffHeapManagementDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/management/OffHeapManagementDUnitTest.java
index e3c5518,d8f0476..b42930a
--- a/geode-core/src/test/java/com/gemstone/gemfire/management/OffHeapManagementDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/management/OffHeapManagementDUnitTest.java
@@@ -16,46 -16,27 +16,42 @@@
   */
  package com.gemstone.gemfire.management;
  
- 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.util.ArrayList;
 +import java.util.Collections;
 +import java.util.List;
 +import java.util.Properties;
- 
 +import javax.management.Attribute;
 +import javax.management.AttributeList;
 +import javax.management.MBeanServer;
 +import javax.management.Notification;
 +import javax.management.NotificationListener;
 +import javax.management.ObjectName;
 +
++import org.junit.Test;
++import org.junit.experimental.categories.Category;
++
  import com.gemstone.gemfire.OutOfOffHeapMemoryException;
  import com.gemstone.gemfire.cache.Cache;
  import com.gemstone.gemfire.cache.DataPolicy;
  import com.gemstone.gemfire.cache.Region;
--import com.gemstone.gemfire.cache30.CacheTestCase;
- import com.gemstone.gemfire.distributed.internal.DistributionConfig;
  import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
  import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
- import com.gemstone.gemfire.internal.offheap.OffHeapStoredObject;
  import com.gemstone.gemfire.internal.offheap.OffHeapMemoryStats;
  import com.gemstone.gemfire.internal.offheap.OffHeapStorage;
+ import com.gemstone.gemfire.internal.offheap.OffHeapStoredObject;
  import com.gemstone.gemfire.management.internal.MBeanJMXAdapter;
  import com.gemstone.gemfire.management.internal.beans.MemberMBean;
 -import com.gemstone.gemfire.test.dunit.*;
 -
 -import javax.management.*;
 -import java.util.ArrayList;
 -import java.util.Collections;
 -import java.util.List;
 -import java.util.Properties;
 -
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +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.dunit.cache.internal.JUnit4CacheTestCase;
++import com.gemstone.gemfire.test.junit.categories.DistributedTest;
  
  /**
   * Tests the off-heap additions to the RegionMXBean and MemberMXBean JMX interfaces.
@@@ -143,14 -123,14 +139,6 @@@ public class OffHeapManagementDUnitTes
     */
    private static MBeanServer mbeanServer = MBeanJMXAdapter.mbeanServer;
  
--  /**
--   * Creates a new OffHeapManagementDUnitTest.
--   * @param name the test name.
--   */
-   public OffHeapManagementDUnitTest() {
-     super();
 -  public OffHeapManagementDUnitTest(String name) {
 -    super(name);
--  }
--  
    @Override
    public final void postSetUp() throws Exception {
      Host.getHost(0).getVM(0).invoke(new SerializableRunnable() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/management/UniversalMembershipListenerAdapterDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/management/UniversalMembershipListenerAdapterDUnitTest.java
index ef229e3,05c9119..c0978b7
--- a/geode-core/src/test/java/com/gemstone/gemfire/management/UniversalMembershipListenerAdapterDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/management/UniversalMembershipListenerAdapterDUnitTest.java
@@@ -16,19 -16,6 +16,20 @@@
   */
  package com.gemstone.gemfire.management;
  
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static com.gemstone.gemfire.test.dunit.Assert.*;
 +import static com.gemstone.gemfire.test.dunit.LogWriterUtils.*;
 +
 +import java.io.IOException;
 +import java.util.Collections;
 +import java.util.HashSet;
 +import java.util.List;
 +import java.util.Properties;
 +import java.util.Set;
 +
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
 +
  import com.gemstone.gemfire.InternalGemFireException;
  import com.gemstone.gemfire.LogWriter;
  import com.gemstone.gemfire.cache.AttributesFactory;
@@@ -66,10 -46,9 +66,11 @@@ import com.gemstone.gemfire.test.junit.
  /**
   * Tests the UniversalMembershipListenerAdapter.
   *
-  * @since 4.2.1
+  * @since GemFire 4.2.1
   */
 +@Category(DistributedTest.class)
  public class UniversalMembershipListenerAdapterDUnitTest extends ClientServerTestCase {
++
    protected static final boolean CLIENT = true;
    protected static final boolean SERVER = false;
    
@@@ -270,6 -249,6 +271,7 @@@
      final boolean[] isClientBridge = new boolean[3];
  
      MembershipListener systemListener = new MembershipListener() {
++      @Override
        public synchronized void memberJoined(MembershipEvent event) {
          assertFalse(firedSystem[JOINED]);
          assertNull(memberSystem[JOINED]);
@@@ -279,6 -258,6 +281,7 @@@
          memberIdSystem[JOINED] = event.getMemberId();
          notify();
        }
++      @Override
        public synchronized void memberLeft(MembershipEvent event) {
          assertFalse(firedSystem[LEFT]);
          assertNull(memberSystem[LEFT]);
@@@ -288,6 -267,6 +291,7 @@@
          memberIdSystem[LEFT] = event.getMemberId();
          notify();
        }
++      @Override
        public synchronized void memberCrashed(MembershipEvent event) {
          assertFalse(firedSystem[CRASHED]);
          assertNull(memberSystem[CRASHED]);
@@@ -343,6 -322,6 +347,7 @@@
      };
  
      ClientMembershipListener bridgeListener = new ClientMembershipListener() {
++      @Override
        public synchronized void memberJoined(ClientMembershipEvent event) {
          assertFalse(firedBridge[JOINED]);
          assertNull(memberBridge[JOINED]);
@@@ -354,6 -333,6 +359,7 @@@
          isClientBridge[JOINED] = event.isClient();
          notify();
        }
++      @Override
        public synchronized void memberLeft(ClientMembershipEvent event) {
          assertFalse(firedBridge[LEFT]);
          assertNull(memberBridge[LEFT]);
@@@ -365,6 -344,6 +371,7 @@@
          isClientBridge[LEFT] = event.isClient();
          notify();
        }
++      @Override
        public synchronized void memberCrashed(ClientMembershipEvent event) {
          assertFalse(firedBridge[CRASHED]);
          assertNull(memberBridge[CRASHED]);
@@@ -419,10 -398,10 +426,10 @@@
      new SerializableCallable("Create bridge client") {
        @Override
        public Object call() {
 -        com.gemstone.gemfire.test.dunit.LogWriterUtils.getLogWriter().info("[testLonerClientEventsInServer] create bridge client");
 +        getLogWriter().info("[testLonerClientEventsInServer] create bridge client");
          Properties config = new Properties();
-         config.setProperty(DistributionConfig.MCAST_PORT_NAME, "0");
-         config.setProperty(DistributionConfig.LOCATORS_NAME, "");
+         config.setProperty(MCAST_PORT, "0");
+         config.setProperty(LOCATORS, "");
          getSystem(config);
          AttributesFactory factory = new AttributesFactory();
          factory.setScope(Scope.LOCAL);
@@@ -853,14 -830,14 +860,14 @@@
      final Properties serverProperties = getSystem().getProperties();
  
      //Below removed properties are already got copied as cluster SSL properties 
-     serverProperties.remove(DistributionConfig.SSL_ENABLED_NAME);
-     serverProperties.remove(DistributionConfig.SSL_CIPHERS_NAME);
-     serverProperties.remove(DistributionConfig.SSL_PROTOCOLS_NAME);
-     serverProperties.remove(DistributionConfig.SSL_REQUIRE_AUTHENTICATION_NAME);
+     serverProperties.remove(SSL_ENABLED);
+     serverProperties.remove(SSL_CIPHERS);
+     serverProperties.remove(SSL_PROTOCOLS);
+     serverProperties.remove(SSL_REQUIRE_AUTHENTICATION);
  
 -    com.gemstone.gemfire.test.dunit.LogWriterUtils.getLogWriter().info("[doTestSystemClientEventsInServer] ports[0]=" + ports[0]);
 -    com.gemstone.gemfire.test.dunit.LogWriterUtils.getLogWriter().info("[doTestSystemClientEventsInServer] serverMemberId=" + serverMemberId);
 -    com.gemstone.gemfire.test.dunit.LogWriterUtils.getLogWriter().info("[doTestSystemClientEventsInServer] serverMember=" + serverMember);
 +    getLogWriter().info("[doTestSystemClientEventsInServer] ports[0]=" + ports[0]);
 +    getLogWriter().info("[doTestSystemClientEventsInServer] serverMemberId=" + serverMemberId);
 +    getLogWriter().info("[doTestSystemClientEventsInServer] serverMember=" + serverMember);
  
      // register the bridge listener
      ClientMembership.registerClientMembershipListener(bridgeListener);
@@@ -1549,14 -1522,14 +1556,14 @@@
      final String serverMemberId = serverMember.toString();
      final Properties serverProperties = getSystem().getProperties();
  
-     serverProperties.remove(DistributionConfig.SSL_ENABLED_NAME);
-     serverProperties.remove(DistributionConfig.SSL_CIPHERS_NAME);
-     serverProperties.remove(DistributionConfig.SSL_PROTOCOLS_NAME);
-     serverProperties.remove(DistributionConfig.SSL_REQUIRE_AUTHENTICATION_NAME);
+     serverProperties.remove(SSL_ENABLED);
+     serverProperties.remove(SSL_CIPHERS);
+     serverProperties.remove(SSL_PROTOCOLS);
+     serverProperties.remove(SSL_REQUIRE_AUTHENTICATION);
      
 -    com.gemstone.gemfire.test.dunit.LogWriterUtils.getLogWriter().info("[testServerEventsInPeerSystem] ports[0]=" + ports[0]);
 -    com.gemstone.gemfire.test.dunit.LogWriterUtils.getLogWriter().info("[testServerEventsInPeerSystem] serverMemberId=" + serverMemberId);
 -    com.gemstone.gemfire.test.dunit.LogWriterUtils.getLogWriter().info("[testServerEventsInPeerSystem] serverMember=" + serverMember);
 +    getLogWriter().info("[testServerEventsInPeerSystem] ports[0]=" + ports[0]);
 +    getLogWriter().info("[testServerEventsInPeerSystem] serverMemberId=" + serverMemberId);
 +    getLogWriter().info("[testServerEventsInPeerSystem] serverMember=" + serverMember);
      
      GemFireCacheImpl cache = GemFireCacheImpl.getExisting();
      assertNotNull(cache);
@@@ -1831,13 -1800,13 +1838,13 @@@
        { AvailablePort.getRandomAvailablePort(AvailablePort.SOCKET) };
      assertTrue(ports[0] != 0);
  
 -    com.gemstone.gemfire.test.dunit.LogWriterUtils.getLogWriter().info("[testServerEventsInLonerClient] create loner bridge client");
 +    getLogWriter().info("[testServerEventsInLonerClient] create loner bridge client");
      Properties config = new Properties();
-     config.setProperty(DistributionConfig.MCAST_PORT_NAME, "0");
-     config.setProperty(DistributionConfig.LOCATORS_NAME, "");
+     config.setProperty(MCAST_PORT, "0");
+     config.setProperty(LOCATORS, "");
      getSystem(config);
          
 -    com.gemstone.gemfire.test.dunit.LogWriterUtils.getLogWriter().info("[testServerEventsInLonerClient] create system bridge client");
 +    getLogWriter().info("[testServerEventsInLonerClient] create system bridge client");
      getSystem();
  
      // register the bridge listener

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/management/internal/cli/CliUtilDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/management/internal/cli/CliUtilDUnitTest.java
index 47cb708,01acabf..a7c2ce4
--- a/geode-core/src/test/java/com/gemstone/gemfire/management/internal/cli/CliUtilDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/management/internal/cli/CliUtilDUnitTest.java
@@@ -16,54 -16,30 +16,47 @@@
   */
  package com.gemstone.gemfire.management.internal.cli;
  
- import org.junit.experimental.categories.Category;
- import org.junit.Test;
- 
 -import com.gemstone.gemfire.cache.*;
 -import com.gemstone.gemfire.cache.execute.*;
 -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.Properties;
 +import java.util.Set;
 +
++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.Region;
 +import com.gemstone.gemfire.cache.RegionFactory;
 +import com.gemstone.gemfire.cache.RegionShortcut;
 +import com.gemstone.gemfire.cache.execute.Function;
 +import com.gemstone.gemfire.cache.execute.FunctionAdapter;
 +import com.gemstone.gemfire.cache.execute.FunctionContext;
 +import com.gemstone.gemfire.cache.execute.FunctionService;
 +import com.gemstone.gemfire.cache.execute.ResultCollector;
- import com.gemstone.gemfire.cache30.CacheTestCase;
  import com.gemstone.gemfire.distributed.DistributedMember;
- import com.gemstone.gemfire.distributed.internal.DistributionConfig;
  import com.gemstone.gemfire.internal.AvailablePortHelper;
  import com.gemstone.gemfire.management.DistributedRegionMXBean;
  import com.gemstone.gemfire.management.ManagementService;
  import com.gemstone.gemfire.management.RegionMXBean;
  import com.gemstone.gemfire.management.internal.cli.result.CommandResultException;
 -import com.gemstone.gemfire.test.dunit.*;
 +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.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.cache.internal.JUnit4CacheTestCase;
++import com.gemstone.gemfire.test.junit.categories.DistributedTest;
  
 -import java.util.Properties;
 -import java.util.Set;
 -
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 -
--/**
-- * 
-- *
-- */
 -public class CliUtilDUnitTest extends CacheTestCase {
 +@Category(DistributedTest.class)
 +public class CliUtilDUnitTest extends JUnit4CacheTestCase {
  
 -  public CliUtilDUnitTest(String name) {
 -    super(name);    
 +  public CliUtilDUnitTest() {
 +    super();    
    }
  
    public static final String COMMON_REGION="region1";

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientIdsDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientIdsDUnitTest.java
index 259cbdb,1ad2efd..5cbf715
--- a/geode-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientIdsDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientIdsDUnitTest.java
@@@ -16,20 -16,7 +16,21 @@@
   */
  package com.gemstone.gemfire.management.internal.pulse;
  
 -import com.gemstone.gemfire.cache.*;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +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.Cache;
 +import com.gemstone.gemfire.cache.CacheFactory;
 +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.cache.client.PoolManager;
  import com.gemstone.gemfire.cache.client.internal.PoolImpl;
  import com.gemstone.gemfire.cache.server.CacheServer;
@@@ -80,9 -62,9 +80,9 @@@ public class TestClientIdsDUnitTest ext
  
    private ManagementTestBase helper;
  
-   public TestClientIdsDUnitTest() {
-     super();
 -  public TestClientIdsDUnitTest(String name) {
 -    super(name);
 -    this.helper = new ManagementTestBase(name);
++  @Override
++  public final void preSetUp() throws Exception {
 +    this.helper = new ManagementTestBase(){};
    }
  
    @Override
@@@ -104,9 -86,8 +104,7 @@@
      disconnectFromDS();
    }
  
--  private static final long serialVersionUID = 1L;
--
 +  @Test
    public void testClientIds() throws Exception {
      helper.createManagementCache(managingNode);
      helper.startManagingNode(managingNode);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestSubscriptionsDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestSubscriptionsDUnitTest.java
index 7328bdc,9b79b67..f483cef
--- a/geode-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestSubscriptionsDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestSubscriptionsDUnitTest.java
@@@ -16,20 -16,7 +16,21 @@@
   */
  package com.gemstone.gemfire.management.internal.pulse;
  
 -import com.gemstone.gemfire.cache.*;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +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.Cache;
 +import com.gemstone.gemfire.cache.CacheFactory;
 +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.cache.client.PoolManager;
  import com.gemstone.gemfire.cache.client.internal.PoolImpl;
  import com.gemstone.gemfire.cache.server.CacheServer;
@@@ -64,17 -46,17 +64,16 @@@ public class TestSubscriptionsDUnitTes
    private static final String client_k1 = "client-k1";
  
    private static final String client_k2 = "client-k2";
--  /** name of the test region */
--  private static final String REGION_NAME = "TestSubscriptionsDUnitTest_Region";
++  private static final String REGION_NAME = TestSubscriptionsDUnitTest.class.getSimpleName() + "_Region";
    private static VM server = null;
    private static VM client = null;
    private static VM client2 = null;
    private static VM managingNode = null;
    private ManagementTestBase helper;
  
-   public TestSubscriptionsDUnitTest() {
-     super();
 -  public TestSubscriptionsDUnitTest(String name) {
 -    super(name);
 -    this.helper = new ManagementTestBase(name);
++  @Override
++  public final void preSetUp() throws Exception {
 +    this.helper = new ManagementTestBase(){};
    }
  
    @Override
@@@ -95,9 -77,8 +94,7 @@@
      disconnectFromDS();
    }
  
--  private static final long serialVersionUID = 1L;
--
 +  @Test
    public void testNoOfSubscription() throws Exception {
  
      helper.createManagementCache(managingNode);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/memcached/DomainObjectsAsValuesJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/memcached/DomainObjectsAsValuesJUnitTest.java
index b9eb71e,98aa90d..b55a5a7
--- a/geode-core/src/test/java/com/gemstone/gemfire/memcached/DomainObjectsAsValuesJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/memcached/DomainObjectsAsValuesJUnitTest.java
@@@ -16,27 -16,28 +16,27 @@@
   */
  package com.gemstone.gemfire.memcached;
  
 -import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 -import com.gemstone.gemfire.internal.AvailablePortHelper;
 -import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 -import net.spy.memcached.MemcachedClient;
 -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 static org.junit.Assert.*;
  
  import java.net.InetAddress;
  import java.net.InetSocketAddress;
  import java.util.concurrent.Future;
  import java.util.logging.Logger;
  
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.MCAST_PORT;
 -import static org.junit.Assert.*;
 +import net.spy.memcached.MemcachedClient;
 +import org.junit.After;
 +import org.junit.Before;
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
 +
++import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 +import com.gemstone.gemfire.internal.AvailablePortHelper;
 +import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
  
  @Category(IntegrationTest.class)
  public class DomainObjectsAsValuesJUnitTest {
  
--  private static final Logger logger = Logger.getLogger(DomainObjectsAsValuesJUnitTest.class.getCanonicalName());
--  
    private int PORT;
    
    private GemFireMemcachedServer server;
@@@ -52,10 -53,10 +52,10 @@@
    @After
    public void tearDown() throws Exception {
      this.server.shutdown();
-     System.getProperties().remove("gemfire.mcast-port");
+     System.getProperties().remove(DistributionConfig.GEMFIRE_PREFIX + MCAST_PORT);
    }
  
 -  public static class Customer implements java.io.Serializable {
 +  private static class Customer implements java.io.Serializable {
      private static final long serialVersionUID = 4238572216598708877L;
      private String name;
      private String address;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/memcached/IntegrationJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/memcached/IntegrationJUnitTest.java
index ecea7db,63e7b3f..b6931d6
--- a/geode-core/src/test/java/com/gemstone/gemfire/memcached/IntegrationJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/memcached/IntegrationJUnitTest.java
@@@ -16,23 -16,25 +16,23 @@@
   */
  package com.gemstone.gemfire.memcached;
  
 -import com.gemstone.gemfire.cache.Cache;
 -import com.gemstone.gemfire.cache.CacheFactory;
 -import com.gemstone.gemfire.internal.AvailablePortHelper;
 -import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 -import net.spy.memcached.MemcachedClient;
 -import org.junit.Test;
 -import org.junit.experimental.categories.Category;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
  
  import java.net.InetAddress;
  import java.net.InetSocketAddress;
  import java.util.Properties;
  import java.util.concurrent.Future;
  
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 -import static org.junit.Assert.*;
 +import net.spy.memcached.MemcachedClient;
 +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.distributed.internal.DistributionConfig;
 +import com.gemstone.gemfire.internal.AvailablePortHelper;
 +import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
  
 -/**
 - * 
 - */
  @Category(IntegrationTest.class)
  public class IntegrationJUnitTest {
  

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/pdx/AutoSerializableJUnitTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/pdx/ClientsWithVersioningRetryDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/pdx/ClientsWithVersioningRetryDUnitTest.java
index a965b02,90f51d9..e536ca6
--- a/geode-core/src/test/java/com/gemstone/gemfire/pdx/ClientsWithVersioningRetryDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/pdx/ClientsWithVersioningRetryDUnitTest.java
@@@ -16,77 -16,41 +16,68 @@@
   */
  package com.gemstone.gemfire.pdx;
  
- import org.junit.experimental.categories.Category;
- import org.junit.Test;
- 
 -import com.gemstone.gemfire.cache.*;
++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.LinkedList;
 +import java.util.List;
 +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.CacheFactory;
 +import com.gemstone.gemfire.cache.DataPolicy;
 +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.Scope;
  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.cache30.CacheTestCase;
  import com.gemstone.gemfire.distributed.DistributedMember;
+ 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.AvailablePortHelper;
- import com.gemstone.gemfire.internal.cache.DistributedCacheOperation;
 -import com.gemstone.gemfire.internal.cache.*;
 +import com.gemstone.gemfire.internal.cache.DistributedPutAllOperation;
 +import com.gemstone.gemfire.internal.cache.DistributedRegion;
 +import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 +import com.gemstone.gemfire.internal.cache.EventID;
 +import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 +import com.gemstone.gemfire.internal.cache.LocalRegion;
 +import com.gemstone.gemfire.internal.cache.RegionEntry;
- import com.gemstone.gemfire.internal.cache.VMCachedDeserializable;
  import com.gemstone.gemfire.internal.cache.tier.sockets.BaseCommand;
  import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
  import com.gemstone.gemfire.internal.cache.tier.sockets.command.Put70;
  import com.gemstone.gemfire.internal.cache.versions.VMVersionTag;
  import com.gemstone.gemfire.internal.cache.versions.VersionTag;
 -import com.gemstone.gemfire.test.dunit.*;
 -
 -import java.util.*;
++import com.gemstone.gemfire.test.dunit.Host;
 +import com.gemstone.gemfire.test.dunit.IgnoredException;
 +import com.gemstone.gemfire.test.dunit.Invoke;
 +import com.gemstone.gemfire.test.dunit.LogWriterUtils;
 +import com.gemstone.gemfire.test.dunit.NetworkUtils;
- 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.cache.internal.JUnit4CacheTestCase;
++import com.gemstone.gemfire.test.junit.categories.DistributedTest;
  
- /**
-  *
-  */
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +@Category(DistributedTest.class)
 +public class ClientsWithVersioningRetryDUnitTest extends JUnit4CacheTestCase {
+ 
 -/**
 - *
 - */
 -public class ClientsWithVersioningRetryDUnitTest extends CacheTestCase {
    // list of expected exceptions to remove in tearDown2()
    static List<IgnoredException> expectedExceptions = new LinkedList<IgnoredException>();
  
-   public ClientsWithVersioningRetryDUnitTest() {
-     super();
 -  public ClientsWithVersioningRetryDUnitTest(String name) {
 -    super(name);
--  }
--  
    @Override
    public final void postSetUp() throws Exception {
      Invoke.invokeInEveryVM(new SerializableRunnable() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/pdx/DistributedSystemIdDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/pdx/DistributedSystemIdDUnitTest.java
index 87cae5b,f1adbce..85e12cf
--- a/geode-core/src/test/java/com/gemstone/gemfire/pdx/DistributedSystemIdDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/pdx/DistributedSystemIdDUnitTest.java
@@@ -16,31 -16,21 +16,27 @@@
   */
  package com.gemstone.gemfire.pdx;
  
 -import com.gemstone.gemfire.distributed.internal.DistributionManager;
 -import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 -import com.gemstone.gemfire.internal.AvailablePortHelper;
 -import com.gemstone.gemfire.test.dunit.*;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
  
  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.distributed.internal.DistributionConfig;
 -public class DistributedSystemIdDUnitTest extends DistributedTestCase {
 -  
 -  public DistributedSystemIdDUnitTest(String name) {
 -    super(name);
 -  }
 +import com.gemstone.gemfire.distributed.internal.DistributionManager;
 +import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 +import com.gemstone.gemfire.internal.AvailablePortHelper;
 +import com.gemstone.gemfire.test.dunit.Host;
 +import com.gemstone.gemfire.test.dunit.IgnoredException;
 +import com.gemstone.gemfire.test.dunit.SerializableCallable;
 +import com.gemstone.gemfire.test.dunit.VM;
 +import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
 +import com.gemstone.gemfire.test.junit.categories.DistributedTest;
  
 +@Category(DistributedTest.class)
 +public class DistributedSystemIdDUnitTest extends JUnit4DistributedTestCase {
 +  
-   public DistributedSystemIdDUnitTest() {
-     super();
-   }
- 
    @Override
    public void preSetUp() {
      disconnectAllFromDS(); // GEODE-558 test fails due to infection from another test
@@@ -60,10 -49,9 +56,9 @@@
      checkId(vm0, 1);
      checkId(vm1, 1);
      checkId(vm2, 1);
--    
    }
    
 +  @Test
    public void testInfectiousId() {
      Host host = Host.getHost(0);
      VM vm0 = host.getVM(0);
@@@ -104,19 -90,19 +99,17 @@@
        createLocator(vm0, "256");
        fail("Should have gotten an exception");
      } catch(Exception expected) {
--
      }
++
      try {
        createLocator(vm0, "aardvark");
        fail("Should have gotten an exception");
      } catch(Exception expected) {
--      
      }
    }
  
    private void createSystem(VM vm, final String dsId, final int locatorPort) {
--    
--    
++
      SerializableCallable createSystem = new SerializableCallable() {
        public Object call() throws Exception {
          Properties props = new Properties();
@@@ -134,13 -120,13 +127,11 @@@
        public Object call() throws Exception {
          int port = AvailablePortHelper.getRandomAvailableTCPPort();
          Properties props = new Properties();
-         props.setProperty(DistributionConfig.DISTRIBUTED_SYSTEM_ID_NAME, dsId);
-         props.setProperty("mcast-port", "0");
-         props.setProperty(DistributionConfig.LOCATORS_NAME, "localhost[" + port + "]");
-         props.setProperty(DistributionConfig.START_LOCATOR_NAME, "localhost[" + port + "]");
+         props.setProperty(DISTRIBUTED_SYSTEM_ID, dsId);
+         props.setProperty(MCAST_PORT, "0");
+         props.setProperty(LOCATORS, "localhost[" + port + "]");
+         props.setProperty(START_LOCATOR, "localhost[" + port + "]");
          getSystem(props);
--//        Locator locator = Locator.startLocatorAndDS(port, File.createTempFile("locator", ""), props);
--//        system = (InternalDistributedSystem) locator.getDistributedSystem();
          return port;
        }
      };
@@@ -149,7 -135,7 +140,6 @@@
    
    private void checkId(VM vm, final int dsId) {
      
--    
      SerializableCallable createSystem = new SerializableCallable() {
        public Object call() throws Exception {
          DistributionManager dm = (DistributionManager) InternalDistributedSystem.getAnyInstance().getDistributionManager();
@@@ -159,7 -145,7 +149,4 @@@
      };
      vm.invoke(createSystem);
    }
--  
--  
--
  }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/pdx/JSONFormatterJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/pdx/JSONFormatterJUnitTest.java
index b84307c,40a1071..6fbc9de
--- a/geode-core/src/test/java/com/gemstone/gemfire/pdx/JSONFormatterJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/pdx/JSONFormatterJUnitTest.java
@@@ -16,10 -16,14 +16,14 @@@
   */
  package com.gemstone.gemfire.pdx;
  
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
 +
 +import java.text.SimpleDateFormat;
 +
+ import com.fasterxml.jackson.core.JsonProcessingException;
+ import com.fasterxml.jackson.databind.DeserializationFeature;
+ import com.fasterxml.jackson.databind.ObjectMapper;
 -import com.gemstone.gemfire.cache.*;
 -import com.gemstone.gemfire.cache.server.CacheServer;
 -import com.gemstone.gemfire.internal.Assert;
 -import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 -import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
  import org.json.JSONException;
  import org.json.JSONObject;
  import org.junit.After;
@@@ -27,19 -31,10 +31,16 @@@ import org.junit.Before
  import org.junit.Test;
  import org.junit.experimental.categories.Category;
  
- import com.fasterxml.jackson.core.JsonProcessingException;
- import com.fasterxml.jackson.databind.DeserializationFeature;
- import com.fasterxml.jackson.databind.ObjectMapper;
 -import java.text.SimpleDateFormat;
 -
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.MCAST_PORT;
 -import static org.junit.Assert.fail;
 +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.Region;
 +import com.gemstone.gemfire.cache.RegionAttributes;
 +import com.gemstone.gemfire.cache.server.CacheServer;
 +import com.gemstone.gemfire.internal.Assert;
 +import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 +import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
  
  @Category(IntegrationTest.class)
  public class JSONFormatterJUnitTest {
@@@ -47,9 -42,13 +48,9 @@@
    private GemFireCacheImpl c;
    private final String PRIMITIVE_KV_STORE_REGION = "primitiveKVStore";
      
 -  public JSONFormatterJUnitTest() {
 -    super();
 -  }
 -
    @Before
    public void setUp() throws Exception {
-     this.c = (GemFireCacheImpl) new CacheFactory().set("mcast-port", "0").setPdxReadSerialized(true).create();
+     this.c = (GemFireCacheImpl) new CacheFactory().set(MCAST_PORT, "0").setPdxReadSerialized(true).create();
      
      //start cache-server
      CacheServer server = c.addCacheServer();
@@@ -190,7 -189,7 +191,7 @@@
            jsonObject.getString(testObject.getDayFN()));
  
      } catch (JSONException e) {
--      fail("Error in VerifyPdxInstanceToJson, Malformed json, can not create JSONArray from it");
++      throw new AssertionError("Error in VerifyPdxInstanceToJson, Malformed json, can not create JSONArray from it", e);
      }
    }
  

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/pdx/JSONPdxClientServerDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/pdx/JSONPdxClientServerDUnitTest.java
index e668c59,0800dde..d249fb9
--- a/geode-core/src/test/java/com/gemstone/gemfire/pdx/JSONPdxClientServerDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/pdx/JSONPdxClientServerDUnitTest.java
@@@ -16,14 -16,6 +16,15 @@@
   */
  package com.gemstone.gemfire.pdx;
  
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
 +
 +import java.io.File;
 +import java.io.FileInputStream;
 +import java.io.IOException;
 +import java.text.SimpleDateFormat;
 +import java.util.Properties;
 +
  import com.fasterxml.jackson.core.JsonProcessingException;
  import com.fasterxml.jackson.databind.DeserializationFeature;
  import com.fasterxml.jackson.databind.ObjectMapper;
@@@ -42,7 -24,7 +43,6 @@@ import com.gemstone.gemfire.cache.clien
  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.distributed.internal.DistributionConfig;
 -import com.gemstone.gemfire.cache30.CacheTestCase;
  import com.gemstone.gemfire.internal.Assert;
  import com.gemstone.gemfire.internal.AvailablePortHelper;
  import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/pdx/PdxClientServerDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/pdx/PdxClientServerDUnitTest.java
index 69603a5,d029557..309cbdc
--- a/geode-core/src/test/java/com/gemstone/gemfire/pdx/PdxClientServerDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/pdx/PdxClientServerDUnitTest.java
@@@ -16,59 -16,35 +16,53 @@@
   */
  package com.gemstone.gemfire.pdx;
  
- 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.ByteArrayInputStream;
 +import java.io.DataInputStream;
 +import java.util.Properties;
 +
++import org.junit.Test;
++import org.junit.experimental.categories.Category;
++
  import com.gemstone.gemfire.DataSerializer;
 -import com.gemstone.gemfire.cache.*;
 -import com.gemstone.gemfire.cache.client.*;
 +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.Region;
 +import com.gemstone.gemfire.cache.Scope;
 +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.client.PoolFactory;
 +import com.gemstone.gemfire.cache.client.PoolManager;
  import com.gemstone.gemfire.cache.client.internal.PoolImpl;
  import com.gemstone.gemfire.cache.query.internal.DefaultQuery;
  import com.gemstone.gemfire.cache.server.CacheServer;
--import com.gemstone.gemfire.cache30.CacheTestCase;
  import com.gemstone.gemfire.distributed.internal.DistributionConfig;
  import com.gemstone.gemfire.internal.AvailablePortHelper;
  import com.gemstone.gemfire.internal.HeapDataOutputStream;
  import com.gemstone.gemfire.internal.PdxSerializerObject;
  import com.gemstone.gemfire.internal.Version;
- import com.gemstone.gemfire.pdx.internal.AutoSerializableManager;
 -import com.gemstone.gemfire.test.dunit.*;
 +import com.gemstone.gemfire.test.dunit.Host;
 +import com.gemstone.gemfire.test.dunit.Invoke;
 +import com.gemstone.gemfire.test.dunit.NetworkUtils;
 +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 java.io.ByteArrayInputStream;
 -import java.io.DataInputStream;
 -import java.util.Properties;
 -
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 -
--/**
-- *
-- */
 -public class PdxClientServerDUnitTest extends CacheTestCase {
 +@Category(DistributedTest.class)
 +public class PdxClientServerDUnitTest extends JUnit4CacheTestCase {
  
 -  public PdxClientServerDUnitTest(String name) {
 -    super(name);
 +  public PdxClientServerDUnitTest() {
 +    super();
    }
  
 +  @Test
    public void testSimplePut() {
      Host host = Host.getHost(0);
      VM vm0 = host.getVM(0);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/pdx/PdxSerializableJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/pdx/PdxSerializableJUnitTest.java
index 5d18525,418a819..f38a2eb
--- a/geode-core/src/test/java/com/gemstone/gemfire/pdx/PdxSerializableJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/pdx/PdxSerializableJUnitTest.java
@@@ -16,35 -16,7 +16,36 @@@
   */
  package com.gemstone.gemfire.pdx;
  
 -import com.gemstone.gemfire.*;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
 +
 +import java.io.ByteArrayInputStream;
 +import java.io.ByteArrayOutputStream;
 +import java.io.DataInput;
 +import java.io.DataInputStream;
 +import java.io.File;
 +import java.io.IOException;
 +import java.io.NotSerializableException;
 +import java.io.OutputStreamWriter;
 +import java.io.PrintWriter;
 +import java.nio.ByteBuffer;
 +import java.util.ArrayList;
 +import java.util.Arrays;
 +import java.util.Collection;
 +import java.util.Date;
 +import java.util.HashMap;
 +import java.util.Map;
 +
 +import org.junit.After;
 +import org.junit.Before;
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
 +
 +import com.gemstone.gemfire.CopyHelper;
 +import com.gemstone.gemfire.DataSerializable;
 +import com.gemstone.gemfire.DataSerializer;
 +import com.gemstone.gemfire.DeltaTestImpl;
 +import com.gemstone.gemfire.ToDataException;
  import com.gemstone.gemfire.cache.CacheFactory;
  import com.gemstone.gemfire.cache.DiskStoreFactory;
  import com.gemstone.gemfire.cache.Region;
@@@ -69,10 -43,10 +70,6 @@@ import com.gemstone.gemfire.test.junit.
  @Category(IntegrationTest.class)
  public class PdxSerializableJUnitTest {
    
--  public PdxSerializableJUnitTest() {
--    super();
--  }
--
    private GemFireCacheImpl c;
  
    @Before

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/pdx/PdxStringJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/pdx/PdxStringJUnitTest.java
index c2c652b,f8b3806..a2d3204
--- a/geode-core/src/test/java/com/gemstone/gemfire/pdx/PdxStringJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/pdx/PdxStringJUnitTest.java
@@@ -16,12 -16,12 +16,13 @@@
   */
  package com.gemstone.gemfire.pdx;
  
 -import com.gemstone.gemfire.cache.CacheFactory;
 -import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 -import com.gemstone.gemfire.pdx.internal.PdxInstanceFactoryImpl;
 -import com.gemstone.gemfire.pdx.internal.PdxInstanceImpl;
 -import com.gemstone.gemfire.pdx.internal.PdxString;
 -import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
 +
 +import java.util.Date;
 +import java.util.HashMap;
 +import java.util.Map;
 +
  import it.unimi.dsi.fastutil.objects.Object2ObjectOpenHashMap;
  import org.junit.After;
  import org.junit.Before;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/redis/RedisDistDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/redis/RedisDistDUnitTest.java
index 31d1d85,f4a7308..a55b687
--- a/geode-core/src/test/java/com/gemstone/gemfire/redis/RedisDistDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/redis/RedisDistDUnitTest.java
@@@ -16,30 -16,20 +16,32 @@@
   */
  package com.gemstone.gemfire.redis;
  
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
 +
 +import java.util.Random;
 +
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
 +import redis.clients.jedis.Jedis;
 +
  import com.gemstone.gemfire.cache.CacheFactory;
+ import com.gemstone.gemfire.distributed.DistributedSystemConfigProperties;
  import com.gemstone.gemfire.internal.AvailablePortHelper;
  import com.gemstone.gemfire.internal.SocketCreator;
 -import com.gemstone.gemfire.test.dunit.*;
 +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.SerializableCallable;
 +import com.gemstone.gemfire.test.dunit.VM;
 +import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
 +import com.gemstone.gemfire.test.junit.categories.DistributedTest;
  import com.gemstone.gemfire.test.junit.categories.FlakyTest;
 -import org.junit.experimental.categories.Category;
 -import redis.clients.jedis.Jedis;
  
 -import java.util.Random;
 -
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 -
 -public class RedisDistDUnitTest extends DistributedTestCase {
 +@Category(DistributedTest.class)
 +public class RedisDistDUnitTest extends JUnit4DistributedTestCase {
  
    public static final String TEST_KEY = "key";
    public static int pushes = 200;
@@@ -53,26 -43,26 +55,25 @@@
    private int server1Port;
    private int server2Port;
    
--  private String localHost = SocketCreator.getLocalHost().getHostName();
++  private String localHost;
    
    private static final int JEDIS_TIMEOUT = 20 * 1000;
  
    private abstract class ClientTestBase extends SerializableCallable {
  
      int port;
++
      protected ClientTestBase (int port) {
        this.port = port;
      }
--
--  }
--
--  public RedisDistDUnitTest() throws Throwable {
-     super();
 -    super("RedisDistTest");  
    }
  
    @Override
    public final void postSetUp() throws Exception {
      disconnectAllFromDS();
++
++    localHost = SocketCreator.getLocalHost().getHostName();
++
      host = Host.getHost(0);
      server1 = host.getVM(0);
      server2 = host.getVM(1);
@@@ -82,8 -72,8 +83,6 @@@
      final int locatorPort = DistributedTestUtils.getDUnitLocatorPort();
      final SerializableCallable<Object> startRedisAdapter = new SerializableCallable<Object>() {
  
--      private static final long serialVersionUID = 1978017907725504294L;
--
        @Override
        public Object call() throws Exception {
          int port = ports[VM.getCurrentVMNum()];
@@@ -100,11 -90,11 +99,7 @@@
      };
      AsyncInvocation i = server1.invokeAsync(startRedisAdapter);
      server2Port = (Integer) server2.invoke(startRedisAdapter);
--    try {
--      server1Port = (Integer) i.getResult();
--    } catch (Throwable e) {
--      throw new Exception(e);
--    }
++    server1Port = (Integer) i.getResult();
    }
  
    @Override
@@@ -113,8 -103,7 +108,8 @@@
    }
  
    @Category(FlakyTest.class) // GEODE-1092: random ports, failure stack involves TCPTransport ConnectionHandler (are we eating BindExceptions somewhere?), uses Random, async actions
 -  public void testConcListOps() throws Throwable {
 +  @Test
-   public void testConcListOps() throws Throwable {
++  public void testConcListOps() throws Exception {
      final Jedis jedis1 = new Jedis(localHost, server1Port, JEDIS_TIMEOUT);
      final Jedis jedis2 = new Jedis(localHost, server2Port, JEDIS_TIMEOUT);
      final int pushes = 20;
@@@ -149,8 -138,7 +144,8 @@@
    }
  
    @Category(FlakyTest.class) // GEODE-717: random ports, BindException in failure stack, async actions
 -  public void testConcCreateDestroy() throws Throwable {
 +  @Test
-   public void testConcCreateDestroy() throws Throwable {
++  public void testConcCreateDestroy() throws Exception {
      IgnoredException.addIgnoredException("RegionDestroyedException");
      IgnoredException.addIgnoredException("IndexInvalidException");
      final int ops = 40;
@@@ -208,10 -196,9 +203,9 @@@
  
    /**
     * Just make sure there are no unexpected server crashes
--   * @throws Throwable 
     */
 -  public void testConcOps() throws Throwable {
 +  @Test
-   public void testConcOps() throws Throwable {
++  public void testConcOps() throws Exception {
  
      final int ops = 100;
      final String hKey = TEST_KEY+"hash";

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/security/SecurityTestUtils.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/security/SecurityTestUtils.java
index fbf7fcb,71a0e55..c5bfa4c
--- a/geode-core/src/test/java/com/gemstone/gemfire/security/SecurityTestUtils.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/security/SecurityTestUtils.java
@@@ -92,7 -70,7 +93,7 @@@ import com.gemstone.gemfire.test.dunit.
   */
  public final class SecurityTestUtils {
  
--  private final JUnit4DistributedTestCase distributedTestCase = new JUnit4DistributedTestCase() {}; // TODO: delete
++  private final JUnit4DistributedTestCase distributedTestCase = new JUnit4DistributedTestCase() {};
  
    protected static final int NO_EXCEPTION = 0;
    protected static final int AUTHREQ_EXCEPTION = 1;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/test/dunit/cache/internal/JUnit3CacheTestCase.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/test/dunit/cache/internal/JUnit4CacheTestCase.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/test/dunit/cache/internal/JUnit4CacheTestCase.java
index 59dfffb,bc74ec1..db5be9c
--- a/geode-core/src/test/java/com/gemstone/gemfire/test/dunit/cache/internal/JUnit4CacheTestCase.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/test/dunit/cache/internal/JUnit4CacheTestCase.java
@@@ -49,15 -30,20 +50,17 @@@ import com.gemstone.gemfire.internal.ca
  import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
  import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator;
  import com.gemstone.gemfire.internal.logging.LogService;
 -import com.gemstone.gemfire.test.dunit.*;
 +import com.gemstone.gemfire.test.dunit.Assert;
 +import com.gemstone.gemfire.test.dunit.IgnoredException;
 +import com.gemstone.gemfire.test.dunit.Invoke;
 +import com.gemstone.gemfire.test.dunit.LogWriterUtils;
 +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 org.apache.logging.log4j.Logger;
 -
 -import java.io.File;
 -import java.io.FileWriter;
 -import java.io.IOException;
 -import java.io.PrintWriter;
 -import java.util.Arrays;
 -import java.util.Map;
 -import java.util.Properties;
  
+ import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.MCAST_PORT;
+ 
  /**
   * This class is the base class for all distributed tests using JUnit 4 that
   * require the creation of a {@link Cache}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/test/dunit/internal/JUnit4DistributedTestCase.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/OverridingGetPropertiesDisconnectsAllDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/OverridingGetPropertiesDisconnectsAllDUnitTest.java
index a112391,2bd1f75..0a4b5d7
--- a/geode-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/OverridingGetPropertiesDisconnectsAllDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/OverridingGetPropertiesDisconnectsAllDUnitTest.java
@@@ -16,17 -16,12 +16,17 @@@
   */
  package com.gemstone.gemfire.test.dunit.tests;
  
 -import com.gemstone.gemfire.test.dunit.DistributedTestCase;
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static com.gemstone.gemfire.test.dunit.Invoke.*;
 +import static org.junit.Assert.*;
  
  import java.util.Properties;
  
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.MCAST_PORT;
 -import static com.gemstone.gemfire.test.dunit.Invoke.invokeInEveryVM;
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
 +
- import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 +import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
 +import com.gemstone.gemfire.test.junit.categories.DistributedTest;
  
  /**
   * Verifies that overriding {@code getDistributedSystemProperties} results

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/bd38e10f/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/CQJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/CQJUnitTest.java
index 0ee24cc,ce67542..0cb1c14
--- a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/CQJUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/CQJUnitTest.java
@@@ -16,15 -16,6 +16,16 @@@
   */
  package com.gemstone.gemfire.cache.query.cq;
  
++import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static org.junit.Assert.*;
 +
 +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;
@@@ -43,15 -39,18 +44,11 @@@ public class CQJUnitTest 
    private Cache cache;
    private QueryService qs;
    
--  /////////////////////////////////////
--  // Methods for setUp and tearDown
--  /////////////////////////////////////
- 
 -  
 -  public CQJUnitTest(String name) {
 -    super(name);
 -  }
 -  
 +  @Before
    public void setUp() throws Exception {
      Properties props = new Properties();
-     props.setProperty("mcast-port", "0");
-     props.setProperty("log-level", "config");
+     props.setProperty(MCAST_PORT, "0");
+     props.setProperty(LOG_LEVEL, "config");
      this.ds = DistributedSystem.connect(props);
      this.cache = CacheFactory.create(ds);
      this.qs = cache.getQueryService();
@@@ -63,10 -61,11 +60,6 @@@
      this.ds.disconnect();
    }
  
--  /////////////////////////////////////
--  // Test Methods
--  /////////////////////////////////////
 -  
--  
    /**
     * Test to make sure CQs that have invalid syntax
     * throw QueryInvalidException, and CQs that have unsupported
@@@ -134,18 -132,18 +127,4 @@@
      }
    }
    
--  /* would need to make the constructServerSideQuery method package
--   * accessible and move this to the internal package in order
--   * to test that method
--   * 
--  public void testConstructServerSideQuery() throws Exception {
--    // default attributes
--    CqAttributes attrs = new CqAttributesFactory().create();
--    
--    // valid CQ
--    CqQuery cq = this.qs.newCq("SELECT * FROM /region WHERE status = 'active'",
--                              attrs);
--    Query serverSideQuery = ((CqQueryImpl)cq).constructServerSideQuery();
--  }
--  */
  }